Ignite - In-Memory Data Fabric
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

AboutDialog - Class in org.apache.ignite.startup.cmdline
About dialog.
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
 
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
 
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcDriver
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcThinDriver
accessTime() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file last access time.
ackMessage() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
Called when message passed the ring.
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.
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.
activate() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Activates the job.
active() - Method in interface org.apache.ignite.Ignite
Checks Ignite grid is active or not active.
active(boolean) - Method in interface org.apache.ignite.Ignite
Changes Ignite grid state to active or inactive.
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
Checks if Ignite grid is active.
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.
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.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.IgniteQueue
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteSet
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.
addAppender(FileAppender) - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
Adds file appender.
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
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.
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.
addNodeSpecificData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addPaging(StringBuilder, Pageable) - Static method in class org.apache.ignite.springdata.repository.query.IgniteQueryGenerator
Add a dynamic part of a query for the pagination support.
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.
AddressResolver - Interface in org.apache.ignite.configuration
Provides resolution between external and internal addresses.
addSelectionListener(VisorSelectionListener<UUID>) - Method in interface org.apache.ignite.visor.plugin.VisorPluginNodesPanel
Add selection listener.
addSendMessageListener(IgniteInClosure<TcpDiscoveryAbstractMessage>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
addSorting(StringBuilder, Sort) - Static method in class org.apache.ignite.springdata.repository.query.IgniteQueryGenerator
Add a dynamic part of query for the sorting support.
addTimeoutObject(IgniteSpiTimeoutObject) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
addTimeoutObject(IgniteSpiTimeoutObject) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
addTopologyListener(VisorTopologyListener) - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Install topology listener.
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 cache.
affinity() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets affinity service to provide information about data partitioning and distribution.
affinity(IgfsPath, long, long, long) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Get affinity block locations for data blocks of the file.
affinity(IgfsPath, long, long, long) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Get affinity block locations for data blocks of the file.
affinity(IgfsPath, long, long, long) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Get affinity block locations for data blocks of the file.
affinity(String) - Method in interface org.apache.ignite.Ignite
Gets affinity service to provide information about data partitioning and distribution.
affinity(IgfsPath, long, long) - Method in interface org.apache.ignite.IgniteFileSystem
Gets affinity block locations for data blocks of the file, i.e. the nodes, on which the blocks are stored.
affinity(IgfsPath, long, long, long) - Method in interface org.apache.ignite.IgniteFileSystem
Get affinity block locations for data blocks of the file.
affinity(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets affinity service to provide information about data partitioning and distribution.
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.
affinityCacheName() - Method in interface org.apache.ignite.spi.failover.FailoverContext
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.
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(Object) - Method in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
If key class has annotation AffinityKeyMapped, then the value of annotated method or field will be used to get affinity value instead of the key itself.
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.
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
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.
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.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
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.
afterPropertiesSet() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
afterPropertiesSet() - Method in class org.apache.ignite.IgniteSpringBean
afterPropertiesSet() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
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.
ALL_NODES - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Filter that accepts all nodes.
allGrids() - Static method in class org.apache.ignite.Ignition
Gets a list of all grids started so far.
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).
alreadyProcessed(int) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Checks if row/object with specified sequential number is already processed.
alreadyProcessed(int) - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Checks if row/object with specified sequential number is already processed.
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.
ANONYMOUS_LOGGER_NAME - Static variable in class org.apache.ignite.logger.java.JavaLoggerFormatter
Name for anonymous loggers.
append(IgfsPath, int, boolean, Map<String, String>) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Opens an output stream to an existing file for appending data.
append(Path, int, Progressable) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
append(IgfsPath, int, boolean, Map<String, String>) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Opens an output stream to an existing file for appending data.
append(IgfsPath, int, boolean, Map<String, String>) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Opens an output stream to an existing file for appending data.
append(IgfsPath, boolean) - Method in interface org.apache.ignite.IgniteFileSystem
Opens an output stream to an existing file for appending data.
append(IgfsPath, int, boolean, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
Opens an output stream to an existing file for appending data.
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.
ApplicationMaster - Class in org.apache.ignite.yarn
Application master request containers from Yarn and decides how many resources will be occupied.
ApplicationMaster(String, ClusterProperties) - Constructor for class org.apache.ignite.yarn.ApplicationMaster
 
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(IgniteConfiguration) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Closure body.
apply(T) - Method in interface org.apache.ignite.stream.jms11.MessageTransformer
Transformation function.
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.
argument(int) - Method in class org.apache.ignite.compute.ComputeJobAdapter
Gets job argument.
arguments() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query arguments.
arguments() - Method in class org.apache.ignite.events.CacheQueryReadEvent
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
 
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.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
 
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.
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.
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
 
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_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_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
Node attribute that is mapped to node port number (value is comm.shmem.tcp.port).
attribute(String) - Method in interface org.apache.ignite.cluster.ClusterNode
Gets a node attribute.
attributes() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets all node attributes.
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
 
autoDelete() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets autoDelete flag.
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.
available() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
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.
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.
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

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.
BaseMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Base class to inherit from to implement specific mutations operation.
BaseMutation(String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Creates instance of mutation operation.
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.
BasicHadoopFileSystemFactory - Class in org.apache.ignite.hadoop.fs
Simple Hadoop file system factory which delegates to FileSystem.get() on each call.
BasicHadoopFileSystemFactory() - Constructor for class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Constructor.
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
 
BasicUserNameMapper - Class in org.apache.ignite.hadoop.util
Name mapper which maps one user name to another based on predefined dictionary.
BasicUserNameMapper() - Constructor for class org.apache.ignite.hadoop.util.BasicUserNameMapper
 
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
 
BatchExecutionAssistant<R,V> - Interface in org.apache.ignite.cache.store.cassandra.session
Provides information for batch operations (loadAll, deleteAll, writeAll) of Ignite cache backed by CassandraCacheStore.
BatchLoaderAssistant - Interface in org.apache.ignite.cache.store.cassandra.session
Provides information for loadCache operation of CassandraCacheStore.
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.
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.
binary() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteBinary interface.
binary() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteBinary interface.
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.
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.
bindKey(PreparedStatement, Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Binds Ignite cache key object to PreparedStatement.
bindKeyValue(PreparedStatement, Object, Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Binds Ignite cache key and value object to PreparedStatement.
bindStatement(PreparedStatement, V) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Binds prepared statement to current Cassandra session.
bindStatement(PreparedStatement) - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Binds prepared statement.
bindStatement(PreparedStatement) - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Binds prepared statement to current Cassandra session.
bindStatement(PreparedStatement) - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Binds prepared statement to current Cassandra session.
bindStatement(PreparedStatement) - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Binds prepared statement to current Cassandra session.
blockSize() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file's data block size.
blocksReadRemote() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total remote blocks read.
blocksReadTotal() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total blocks read, local and remote.
blocksWrittenRemote() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total remote blocks written.
blocksWrittenTotal() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total blocks written, local and remote.
body() - Method in class org.apache.ignite.spi.IgniteSpiThread
Body of SPI thread.
bounded() - Method in interface org.apache.ignite.IgniteQueue
Returns true if this queue is bounded.
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.
BUCKET_NAME_PREFIX - Static variable in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Prefix to use in bucket name generation.
build() - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Builds binary object.
build() - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
buildBinaryObject(String, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Construct binary object from query result.
buildClient(BlockingQueue<String>, HttpHosts, StreamingEndpoint) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
 
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.
buildKeyObject(Row) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Builds Ignite cache key object from returned Cassandra table row.
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.
buildValueObject(Row) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Builds Ignite cache value object from Cassandra table row .
BUILT_IN_TYPES - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Built in Java types names.
bundle - Variable in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
The bundle which loaded Ignite.
BundleDelegatingClassLoader - Class in org.apache.ignite.osgi.classloaders
A ClassLoader implementation delegating to a given OSGi bundle, and to the specified ClassLoader as a fallback.
BundleDelegatingClassLoader(Bundle) - Constructor for class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
Constructor.
BundleDelegatingClassLoader(Bundle, ClassLoader) - Constructor for class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
Constructor.
bytesRead() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total bytes read.
bytesReadTime() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total bytes read time.
BytesWritablePartiallyRawComparator - Class in org.apache.ignite.hadoop.io
Partial raw comparator for BytesWritable data type.
BytesWritablePartiallyRawComparator() - Constructor for class org.apache.ignite.hadoop.io.BytesWritablePartiallyRawComparator
 
bytesWriteTime() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total bytes write time.
bytesWritten() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets total bytes written.

C

cache - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
cache() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets base cache for this projection.
cache() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
cache(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCache API.
cache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCache API.
CACHE_ALLOW_OVERWRITE - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
Flag to enable overwriting existing values in cache.
CACHE_CFG_PATH - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
Ignite configuration file path.
CACHE_CFG_PATH - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
Ignite configuration file path.
CACHE_EVENTS - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
Events to be listened to.
CACHE_FILTER_CLASS - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
User-defined filter class.
CACHE_NAME - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
Cache name.
CACHE_NAME - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
Cache name.
CACHE_PER_NODE_DATA_SIZE - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
Size of per-node buffer before data is sent to remote node.
CACHE_PER_NODE_PAR_OPS - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
Maximum number of parallel stream operations per node.
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.EntryMapping(String, JdbcDialect, JdbcType, CacheAbstractJdbcStore.TypeKind, CacheAbstractJdbcStore.TypeKind, boolean) - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
CacheAbstractJdbcStore.TypeKind - Enum in org.apache.ignite.cache.store.jdbc
Type kind.
CacheAtomicityMode - Enum in org.apache.ignite.cache
Cache atomicity mode controls whether cache should maintain fully transactional semantics or more light-weight atomic behavior.
CacheAtomicUpdateTimeoutException - Exception in org.apache.ignite.cache
Exception thrown when atomic operation timeout occurs.
CacheAtomicUpdateTimeoutException(String) - Constructor for exception org.apache.ignite.cache.CacheAtomicUpdateTimeoutException
Creates new timeout exception with given error message.
CacheAtomicUpdateTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheAtomicUpdateTimeoutException
Creates new timeout exception with given error message and optional nested exception.
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.
CacheConfiguration.IgniteAllNodesPredicate() - Constructor for class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
 
CacheEntry<K,V> - Interface in org.apache.ignite.cache
Cache entry that extends Cache.Entry by providing additional entry related information.
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.
CacheEvent - Class in org.apache.ignite.events
In-memory database (cache) event.
CacheEvent(String, ClusterNode, ClusterNode, String, int, int, boolean, Object, IgniteUuid, Object, Object, boolean, Object, boolean, UUID, String, String) - Constructor for class org.apache.ignite.events.CacheEvent
Constructs cache event.
CacheEventConverter - Class in org.apache.ignite.stream.kafka.connect.serialization
CacheEvent converter for Connect API.
CacheEventConverter() - Constructor for class org.apache.ignite.stream.kafka.connect.serialization.CacheEventConverter
 
CacheEventDeserializer - Class in org.apache.ignite.stream.kafka.connect.serialization
Deserializer based on JdkMarshaller.
CacheEventDeserializer() - Constructor for class org.apache.ignite.stream.kafka.connect.serialization.CacheEventDeserializer
 
CacheEventSerializer - Class in org.apache.ignite.stream.kafka.connect.serialization
Serializer based on JdkMarshaller.
CacheEventSerializer() - Constructor for class org.apache.ignite.stream.kafka.connect.serialization.CacheEventSerializer
 
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
 
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.
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.
CacheMetricsMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on IgniteCache.
CacheMode - Enum in org.apache.ignite.cache
Enumeration of all supported caching modes.
cacheName() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Cache name for the current store operation.
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.
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.Ignite
Gets the collection of names of currently available caches.
cacheNames() - Method in class org.apache.ignite.IgniteSpringBean
Gets the collection of names of currently available caches.
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
 
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.
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
 
CacheSpringStoreSessionListener - Class in org.apache.ignite.cache.store.spring
Cache store session listener based on Spring transaction management.
CacheSpringStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
 
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
 
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.
CacheWriteSynchronizationMode - Enum in org.apache.ignite.cache
Mode indicating how Ignite should wait for write replies from other nodes.
CachingHadoopFileSystemFactory - Class in org.apache.ignite.hadoop.fs
Caching Hadoop file system factory.
CachingHadoopFileSystemFactory() - Constructor for class org.apache.ignite.hadoop.fs.CachingHadoopFileSystemFactory
Constructor.
CachingProvider - Class in org.apache.ignite.cache
Implementation of JSR-107 CachingProvider.
CachingProvider() - Constructor for class org.apache.ignite.cache.CachingProvider
 
calculatedField() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Indicates if it's a calculated field - field which value just generated based on other field values.
call() - Method in class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
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.
CamelStreamer<K,V> - Class in org.apache.ignite.stream.camel
This streamer consumes messages from an Apache Camel consumer endpoint and feeds them into an Ignite data streamer.
CamelStreamer() - Constructor for class org.apache.ignite.stream.camel.CamelStreamer
 
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() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsJob
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.igfs.mapreduce.IgfsJobAdapter
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(String) - Method in interface org.apache.ignite.IgniteServices
Cancels service deployment.
cancel() - Method in interface org.apache.ignite.lang.IgniteFuture
Cancels this future.
cancel(ServiceContext) - Method in interface org.apache.ignite.services.Service
Cancels this service.
cancel() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Cancels the job.
cancelAll() - Method in interface org.apache.ignite.IgniteServices
Cancels all deployed services.
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.
capacity() - Method in interface org.apache.ignite.IgniteQueue
Gets maximum number of elements of the queue.
CassandraCacheStore<K,V> - Class in org.apache.ignite.cache.store.cassandra
Implementation of CacheStore backed by Cassandra database.
CassandraCacheStore(DataSource, KeyValuePersistenceSettings, int) - Constructor for class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
Store constructor.
CassandraCacheStoreFactory<K,V> - Class in org.apache.ignite.cache.store.cassandra
Factory class to instantiate CassandraCacheStore.
CassandraCacheStoreFactory() - Constructor for class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
 
CassandraHelper - Class in org.apache.ignite.cache.store.cassandra.common
Helper class providing methods to work with Cassandra session and exceptions
CassandraHelper() - Constructor for class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
 
CassandraSession - Interface in org.apache.ignite.cache.store.cassandra.session
Wrapper around Cassandra driver session, to automatically handle: Keyspace and table absence exceptions Timeout exceptions Batch operations
CassandraSessionImpl - Class in org.apache.ignite.cache.store.cassandra.session
Implementation for CassandraSession.
CassandraSessionImpl(Cluster.Builder, Integer, ConsistencyLevel, ConsistencyLevel, long, IgniteLogger) - Constructor for class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Creates instance of Cassandra driver session wrapper.
cassandraUniqueFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
List of POJO fields having unique mapping to Cassandra columns - skipping aliases pointing to the same Cassandra table column.
centerShow(String, String, String, Date, String) - Static method in class org.apache.ignite.startup.cmdline.AboutDialog
Show about dialog.
CFG_BATCH_SIZE - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
Batch size.
CFG_CACHE_NAME - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
Cache name.
CFG_EVENT_TRANSFORMER - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
Event transformer implementation.
CFG_PATH - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
Ignite configuration file path.
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.
ChainedUserNameMapper - Class in org.apache.ignite.hadoop.util
Chained user name mapper.
ChainedUserNameMapper() - Constructor for class org.apache.ignite.hadoop.util.ChainedUserNameMapper
 
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.
checkDuplicates(List<PojoField>) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Checks if there are POJO filed with the same name or same Cassandra column specified in persistence settings.
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 generated because failure detection timeout has been reached.
checkIgnite() - Method in class org.apache.ignite.IgniteSpringBean
Checks if this bean is valid.
checkIsSplitToJobsAllowed(GridifyRangeArgument, GridifySetToSet) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
Check if split allowed for input argument.
checkIsSplitToJobsAllowed(GridifyRangeArgument, GridifySetToValue) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
Check if split allowed for input argument.
checkMethodSignature(Method) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
Check method signature.
checkMethodSignature(Method) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
Check method signature.
checkPath(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
checkPath(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
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.
checkRingLatency(int) - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Diagnosis method for determining ring message latency.
checkStarvation() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
Checks for starvation in striped pool, dumps in log information if potential starvation was found.
classLoader() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
Gets class loader for the class.
classLoader() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
Gets class loader for the class.
classloaders() - Static method in class org.apache.ignite.osgi.IgniteOsgiUtils
Returns a Map of Ignite instances and the classloaders of the Bundles they were started from.
classLoadingStrategy() - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
Override this method to indicate which classloading strategy to use.
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.
classNotFoundException(String) - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
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.
cleanup() - Method in class org.apache.ignite.stream.storm.StormStreamer
Cleans up the streamer when the bolt is going to shutdown.
clear(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears key on all nodes that store it's data.
clear() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears cache on all nodes that store it's data.
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.IgniteFileSystem
Formats the file system removing all existing entries from it, but not removing anything in secondary file system (if any).
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
clear() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
clearAll(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears keys on all nodes that store it's data.
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) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
clearAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
clearAsync() - Method in interface org.apache.ignite.IgniteFileSystem
Formats the file system removing all existing entries from it, but not removing anything in secondary file system (if any).
clearCache() - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Intended for test purposes only.
clearLocally(boolean, boolean, boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears all entries from this cache only if the entry is not currently locked or participating in a transaction.
clearLocally(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears an entry from this cache and swap storage only if the entry is not currently locked, and is not participating in a transaction.
clearLocallyAll(Set, boolean, boolean, boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears entries from this cache and swap storage only if the entry is not currently locked, and is not participating in a transaction.
clearQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Clear query entities.
clientFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns client failure detection timeout set to use for network related operations.
clientReconnectFuture() - Method in interface org.apache.ignite.IgniteCluster
If local client node disconnected from cluster returns future that will be completed when client reconnected.
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 interface org.apache.ignite.cache.query.QueryCursor
Closes all resources related to this cursor.
close() - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
close() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
close() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
close(ClientProtocol) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
close() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
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 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 class org.apache.ignite.stream.kafka.connect.serialization.CacheEventDeserializer
close() - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventSerializer
close() - Method in class org.apache.ignite.stream.zeromq.IgniteZeroMqStreamer
Stops ZeroMQ streamer.
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.
closeSession(Session) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Closes Cassandra driver session.
closureClassName() - Method in class org.apache.ignite.events.CacheEvent
Gets closure class name (applicable only for TRANSFORM operations).
clsLdr - Variable in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
The fallback classloader, expected to be the ignite-core classloader.
cluster() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCluster interface.
cluster() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCluster interface.
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.
ClusterLocalNodeMetricsMXBean - Interface in org.apache.ignite.mxbean
MBean for local node metrics.
clusterMetrics() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets whole cluster metrics (statistics) for this cache.
clusterMetrics(ClusterGroup) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets cluster group metrics (statistics) for this cache.
ClusterMetrics - Interface in org.apache.ignite.cluster
This class represents runtime information on a cluster.
clusterMxBean() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets whole cluster metrics (statistics) for this cache.
clusterName() - Method in class org.apache.ignite.mesos.ClusterProperties
 
clusterName() - Method in class org.apache.ignite.yarn.ClusterProperties
 
ClusterNode - Interface in org.apache.ignite.cluster
Interface representing a single cluster node.
ClusterProperties - Class in org.apache.ignite.mesos
The class defines cluster configuration.
ClusterProperties() - Constructor for class org.apache.ignite.mesos.ClusterProperties
 
ClusterProperties - Class in org.apache.ignite.yarn
Cluster settings.
ClusterProperties() - Constructor for class org.apache.ignite.yarn.ClusterProperties
 
ClusterStartNodeResult - Interface in org.apache.ignite.cluster
Cluster start node result information.
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.
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
 
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.
colocateFileWrites(boolean) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Public setter that can be used by direct users of FS or Visor.
colocateFileWrites(boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
Public setter that can be used by direct users of FS or Visor.
columnIndex(Map<String, Integer>, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Find column index by database name.
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.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.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
 
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.
compare(BytesWritable, RawMemory) - Method in class org.apache.ignite.hadoop.io.BytesWritablePartiallyRawComparator
Do compare.
compare(BytesWritable, long, int) - Method in class org.apache.ignite.hadoop.io.BytesWritablePartiallyRawComparator
Perform compare.
compare(T, RawMemory) - Method in interface org.apache.ignite.hadoop.io.PartiallyRawComparator
Do compare.
compare(Text, RawMemory) - Method in class org.apache.ignite.hadoop.io.TextPartiallyRawComparator
Do compare.
compare(Text, long, int) - Method in class org.apache.ignite.hadoop.io.TextPartiallyRawComparator
Perform compare.
compare(String, String) - Method in class org.apache.ignite.yarn.IgniteProvider.VersionComparator
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(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
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.
components() - Method in class org.apache.ignite.igfs.IgfsPath
Split full path on components.
componentsArray() - Method in class org.apache.ignite.igfs.IgfsPath
Get components in array form.
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.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.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.
ComputeLoadBalancer - Interface in org.apache.ignite.compute
Load balancer is used for finding the best balanced node according to load balancing policy.
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.
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 interface org.apache.ignite.transactions.Transaction
Cache transaction concurrency mode.
config() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkConnector
config() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
CONFIG_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
configInfo(String, Object) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformed string for configuration parameter.
configName() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
configuration() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets configuration bean for this cache.
configuration() - Method in interface org.apache.ignite.Ignite
Gets the configuration of this Ignite instance.
configuration() - Method in interface org.apache.ignite.IgniteFileSystem
Gets IGFS configuration.
configuration() - Method in class org.apache.ignite.IgniteSpringBean
Gets the configuration of this Ignite instance.
configure(Context) - Method in class org.apache.ignite.stream.flume.IgniteSink
Sink configurations with Ignite-specific settings.
configure(Map<String, ?>, boolean) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventConverter
configure(Map<String, ?>, boolean) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventDeserializer
configure(Map<String, ?>, boolean) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventSerializer
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.TcpCommunicationSpi.HandshakeMessage
 
connected() - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Whether Visor connected to the grid.
connection() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage2
connectionLost(Throwable) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Implements the MqttCallback.connectionLost(Throwable) callback method for the MQTT client to inform the streamer that the connection has been lost.
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.
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.tcp.TcpDiscoverySpi
Gets consistent ID.
consumeMessage(List<MessageExt>, ConsumeConcurrentlyContext) - Method in class org.apache.ignite.stream.rocketmq.RocketMQStreamer
Implements MessageListenerConcurrently.consumeMessage(List, ConsumeConcurrentlyContext) to receive messages.
container() - Method in interface org.apache.ignite.visor.plugin.VisorPluginComponent
Get component container.
ContainerSweepClassLoader - Class in org.apache.ignite.osgi.classloaders
A ClassLoader implementation that first attempts to load the class from the associated Bundle.
ContainerSweepClassLoader(Bundle) - Constructor for class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
Constructor with a Bundle only.
ContainerSweepClassLoader(Bundle, ClassLoader) - Constructor for class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
Constructor with a Bundle and another ClassLoader to check.
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.IgniteQueue
containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
containsField(List<PojoField>, String) - Static method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Checks if list contains POJO field with the specified name.
containsKey(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
containsKeyAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains an entry for the specified key.
containsKeys(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Determines if the Cache contains entries for the specified keys.
containsKeysAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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
context() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
controller() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Service method to get persistence controller instance
convert(Exception) - Method in interface org.apache.ignite.cache.hibernate.HibernateExceptionConverter
 
convert(byte[]) - Method in interface org.apache.ignite.stream.socket.SocketMessageConverter
Converter message represented by array of bytes to object.
copyLocalToHdfs(FileSystem, String, String) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
copyright() - Method in interface org.apache.ignite.plugin.PluginProvider
 
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.springdata.repository.support.IgniteRepositoryImpl
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.
COUNTER_WRITER_DIR_PROPERTY - Static variable in class org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter
 
COURTESY_LOGGER_NAME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Courtesy notice log category.
CPU - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Cpus.
cpuCores - Variable in class org.apache.ignite.mesos.IgniteTask
 
cpuCores() - Method in class org.apache.ignite.mesos.IgniteTask
 
cpuCores - Variable in class org.apache.ignite.yarn.IgniteContainer
 
cpuCores() - Method in class org.apache.ignite.yarn.IgniteContainer
 
cpus() - Method in class org.apache.ignite.mesos.ClusterProperties
 
cpus(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets CPU count limit.
cpusPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
cpusPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets CPU count limit.
cpusPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
cpusPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets CPU count limit.
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.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.cassandra.CassandraCacheStoreFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
create() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
create(IgfsPath, boolean) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Creates a file and opens it for writing.
create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Creates a file and opens it for writing.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
create(Configuration) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
create(InetSocketAddress, Configuration) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
create(IgfsPath, boolean) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Creates a file and opens it for writing.
create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Creates a file and opens it for writing.
create(IgfsPath, boolean) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Creates a file and opens it for writing.
create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Creates a file and opens it for writing.
create(IgfsPath, boolean) - Method in interface org.apache.ignite.IgniteFileSystem
Creates a file and opens it for writing.
create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
Creates a file and opens it for writing.
create(IgfsPath, int, boolean, IgniteUuid, int, long, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
Creates a file and opens it for writing.
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
Creates new message instance of provided type.
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 class org.apache.ignite.ssl.SslContextFactory
createCache(String, C) - Method in class org.apache.ignite.cache.CacheManager
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(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.
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.
createConsoleLogger() - Static method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates console appender with some reasonable default logging settings.
createDefaultPolicyConfig() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Creates a configuration for the default memory policy that will instantiate the default memory region.
createInternal(Path, EnumSet<CreateFlag>, FsPermission, int, short, long, Progressable, Options.ChecksumOpt, boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
createJob(IgfsPath, IgfsFileRange, IgfsTaskArgs<T>) - Method in class org.apache.ignite.igfs.mapreduce.IgfsTask
Callback invoked during task map procedure to create job that will process specified split for IGFS file.
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.
createPanel(VisorPluginComponentsFactory, JPanel) - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
Construct content of pluggable tab.
createPojoField(Element, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates instance of PojoField based on it's description in XML element.
createPojoField(PojoFieldAccessor) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates instance of PojoField from its field accessor.
createPojoField(Element, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Creates instance of PojoField based on it's description in XML element.
createPojoField(PojoFieldAccessor) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Creates instance of PojoField from its field accessor.
createPojoField(Element, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates instance of PojoField based on it's description in XML element.
createPojoField(PojoFieldAccessor) - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates instance of PojoField from its field accessor.
createRepositoryFactory() - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactoryBean
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.
createTokenBuffer(Credentials) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
Creates a ByteBuffer with serialized Credentials.
Credentials - Interface in org.apache.ignite.cache.store.cassandra.datasource
Provides credentials for Cassandra (instead of specifying user/password directly in Spring context XML).
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.
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.
currentUser() - Static method in class org.apache.ignite.igfs.IgfsUserContext
Gets the current context user.

D

DataPageEvictionMode - Enum in org.apache.ignite.configuration
Defines memory page eviction algorithm.
dataSize() - Method in class org.apache.ignite.events.IgfsEvent
Transferred data size for this event.
DataSource - Class in org.apache.ignite.cache.store.cassandra.datasource
Data source abstraction to specify configuration of the Cassandra session to be used.
DataSource() - Constructor for class org.apache.ignite.cache.store.cassandra.datasource.DataSource
 
dataSrc - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Data source.
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
 
DDLGenerator - Class in org.apache.ignite.cache.store.cassandra.utils
Generates Cassandra DDL statements from persistence descriptor xml file.
DDLGenerator() - Constructor for class org.apache.ignite.cache.store.cassandra.utils.DDLGenerator
 
debug(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.log4j.Log4JLogger
Logs out debug message.
debug(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.
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.ignite.stream.storm.StormStreamer
Normally declares output fields for the stream of the topology.
decrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Decrements and gets current value of atomic long.
DEFAULT_CLUSTER_NAME - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_CLUSTER_NAME - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_CONFIG - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
DEFAULT_CPU_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_HTTP_SERVER_PORT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_IGNITE_CONFIG - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
DEFAULT_IGNITE_LOCAL_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_RELEASES_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_VERSION - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_IGNITE_WORK_DIR - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_IGNITE_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_MEM_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_MESOS_MASTER_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_MINIMUM_MEM_OVERHEAD_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
The minimum memory overhead: overhead is by default 0.1* MEMORY_PER_NODE, with a minimum of DEFAULT_MINIMUM_MEM_OVERHEAD_PER_NODE.
DEFAULT_PORT - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Default port range.
DEFAULT_PORT - Static variable in class org.apache.ignite.yarn.ApplicationMaster
Default port range.
DEFAULT_RESOURCE_MIN_CPU - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_RESOURCE_MIN_MEM - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
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.
defaultColumnName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns default name for Cassandra column (if it's not specified explicitly).
defaultColumnName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns default name for Cassandra column (if it's not specified explicitly).
defaultColumnName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Returns default name for Cassandra column (if it's not specified explicitly).
delete(Object) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
delete(Object) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
delete(IgfsPath, boolean) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Deletes file.
delete(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
delete(Path, boolean) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
delete(Path, boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
delete(IgfsPath, boolean) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Deletes file.
delete(IgfsPath, boolean) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Deletes file.
delete(IgfsPath, boolean) - Method in interface org.apache.ignite.IgniteFileSystem
Deletes file.
delete(ID) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
delete(T) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
delete(Iterable<? extends T>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
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.cassandra.CassandraCacheStore
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
deleteAll(Iterable<ID>) - Method in interface org.apache.ignite.springdata.repository.IgniteRepository
Deletes all the entities for the provided ids.
deleteAll(Iterable<ID>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
Deletes all the entities for the provided ids.
deleteAll() - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
DeleteMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Mutation which deletes object from Cassandra.
DeleteMutation(Object, String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Creates instance of delete mutation operation.
DELIM - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Delimiter char.
DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Delimiter to use in S3 entries name.
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.
DELIM - Static variable in class org.apache.ignite.yarn.ApplicationMaster
Delimiter char.
deliveryComplete(IMqttDeliveryToken) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Empty implementation of MqttCallback.deliveryComplete(IMqttDeliveryToken).
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).
deployAsync(ServiceConfiguration) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple instances of the service on the grid according to provided configuration.
deployClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
Gets top level user class being deployed.
deployClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
Gets top level user class being deployed.
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.
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.
depth() - Method in class org.apache.ignite.igfs.IgfsPath
Return the number of elements in this path.
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.
deserialize() - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
deserialize(ByteBuffer) - Method in class org.apache.ignite.cache.store.cassandra.serializer.JavaSerializer
Deserializes object from byte buffer.
deserialize(ByteBuffer) - Method in class org.apache.ignite.cache.store.cassandra.serializer.KryoSerializer
Deserializes object from byte buffer.
deserialize(ByteBuffer) - Method in interface org.apache.ignite.cache.store.cassandra.serializer.Serializer
Deserializes object from byte buffer.
deserialize(String, byte[]) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventDeserializer
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.Ignite
Stops dynamically started cache.
destroyCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Stops dynamically started cache.
destroyCaches(Collection<String>) - Method in interface org.apache.ignite.Ignite
Stops dynamically started caches.
destroyCaches(Collection<String>) - Method in class org.apache.ignite.IgniteSpringBean
Stops dynamically started caches.
destroySession(String) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
detectPojoFields(NodeList) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Extracts POJO fields from a list of corresponding XML field nodes.
DFLT_ACCESS_TYPE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
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
Default value for active on start flag.
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.configuration.AtomicConfiguration
Default atomic sequence reservation size.
DFLT_AUTO_UNSUBSCRIBE - Static variable in class org.apache.ignite.cache.query.ContinuousQuery
Default value for automatic unsubscription flag.
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_BLOCK_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default file's data block size (bytes).
DFLT_BUCKET_NAME_SUFFIX - Static variable in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Suffix to use in bucket name generation.
DFLT_BUF_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default read/write buffers size (bytes).
DFLT_BUFFER_SIZE - Static variable in class org.apache.ignite.marshaller.AbstractMarshaller
Default initial buffer size for the GridByteArrayOutputStream.
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.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_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
Default cache property name.
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_CHECKPOINT_TABLE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint table name (value is CHECKPOINTS).
DFLT_CHECKPOINTING_FREQ - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
DFLT_CHECKPOINTING_THREADS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
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_COLOCATE_META - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default value of metadata co-location flag.
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_COPY_ON_READ - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'copyOnRead' flag.
DFLT_CORE_POOL_SIZE - Static variable in class org.apache.ignite.thread.IgniteThreadPoolExecutor
Default core pool size (value is 100).
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_STREAMER_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of data streamer thread pool.
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 GAR files.
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_DISCOVERY_STARTUP_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default discovery startup delay in milliseconds (value is 60,000ms).
DFLT_EAGER_TTL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for eager ttl 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_EXTERNAL_EXECUTION - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
Default value for external execution flag.
DFLT_FAILURE_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default failure detection timeout in millis.
DFLT_FINISHED_JOB_INFO_TTL - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
Default finished job info time-to-live.
DFLT_FRAGMENTIZER_CONCURRENT_FILES - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default fragmentizer concurrent files.
DFLT_FRAGMENTIZER_ENABLED - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Fragmentizer enabled property.
DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default fragmentizer throttling block length.
DFLT_FRAGMENTIZER_THROTTLING_DELAY - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default fragmentizer throttling delay.
DFLT_GRID_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default grid count to warm up.
DFLT_GRP - Static variable in class org.apache.ignite.spi.IgniteSpiThread
Default thread's group.
DFLT_GRP_SIZE - Static variable in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
Default group size.
DFLT_HOST - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default host.
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.ConnectorConfiguration
Default REST idle timeout.
DFLT_IGFS_LOG_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default batch size for logging.
DFLT_IGFS_LOG_DIR - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default IGFS log directory.
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_IPC_ENDPOINT_ENABLED - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default IPC endpoint enabled flag.
DFLT_ITERATION_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default iteration count per thread.
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_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 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_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_LOC_MAPPER_WEIGHT - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Default local mapper weight.
DFLT_LOC_REDUCER_WEIGHT - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Default local reducer weight.
DFLT_LOCK_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default lock timeout.
DFLT_LOCK_WAIT_TIME - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
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
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_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_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.SqlConnectorConfiguration
Default max number of open cursors per connection.
DFLT_MAX_PARALLEL_OPS - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default max concurrent put operations count.
DFLT_MAX_PARALLEL_TASKS - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
Default value for the max parallel tasks.
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_MAX_TASK_QUEUE_SIZE - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
Default value for the max task queue size.
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
This name is assigned to default MemoryPolicy if no user-defined default MemPlc is specified
DFLT_MEM_SIZE - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default shared memory space in bytes.
DFLT_MEMORY_POLICY_INITIAL_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Default memory policy start size (256 MB).
DFLT_MEMORY_POLICY_MAX_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Default memory policy's size is 80% of physical memory available on current machine.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Default metrics enabled flag.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
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_PORT - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default management port.
DFLT_MGMT_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of management thread pool.
DFLT_MODE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default IGFS mode.
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_NEAR_START_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Initial default near cache size.
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_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_SIZE - Static variable in class org.apache.ignite.cache.query.ContinuousQuery
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.MemoryConfiguration
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_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_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default per node buffer size.
DFLT_PER_NODE_BUFFER_SIZE - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default per node buffer size.
DFLT_PER_NODE_PARALLEL_BATCH_CNT - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default number of per node parallel operations.
DFLT_PESSIMISTIC_TX_LOG_LINGER - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default size of pessimistic transactions log.
DFLT_PORT - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
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.ConnectorConfiguration
Default rest port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
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_PREFER_LOCAL_REDUCER_THRESHOLD_WEIGHT - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Default reducer migration threshold weight.
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_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_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.MemoryPolicyConfiguration
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
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
Default rebalance batch size in bytes.
DFLT_REBALANCE_BATCHES_PREFETCH_COUNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default rebalance batches prefetch count.
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
Deprecated.
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
Time in milliseconds to wait between rebalance messages to avoid overloading CPU.
DFLT_REBALANCE_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default rebalance timeout (ms).
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_RELAXED_CONSISTENCY - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default value of relaxed consistency flag.
DFLT_RELOGIN_INTERVAL - Static variable in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
The default interval used to re-login from the key tab, in milliseconds.
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_RMT_MAPPER_WEIGHT - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Default remote mapper weight.
DFLT_RMT_REDUCER_WEIGHT - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Default remote reducer weight.
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_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_SESSION_EXPIRATION_TIMEOUT - Static variable in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Default expiration timeout for Cassandra driver session.
DFLT_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default port which node sets listener for shared memory connections (value is 48100).
DFLT_SIMPLE_NAME - Static variable in class org.apache.ignite.binary.BinaryBasicNameMapper
Default use simple name flag setting.
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
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_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_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 store type.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Default amount of sub intervals to calculate MemoryMetrics.getAllocationRate() metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default amount of sub intervals to calculate rate-based metric.
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.SqlConnectorConfiguration
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.igfs.IgfsIpcEndpointConfiguration
Default threads 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.OdbcConfiguration
Deprecated.
Default size of thread pool.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
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_TIME_INTERVAL - Static variable in class org.apache.ignite.cache.query.ContinuousQuery
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_TLB_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default thread local buffer size.
DFLT_TOKEN_DIR_PATH - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default token directory.
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.TransactionConfiguration
Default transaction timeout.
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.TransactionConfiguration
Default transaction isolation level.
DFLT_TX_SERIALIZABLE_ENABLED - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default value for 'txSerializableEnabled' flag.
DFLT_TYPE - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default endpoint type is TCP.
DFLT_UNLIMIT_TIMEOUT - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default timeout for streamer's operations.
DFLT_UPDATE_FILE_LEN_ON_FLUSH - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default value of update file length on flush flag.
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_USER_NAME - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default file system user name.
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.PersistentStoreConfiguration
Default wal always write full pages.
DFLT_WAL_ARCHIVE_PATH - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default wal archive directory.
DFLT_WAL_FLUSH_FREQ - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default Wal flush frequency.
DFLT_WAL_FSYNC_DELAY - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default wal fsync delay.
DFLT_WAL_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default number of checkpoints to be kept in WAL after checkpoint is finished
DFLT_WAL_MODE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default wal mode.
DFLT_WAL_RECORD_ITERATOR_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default wal record iterator buffer size.
DFLT_WAL_SEGMENT_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Default WAL file segment size, 64MBytes
DFLT_WAL_SEGMENTS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
DFLT_WAL_STORE_PATH - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
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.
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.
directoriesCount() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets number of directories created in file system.
directoriesCount() - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
directoriesCount(int) - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
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.TcpCommunicationSpi.HandshakeMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage2
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
Gets message type.
disableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Disables provided events.
disableMetrics() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Disables memory metrics collection on an Apache Ignite node.
disableMetrics() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Disables persistence metrics collection on an Apache Ignite node.
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.tcp.TcpDiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnected(SchedulerDriver) - Method in class org.apache.ignite.mesos.IgniteScheduler
discoveryClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
 
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) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
DiscoveryDataBag(UUID, Set<Integer>) - 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.
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.
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.
disk() - Method in class org.apache.ignite.mesos.ClusterProperties
 
DISK - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Disk.
disk - Variable in class org.apache.ignite.mesos.IgniteTask
 
disk() - Method in class org.apache.ignite.mesos.IgniteTask
 
diskPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
doAs(String, IgniteOutClosure<T>) - Static method in class org.apache.ignite.igfs.IgfsUserContext
Executes given callable in the given user context.
doAs(String, Callable<T>) - Static method in class org.apache.ignite.igfs.IgfsUserContext
Same contract that IgfsUserContext.doAs(String, IgniteOutClosure) has, but accepts callable that throws checked Exception.
doBegin(Object, TransactionDefinition) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doCleanupAfterCompletion(Object) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doCommit(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
doGetTransaction() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doRollback(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
DOWNLOAD_LINK - Static variable in class org.apache.ignite.yarn.IgniteProvider
 
downloadIgnite(String) - Method in class org.apache.ignite.mesos.resource.IgniteProvider
 
drainPermits() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires and returns all permits that are immediately available.
driverSession() - Method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionWrapper
Returns wrapped Cassandra driver session.
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.
dumpNodeStatistics(UUID) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
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
 

E

EMPTY_STRING - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
enabledEvents() - Method in interface org.apache.ignite.IgniteEvents
Gets types of enabled events.
EnableIgniteRepositories - Annotation Type in org.apache.ignite.springdata.repository.config
Annotation to activate Apache Ignite repositories.
enableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Enables provided events.
enableManagement(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
enableMetrics() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Enables memory metrics collection on an Apache Ignite node.
enableMetrics() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Enables persistence metrics collection on an Apache Ignite node.
enableStatistics(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
end(Connection, Statement) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes allocated resources depending on transaction status.
endTime() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
 
enhance(T) - Static method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringEnhancer
Enhances the object on load.
ensured(TcpDiscoveryAbstractMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
entrySet() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets set of all entries cached on this node.
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
 
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.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.hadoop.HadoopInputSplit
This method must be implemented for purpose of internal implementation.
equals(Object) - Method in class org.apache.ignite.igfs.IgfsPath
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
equalsIgnoreNodeFilter(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
Checks if configurations are equal ignoring the node filter.
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) - 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) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out error message.
error(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) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs error message with optional exception.
error(SchedulerDriver, String) - Method in class org.apache.ignite.mesos.IgniteScheduler
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
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.
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.
EventTransformer<Event,K,V> - Interface in org.apache.ignite.stream.flume
Flume event transformer to convert a list of Flume Events to cache entries.
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.
evict(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove object from cache without regard to transaction.
evict(Ignite, HibernateCacheProxy, Object) - Static method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove object from cache without regard to transaction.
evict(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Evicts entry associated with given key from cache.
EvictableEntry<K,V> - Interface in org.apache.ignite.cache.eviction
Evictable cache entry passed into EvictionPolicy.
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove all data from cache without regard to transaction.
evictAll(IgniteInternalCache<Object, Object>) - Static method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove all data from cache without regard to transaction.
evictAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Attempts to evict all entries associated with keys.
evictAllowed(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.eviction.EvictionFilter
Checks if entry may be evicted from cache.
evictAllowed(Cache.Entry) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsEvictionFilter
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.
EvictionPolicy<K,V> - Interface in org.apache.ignite.cache.eviction
Pluggable cache eviction policy.
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_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_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: checkpoint was loaded.
EVT_CHECKPOINT_REMOVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: checkpoint was removed.
EVT_CHECKPOINT_SAVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: 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_IGFS_DIR_CREATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS directory created.
EVT_IGFS_DIR_DELETED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS directory deleted.
EVT_IGFS_DIR_RENAMED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS directory renamed.
EVT_IGFS_FILE_CLOSED_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file closed.
EVT_IGFS_FILE_CLOSED_WRITE - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file closed.
EVT_IGFS_FILE_CREATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file created.
EVT_IGFS_FILE_DELETED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file deleted.
EVT_IGFS_FILE_OPENED_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file opened for reading.
EVT_IGFS_FILE_OPENED_WRITE - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file opened for writing.
EVT_IGFS_FILE_PURGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file purged.
EVT_IGFS_FILE_RENAMED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file renamed.
EVT_IGFS_META_UPDATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: IGFS file or directory metadata updated.
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_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_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_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.
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_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_IGFS - Static variable in interface org.apache.ignite.events.EventType
All Igfs events.
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.
exchange - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Data exchange.
exclude(IgfsPath) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Check whether provided path must be excluded from evictions.
execute(ExecutionAssistant<V>) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Execute single synchronous operation against Cassandra database.
execute(BatchExecutionAssistant<R, V>, Iterable<? extends V>) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Executes batch asynchronous operation against Cassandra database.
execute(BatchLoaderAssistant) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Executes batch asynchronous operation to load bunch of records specified by CQL statement from Cassandra database
execute(List<Mutation>) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Executes all the mutations performed withing Ignite transaction against Cassandra database.
execute(ExecutionAssistant<V>) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Execute single synchronous operation against Cassandra database.
execute(BatchExecutionAssistant<R, V>, Iterable<? extends V>) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Executes batch asynchronous operation against Cassandra database.
execute(BatchLoaderAssistant) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Executes batch asynchronous operation to load bunch of records specified by CQL statement from Cassandra database
execute(List<Mutation>) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Executes all the mutations performed withing Ignite transaction against Cassandra database.
execute() - Method in interface org.apache.ignite.compute.ComputeJob
Executes this job.
execute(IgniteCompute, Class<?>, GridifyRangeArgument, GridifyNodeFilter, int, int, long) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
Execute method on grid.
execute(Method, IgniteCompute, Class<?>, GridifyRangeArgument, GridifyNodeFilter, int, int, long) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
Execute method on grid.
execute(IgniteFileSystem, IgfsFileRange, IgfsInputStream) - Method in class org.apache.ignite.igfs.mapreduce.IgfsInputStreamJobAdapter
Executes this job.
execute(IgniteFileSystem, IgfsRangeInputStream) - Method in class org.apache.ignite.igfs.mapreduce.IgfsInputStreamJobAdapter
Executes this job.
execute(IgniteFileSystem, IgfsFileRange, IgfsInputStream) - Method in interface org.apache.ignite.igfs.mapreduce.IgfsJob
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(IgfsTask<T, R>, IgfsRecordResolver, Collection<IgfsPath>, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task.
execute(IgfsTask<T, R>, IgfsRecordResolver, Collection<IgfsPath>, boolean, long, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task with overridden maximum range length (see FileSystemConfiguration.getMaximumTaskRangeLength() for more information).
execute(Class<? extends IgfsTask<T, R>>, IgfsRecordResolver, Collection<IgfsPath>, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task.
execute(Class<? extends IgfsTask<T, R>>, IgfsRecordResolver, Collection<IgfsPath>, boolean, long, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task with overridden maximum range length (see FileSystemConfiguration.getMaximumTaskRangeLength() for more information).
execute(ServiceContext) - Method in interface org.apache.ignite.services.Service
Starts execution of this service.
execute(Object[]) - Method in class org.apache.ignite.springdata.repository.query.IgniteRepositoryQuery
execute(Tuple) - Method in class org.apache.ignite.stream.storm.StormStreamer
Transfers data into grid.
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(Class<? extends ComputeTask<A, R>>, Collection<UUID>, A) - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Executes given task on this grid projection.
execute(String, Collection<UUID>, A) - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Executes given task on this grid projection.
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.
executeAsync(IgfsTask<T, R>, IgfsRecordResolver, Collection<IgfsPath>, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task asynchronously.
executeAsync(IgfsTask<T, R>, IgfsRecordResolver, Collection<IgfsPath>, boolean, long, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task asynchronously with overridden maximum range length (see FileSystemConfiguration.getMaximumTaskRangeLength() for more information).
executeAsync(Class<? extends IgfsTask<T, R>>, IgfsRecordResolver, Collection<IgfsPath>, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task asynchronously.
executeAsync(Class<? extends IgfsTask<T, R>>, IgfsRecordResolver, Collection<IgfsPath>, boolean, long, T) - Method in interface org.apache.ignite.IgniteFileSystem
Executes IGFS task asynchronously with overridden maximum range length (see FileSystemConfiguration.getMaximumTaskRangeLength() for more information).
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.
ExecutionAssistant<R> - Interface in org.apache.ignite.cache.store.cassandra.session
Provides information for single operations (load, delete, write) of Ignite cache backed by CassandraCacheStore.
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.
executor() - Method in interface org.apache.ignite.plugin.extensions.communication.IoPool
Gets the Executor for this Pool.
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.
executorLost(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, int) - Method in class org.apache.ignite.mesos.IgniteScheduler
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.
exists(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Checks if the specified path exists.
exists(IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Checks if the specified path exists.
exists(IgfsPath) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Checks if the specified path exists.
exists(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Checks if the specified path exists in the file system.
exists(ID) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
expired() - Method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionWrapper
Checks if Cassandra driver session expired.
expiry() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Extension - Interface in org.apache.ignite.plugin
Marker interface for extensions.
ExtensionRegistry - Interface in org.apache.ignite.plugin
Context that allows to register extensions.
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.
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.tcp.TcpDiscoverySpi
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.
FailoverContext - Interface in org.apache.ignite.spi.failover
This interface defines a set of operations available to failover SPI one a given failed job.
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.
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.
failures() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets number of times a query execution failed.
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.
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.
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.TcpCommunicationSpi.HandshakeMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
Gets fields count.
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.
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.log4j.Log4JLogger
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.
filesCount() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets number of files stored in file system.
filesCount() - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
filesCount(int) - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
filesOpenedForRead() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets number of files that are currently opened for reading.
filesOpenedForWrite() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets number of files that are currently opened for writing.
fileSystem(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of IGFS (Ignite In-Memory File System).
fileSystem(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IGFS (Ignite In-Memory File System).
FileSystemConfiguration - Class in org.apache.ignite.configuration
IGFS configuration.
FileSystemConfiguration() - Constructor for class org.apache.ignite.configuration.FileSystemConfiguration
Constructs default configuration.
FileSystemConfiguration(FileSystemConfiguration) - Constructor for class org.apache.ignite.configuration.FileSystemConfiguration
Constructs the copy of the configuration.
FileSystemResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of primary Ignite filesystem to a secondary filesystem implementation.
fileSystems() - Method in interface org.apache.ignite.Ignite
Gets all instances of IGFS (Ignite In-Memory File System).
fileSystems() - Method in class org.apache.ignite.IgniteSpringBean
Gets all instances of IGFS (Ignite In-Memory File System).
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
 
finalize() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
findAll() - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
findAll(Iterable<ID>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
findClass(String) - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
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
 
findOne(ID) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
findPropertyDescriptor(List<PropertyDescriptor>, String) - Static method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Extracts property descriptor from the descriptors list by its name.
findResource(String) - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
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.
findResources(String) - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
Finds a given resource from within the BundleDelegatingClassLoader.bundle.
findValueType() - Method in class org.apache.ignite.cache.QueryEntity
Attempts to get value type from fields in case it was not set directly.
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.JavaLoggerFileHandler
flush(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
Pushes buffered data to grid.
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.
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.cluster.ClusterGroup
Creates a cluster group of nodes started in client mode.
forDaemons() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a cluster group consisting from the daemon nodes.
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.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.cluster.ClusterGroup
Creates a cluster group for the given node.
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.cluster.ClusterGroup
Creates a cluster group over nodes with specified node IDs.
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.cluster.ClusterGroup
Creates a cluster group with one oldest node from the current 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(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.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.cluster.ClusterGroup
Creates a cluster group of nodes started in server mode.
forSubjectId(UUID) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Creates projection for specified subject ID.
forYoungest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one youngest node in the current cluster group.
FRAMEWORK_NAME - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
Framework name used in configuration.
frameworkMessage(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, byte[]) - Method in class org.apache.ignite.mesos.IgniteScheduler
from(String) - Static method in class org.apache.ignite.mesos.ClusterProperties
 
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.
from(String) - Static method in class org.apache.ignite.yarn.ClusterProperties
 
from() - Static method in class org.apache.ignite.yarn.ClusterProperties
 
fromBytes(byte[]) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Deserialize object from byte array using marshaller.
fromConnectData(String, Schema, Object) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventConverter
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheMode
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(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.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.WALMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.igfs.IgfsMode
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(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 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 GridUuid.
fromUuid(UUID) - Static method in class org.apache.ignite.lang.IgniteUuid
Constructs new GridUuid based on global and local ID portions.
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

generateSql(Method, RepositoryMetadata) - Static method in class org.apache.ignite.springdata.repository.query.IgniteQueryGenerator
 
GenericBatchExecutionAssistant<R,V> - Class in org.apache.ignite.cache.store.cassandra.session
Implementation of the BatchExecutionAssistant.
GenericBatchExecutionAssistant() - Constructor for class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
 
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves value mapped to the specified key from cache.
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
get(CassandraSessionImpl) - Static method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
Extracts Cassandra driver session from pool.
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(String) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Gets file system for the given user name.
get(String) - Method in interface org.apache.ignite.hadoop.fs.HadoopFileSystemFactory
Gets file system for the given user name.
get(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get byte value at the given index.
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.
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
 
getAccessKey() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets S3 access key.
getAccessKey() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
getAccessToken() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
 
getAccessTokenSecret() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
 
getAckSendThreshold() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.
getActiveCount() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getActiveCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the approximate number of threads that are actively executing tasks.
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.
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
Sets table alias for type.
getAliases() - Method in class org.apache.ignite.cache.QueryEntity
Gets aliases map.
getAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves values mapped to the specified keys from cache.
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.IgniteCache
getAllAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves values mapped to the specified keys from cache.
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.MemoryMetrics
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets pages allocation rate of a memory region.
getAllOutTx(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets values from cache.
getAllOutTx(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets values from cache.
getAllOutTxAsync(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets values from cache.
getAllOutTxAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets values from cache.
getAllowOverwrite() - Method in class org.apache.ignite.sink.flink.IgniteSink
Obtains flag for enabling overwriting existing values in cache.
getAllowOverwrite() - Method in class org.apache.ignite.stream.storm.StormStreamer
Obtains flag for enabling overwriting existing values in cache.
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.IgniteAtomicLong
Gets and decrements 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(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache.
getAndPut(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndPutAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache.
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(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if cache had no previous mapping for it.
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(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously 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.IgniteCache
Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
getAndRemove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mapping from cache.
getAndRemove(K) - Method in interface org.apache.ignite.IgniteCache
getAndRemoveAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mapping from cache.
getAndRemoveAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the entry for a key only if currently mapped to some value.
getAndReplace(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if there is a previous mapping for it.
getAndReplace(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndReplaceAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if there is a previous mapping for it.
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.IgniteAtomicLong
Gets current value of atomic long and sets new value l of atomic long.
getAnnotation(Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Returns POJO field annotation.
getAnnotation(Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns POJO field annotation.
getAnnotation() - Method in class org.apache.ignite.springdata.repository.config.IgniteRepositoriesRegistar
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
Gets SQL arguments.
getAssemblies() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
getAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves value mapped to the specified key from cache.
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.
getAtomicConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
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.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
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.
getAutoFlushFrequency() - Method in class org.apache.ignite.sink.flink.IgniteSink
Obtains data flush frequency.
getAutoFlushFrequency() - Method in class org.apache.ignite.stream.storm.StormStreamer
Obtains data flush frequency.
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.
getAverageGetTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.
getAveragePutTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.
getAverageRemoveTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
The mean time to execute removes.
getAverageTxCommitTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute tx commit.
getAverageTxCommitTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
The mean time to execute tx commit.
getAverageTxRollbackTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute tx rollbacks.
getAverageTxRollbackTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.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.
getBasePath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
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 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 delete and delete operations.
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
 
getBlockSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get file's data block size.
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.
getBrokerUrl() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the broker URL.
getBucketName() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets S3 bucket name to use.
getBucketName() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
Gets S3 bucket name to use.
getBufferSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get read/write buffer size for IGFS stream operations in bytes.
getBundle() - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
Returns the Bundle to which this ClassLoader is associated.
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.ClusterLocalNodeMetricsMXBean
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
getCache(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
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.
getCacheEvictions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getCacheGets() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
The total number of requests to the cache.
getCacheHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
This is a measure of cache efficiency.
getCacheHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getCacheHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getCacheMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getCacheMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Returns the percentage of cache accesses that did not find a requested entry in the cache.
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.services.ServiceConfiguration
Gets cache name used for key-to-node affinity calculation.
getCacheName() - Method in class org.apache.ignite.sink.flink.IgniteSink
Gets the cache name.
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..
getCacheName() - Method in class org.apache.ignite.stream.storm.StormStreamer
Gets the cache name.
getCacheNames() - Method in class org.apache.ignite.cache.CacheManager
getCacheNames() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
getCachePuts() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of puts to the cache.
getCachePuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getCacheRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
The total number of removals from the cache.
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.
getCacheTxCommits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets total number of transaction commits.
getCacheTxRollbacks() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets total number of transaction rollbacks.
getCacheTxRollbacks() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets total number of transaction rollbacks.
getCachingProvider() - Method in class org.apache.ignite.cache.CacheManager
getCamelContext() - Method in class org.apache.ignite.stream.camel.CamelStreamer
Gets the underlying CamelContext, whether created automatically by Ignite or the context specified by the user.
getCassandraColumnValue(Row, String, Class, Serializer) - Static method in class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
Returns value of specific column in the row returned by CQL statement.
getCassandraType(Class) - Static method in class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
Maps Cassandra type to specified Java type.
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.
getChar(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get char value at the given index.
getCheckpointingFrequency() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets checkpointing frequency.
getCheckpointingPageBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets amount of memory allocated for a checkpointing temporary buffer.
getCheckpointingThreads() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets a number of threads to use for the checkpointing purposes.
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
Gets a formatted instance of configured checkpoint SPI implementation.
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.
getClass(int, ClassLoader) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Gets class for provided type ID.
getClassFilter() - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
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.
getClient(BlockingQueue<String>) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
 
getClientFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns failure detection timeout for client nodes used by TcpDiscoverySpi and TcpCommunicationSpi.
getClientId() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the client ID, either the one set by the user or the automatically generated one.
getClusteringDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns Cassandra DDL for cluster key.
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
Gets a formatted instance of configured collision SPI implementations.
getColumn() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns Cassandra table column name where object should be persisted in case of using BLOB or PRIMITIVE persistence strategy.
getColumn() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
 
getColumnDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
 
getColumnDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
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.
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
Gets a formatted instance of fully configured SPI communication implementation.
getCompletedTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the approximate total number of tasks that have completed execution.
getComponentClass() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
getComponentConfiguration() - Method in class org.apache.ignite.stream.storm.StormStreamer
Not used.
getConcurrencyLevel() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Returns the number of concurrent segments in Ignite internal page mapping tables.
getConfigPaths() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Gets paths to additional file system configuration files (e.g. core-site.xml).
getConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets configuration bean.
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.
getConfiguration() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets configuration bean.
getConfigurationPath() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets configuration file path.
getConfigurationPath() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets configuration file path.
getConnectionsPerNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.
getConnectOptions() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the currently used MQTT client connect options.
getConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getConnectTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.
getConsumerKey() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
 
getConsumerSecret() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
 
getContainers() - Method in class org.apache.ignite.yarn.ApplicationMaster
Deprecated.
getContentSummary(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getContext() - Method in class org.apache.ignite.marshaller.AbstractMarshaller
 
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.
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
Gets copyright statement for Ignite product.
getCorePoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the core number of threads.
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.ClusterLocalNodeMetricsMXBean
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.
getCurrentBlocks() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Gets current amount of blocks.
getCurrentBlocks() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Gets current amount of blocks.
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.ClusterLocalNodeMetricsMXBean
Gets number of cancelled jobs that are still running.
getCurrentCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the CPU usage usage in [0, 1] range.
getCurrentCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
Returns the CPU usage 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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.
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.ClusterLocalNodeMetricsMXBean
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
 
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.igfs.IgfsPerBlockLruEvictionPolicy
Gets current size of data in all blocks.
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Gets current size of data in all blocks.
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.ClusterLocalNodeMetricsMXBean
Returns the current number of live threads including both daemon and non-daemon threads.
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.ClusterLocalNodeMetricsMXBean
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.
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.
getDataCacheConfiguration() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Cache config to store IGFS data.
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.
getDataSource() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
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.
getDataStreamerThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing data stream messages.
getDefaultBlockSize() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getDefaultClassLoader() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultLockTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets default lock acquisition timeout.
getDefaultMemoryPolicyName() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Gets a name of default memory policy.
getDefaultMemoryPolicySize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Gets a size for default memory policy overridden by user.
getDefaultMode() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets mode to specify how IGFS interacts with Hadoop file system, like HDFS.
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
getDefaultReplication() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getDefaultSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
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.TransactionConfiguration
Default cache transaction isolation to use when one is not explicitly specified.
getDefaultTxTimeout() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets default transaction timeout.
getDefaultURI() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultUserName() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Gets default user name.
getDefaultUserName() - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Get default user name (optional).
getDeleteStatement(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns CQL statement to delete row from Cassandra table.
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
Gets a formatted instance of fully configured deployment SPI implementation.
getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets current size of evict queue used to batch up evictions.
getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets current size of evict queue used to batch up evictions.
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.MemoryMetrics
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
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.
getDisconnectForciblyTimeout() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the timeout if disconnecting forcibly.
getDisconnectQuiesceTimeout() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the disconnect quiesce timeout.
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
Gets a formatted instance of configured discovery SPI implementation.
getDiscoveryStartupDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
This value is used to expire messages from waiting list whenever node discovery discrepancies happen.
getDouble(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get double value at the given index.
getDouble(String, double) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getDynamicCacheConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets dynamic cache configuration template.
getDynamicNearCacheConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets dynamic near cache configuration template.
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.MemoryPolicyConfiguration
Specifies the minimal number of empty pages to be present in reuse lists for this memory policy.
getEndpointAddress() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Get ODBC endpoint address.
getEndpointUri() - Method in class org.apache.ignite.stream.camel.CamelStreamer
Gets the endpoint URI from which to consume.
getEndTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets end of computation time for the task.
getEntityInformation(Class<T>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
getEntries(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves values mapped to the specified keys from cache.
getEntries(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets a collection of entries from the Cache.
getEntriesAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves values mapped to the specified keys from cache.
getEntriesAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets a collection of entries from the Cache.
getEntry(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves value mapped to the specified key from cache.
getEntry(K) - Method in interface org.apache.ignite.IgniteCache
Gets an entry from the cache.
getEntryAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves value mapped to the specified key from cache.
getEntryAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets an entry from the cache.
getEnumValues() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
 
getError() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets error message if any.
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
Gets a formatted instance of fully configured event SPI implementation.
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
Gets cache eviction policy.
getEvictionRate() - Method in interface org.apache.ignite.MemoryMetrics
Gets eviction rate of a given memory region.
getEvictionRate() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets eviction rate of a given memory region.
getEvictionThreshold() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
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.
getExcludePaths() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Gets collection of regex for paths whose blocks must not be evicted.
getExcludePaths() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Gets collection of regex for paths whose blocks must not be evicted.
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
Gets a formatted instance of fully configured thread pool that is used in grid.
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.
getExtension() - Method in class org.apache.ignite.springdata.repository.config.IgniteRepositoriesRegistar
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.
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
Gets a formatted instance of fully configured failover SPI implementations.
getFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns failure detection timeout used by TcpDiscoverySpi and TcpCommunicationSpi.
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.
getFetchSize() - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
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.
getFieldByColumn(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns POJO field by Cassandra table column 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.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns a list of POJO fields to be persisted.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns list of POJO fields to be mapped to Cassandra table columns.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns a list of POJO fields to be persisted.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
 
getFieldType() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns field type.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getFileBlockLocations(Path, long, long) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
getFileChecksum(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
getFileIOFactory() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Factory to provide implementation of FileIO interface which is used for any file read/write operations
getFileStatus(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getFileStatus(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
getFileSystemConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets IGFS (Ignite In-Memory File System) configurations.
getFileSystemFactory() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Gets secondary file system factory.
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.
getFinishedJobInfoTtl() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets finished job info time-to-live in milliseconds.
getFloat(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get float value at the given index.
getFloat(String, float) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getForcePrimary(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets value from cache.
getForcePrimaryAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously gets value from cache.
getFragmentizerConcurrentFiles() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets number of files that can be processed by fragmentizer concurrently.
getFragmentizerThrottlingBlockLength() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets the length of file chunk to send before delaying the fragmentizer.
getFragmentizerThrottlingDelay() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets throttle delay for fragmentizer.
getFrameworkInfo() - Method in class org.apache.ignite.mesos.IgniteFramework
 
getFsHadoopUser() - Static method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Gets non-null user name as per the Hadoop file system viewpoint.
getFsStatus() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
getFullVersion() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets string presentation of the version.
getFunc() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets the inner func.
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
Gets a formatted instance of logger that is in grid.
getGridName() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
getGridName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getGridName() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
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.tcp.TcpDiscoverySpi
Gets start time of the very first node in the grid.
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
 
getGroupSize() - Method in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
Get group size.
getHadoopConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets hadoop configuration.
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.
getHeapEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
Returns the current heap size that is used for object allocation.
getHoldCount() - Method in interface org.apache.ignite.IgniteLock
Queries the number of holds on this lock by the current thread.
getHomeDirectory() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
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
Get host.
getHost() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Gets the host endpoint is bound to.
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.
getIdentifyingTypes() - Method in class org.apache.ignite.springdata.repository.config.IgniteRepositoryConfigurationExtension
getIdleConnectionTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.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.ClusterLocalNodeMetricsMXBean
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
 
getIgfsThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing outgoing IGFS messages.
getIgnite(String) - Method in class org.apache.ignite.mesos.resource.IgniteProvider
 
getIgnite() - Static method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask.StreamerContext
Obtains grid instance.
getIgnite() - Static method in class org.apache.ignite.stream.storm.StormStreamer.StreamerContext
Obtains grid instance.
getIgnite() - Method in class org.apache.ignite.stream.StreamAdapter
 
getIgnite() - Method in class org.apache.ignite.yarn.IgniteProvider
 
getIgnite(String) - Method in class org.apache.ignite.yarn.IgniteProvider
 
getIgniteConfigFile() - Method in class org.apache.ignite.sink.flink.IgniteSink
Gets Ignite configuration file.
getIgniteConfigFile() - Method in class org.apache.ignite.stream.storm.StormStreamer
Gets Ignite configuration file.
getIgniteHome() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return Ignite installation home folder.
getIgniteHome() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets Ignite installation home folder.
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.cache.spring.SpringCacheManager
Gets Ignite instance name.
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.
getIgniteInstanceName() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets Ignite instance name.
getIgniteTupleField() - Method in class org.apache.ignite.stream.storm.StormStreamer
Gets Ignite tuple field, by which tuple data is obtained in topology.
getIncludeEventTypes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets array of event types, which will be recorded.
getIncludeProperties() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets array of system or environment properties to include into node attributes.
getIndexDDL(String, String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Returns DDL for the field secondary index.
getIndexDDLStatements(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns DDL statements to create Cassandra table secondary indexes.
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.
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.ContinuousQuery
Gets initial query.
getInitialSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Gets initial memory region size defined by this memory policy.
getInitialSize() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets initial memory region size defined by its MemoryPolicyConfiguration.
getInlineSize() - Method in class org.apache.ignite.cache.QueryIndex
Gets inline size.
getInstance() - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Get Kerberos instance (optional).
getInstanceName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets optional kernal instance name.
getInt(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get int value at the given index.
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.
getIpcEndpointConfiguration() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets IPC endpoint configuration.
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 IP finder clean frequency.
getIpFinderCleanFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets IP finder clean frequency.
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.
getJavaClass() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns java class of the object to be persisted.
getJavaClass() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Returns java class of the field.
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
Gets JDK information.
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
Gets join timeout.
getJoinTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets join timeout.
getKeepAliveTime() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the thread keep-alive time, which is the amount of time which threads in excess of the core pool size may remain idle before being terminated.
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.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.cassandra.persistence.KeyValuePersistenceSettings
Returns list of Ignite cache key POJO fields to be mapped to Cassandra table columns.
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.
getKeyPersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns persistence settings for Ignite cache keys.
getKeyRange() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets key range.
getKeySize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of keys in the cache, possibly with null values.
getKeySize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of keys in the cache, possibly with null values.
getKeyspace() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns Cassandra keyspace to use.
getKeyspaceDDLStatement() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns DDL statement to create Cassandra keyspace.
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.
getKeyStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets key store type used for context creation.
getKeyTab() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
Gets the key tab full file name (e.g.
getKeyTabPrincipal() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
Gets the key tab principal short name (e.g.
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.
getKeyType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Determines the required type of keys for this Cache, if any.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.MemoryMetrics
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargestPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the largest number of threads that have ever simultaneously been in the pool.
getLastCheckpointCopiedOnWritePagesNumber() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointCopiedOnWritePagesNumber() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the number of data pages written during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the number of data pages written during the last checkpoint.
getLastCheckpointFsyncDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointFsyncDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointingDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointingDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointLockWaitDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointLockWaitDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointMarkDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointMarkDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointTotalPagesNumber() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the total number of pages written during the last checkpoint.
getLastCheckpointTotalPagesNumber() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the total number of pages written during the last checkpoint.
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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
Gets toString() representation of of lifecycle beans configured with Ignite.
getListener() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
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
Gets a formatted instance of fully configured load balancing SPI implementations.
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.
getLoadStatement(String, boolean) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns CQL statement to select key/value fields from Cassandra table.
getLocalAddress() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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
Gets local listener.
getLocalMapperWeight() - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Get local mapper weight.
getLocalNode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
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.IgniteSpiAdapter
 
getLocalNodeId() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Unique identifier for this node within grid.
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.
getLocalReducerWeight() - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Get local reducer weight.
getLocksCount() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets locks count.
getLockWaitTime() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Time out in milliseonds to wait when acquiring persistence store lock file before failing the local node.
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.log4j.Log4JLogger
Gets IgniteLogger wrapper around log4j logger for the given category.
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.
getLong(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get long value at the given index.
getLong(String, long) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets timeout in milliseconds after which long query warning will be printed.
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getManagementPort() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets port number for management endpoint.
getManagementThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal and Visor GridJobs.
getMappers() - Method in class org.apache.ignite.hadoop.util.ChainedUserNameMapper
Get child mappers.
getMappings() - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Get mappings.
getMapReducePlanner() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets Hadoop map-reduce planner, a component which defines job execution plan based on job configuration and current grid topology.
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)
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.
getMaxBlocks() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Gets maximum allowed amount of blocks.
getMaxBlocks() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Gets maximum allowed amount of blocks.
getMaxConcurrentAsyncOperations() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum number of allowed concurrent asynchronous operations.
getMaxConnectTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets maximum connect timeout.
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.
getMaximumPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the maximum allowed number of threads.
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.ClusterLocalNodeMetricsMXBean
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.
getMaximumTaskRangeLength() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get maximum default range size of a file being split during IGFS task execution.
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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 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.SqlConnectorConfiguration
Gets maximum number of opened cursors per connection.
getMaxParallelTasks() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets max number of local tasks that may be executed in parallel.
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.
getMaxPoolSize() - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Get maximum workers thread count.
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 interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Gets maximum allowed size of all blocks in bytes.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Gets maximum allowed size of all blocks in bytes.
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.MemoryPolicyConfiguration
Maximum memory region size defined by this memory policy.
getMaxSize() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Maximum memory region size defined by its MemoryPolicyConfiguration.
getMaxTaskQueueSize() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets max task queue size.
getMBean() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
getMBean() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
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
 
getMBeanServer() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return MBean server instance.
getMBeanServerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets a formatted instance of MBean server instance.
getMemoryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets page memory configuration.
getMemoryPolicies() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Gets an array of all memory policies configured.
getMemoryPolicyName() - Method in class org.apache.ignite.configuration.CacheConfiguration
 
getMemorySize() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Gets shared memory size in bytes allocated for endpoint communication.
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets message queue limit for incoming and outgoing messages.
getMessageQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets message queue limit for incoming and outgoing messages.
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.
getMetaCacheConfiguration() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Cache config to store IGFS meta information.
getMethodClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Gets class to which the executed method belongs.
getMethodClass() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
Gets class to which the executed method belongs.
getMethodMatcher() - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
getMethodName() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Gets method name.
getMethodName() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Gets method name.
getMethodName() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
Gets method name.
getMethodParameters() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Gets method parameters in the same order they appear in method signature.
getMethodParameters() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
Gets method parameters in the same order they appear in method signature.
getMethodParameterTypes() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Gets method parameter types in the same order they appear in method signature.
getMethodParameterTypes() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
Gets method parameter types in the same order they appear in method signature.
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.
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
getModeResolver() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
 
getModuleName() - Method in class org.apache.ignite.springdata.repository.config.IgniteRepositoryConfigurationExtension
getModulePrefix() - Method in class org.apache.ignite.springdata.repository.config.IgniteRepositoryConfigurationExtension
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
 
getName() - Method in class org.apache.ignite.cache.QueryIndex
Gets index name.
getName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
 
getName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns POJO field name.
getName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Cache name or null if not provided, then this will be considered a default cache which can be accessed via Ignite.cache(String) method.
getName() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Get thread pool name.
getName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets IGFS instance name.
getName() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Gets memory policy name.
getName() - Method in interface org.apache.ignite.MemoryMetrics
A name of a memory region the metrics are collected for.
getName() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
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.
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
 
getNativeFactory() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
Gets the wrapped factory object.
getNativeLibraryNames() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Get native library names.
getNearConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
 
getNearEvictionPolicy() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Gets near eviction policy.
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.
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.
getNode() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets node this job executed on.
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.tcp.TcpDiscoverySpi
Gets node by ID.
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.communication.tcp.TcpCommunicationSpi
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.
getNodeId() - Method in class org.apache.ignite.logger.java.JavaLogger
Gets node ID.
getNodeId() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Gets node ID.
getNodeId() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Gets node ID.
getNodeId() - Method in interface org.apache.ignite.logger.LoggerNodeIdAware
Gets node ID.
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 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 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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
Returns the current non-heap memory size that is used by Java VM.
getNonLoopbackAddress() - Static method in class org.apache.ignite.mesos.ClusterProperties
Finds a local, non-loopback, IPv4 address
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.
getOffHeapAllocatedSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapBackupEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapEvictions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapGets() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
The number of get requests that were satisfied by the off-heap memory.
getOffHeapMaxMemory() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getOffHeapMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
A miss is a get request that is not satisfied by off-heap memory.
getOffHeapMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapPrimaryEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapPuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getOffHeapRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
The total number of removals from the off-heap memory.
getOptions(Method) - Static method in class org.apache.ignite.springdata.repository.query.IgniteQueryGenerator
Determines whether query is dynamic or not (by list of method parameters)
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(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.
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.
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.
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
Gets OS information.
getOsUser() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets OS user.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
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.
getPageEvictionMode() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Gets memory pages eviction mode.
getPagesFillFactor() - Method in interface org.apache.ignite.MemoryMetrics
Gets the percentage of space that is still free and can be filled in.
getPagesFillFactor() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
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.MemoryConfiguration
The pages memory consists of one or more expandable memory regions defined by MemoryPolicyConfiguration.
getPagesReplaceRate() - Method in interface org.apache.ignite.MemoryMetrics
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
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.IgniteJdbcThinDriver
getPartition() - Method in class org.apache.ignite.cache.query.ScanQuery
Gets partition number over which this query should iterate.
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
Gets partitions for query, in ascending order.
getPartitions() - Method in class org.apache.ignite.cache.query.SqlQuery
Gets partitions for query, in ascending order.
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 interface org.apache.ignite.cache.store.cassandra.datasource.Credentials
Returns password
getPassword() - Method in class org.apache.ignite.cache.store.cassandra.datasource.PlainCredentials
Returns password
getPassword() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets password.
getPath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Gets path.
getPathModes() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets map of path prefixes to IGFS modes used for them.
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.
getPerNodeBatchSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets number of file blocks buffered on local node before sending batch to remote node.
getPerNodeParallelBatchCount() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets number of batches that can be concurrently sent to remote node.
getPersistence() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the currently set persistence mechanism.
getPersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns Ignite cache persistence settings.
getPersistenceSettings() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Returns Ignite cache key/value persistence settings.
getPersistenceSettings() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Persistence settings to use for an operation.
getPersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Returns Ignite cache key/value persistence settings.
getPersistenceSettings() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Returns Ignite cache key/value persistence settings.
getPersistentStoreConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets persistence configuration used by Apache Ignite Persistent Store.
getPersistentStorePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Returns a path the root directory where the Persistent Store will persist data and indexes.
getPessimisticTxLogLinger() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets delay, in milliseconds, after which pessimistic recovery entries will be cleaned up for failed node.
getPessimisticTxLogSize() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets size of pessimistic transactions log stored on node in order to recover transaction commit if originating node has left grid before it has sent all messages to transaction nodes.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.MemoryMetrics
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets total number of pages currently loaded to the RAM.
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
Gets plugin configurations.
getPojoFieldAccessor(Class, String) - Static method in class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
Returns property accessor by class property name.
getPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the current number of threads in the pool.
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
Get port.
getPort() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Gets the port endpoint is bound to.
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
Get port range.
getPreferLocalReducerThresholdWeight() - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Get reducer migration threshold weight.
getPrefetchBlocks() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get number of pre-fetched blocks if specific file's chunk is requested.
getPrimaryKeyDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns Cassandra DDL for primary key.
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.
getProgress() - Method in class org.apache.ignite.yarn.ApplicationMaster
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.SslContextFactory
Gets protocol for secure transport.
getProxyHost() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets HTTP proxy host.
getProxyHost() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
getProxyPassword() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets HTTP proxy password.
getProxyPort() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets HTTP proxy port.
getProxyPort() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
getProxyUsername() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets HTTP proxy user name.
getProxyUsername() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
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.
getQualitiesOfService() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the qualities of service for multiple topics.
getQualityOfService() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the quality of service set by the user for a single topic consumption.
getQueryDetailMetricsSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets size of queries detail metrics that will be stored in memory for monitoring purposes.
getQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets a collection of configured query entities.
getQueryLookupStrategy(QueryLookupStrategy.Key, EvaluationContextProvider) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
getQueryMethod() - Method in class org.apache.ignite.springdata.repository.query.IgniteRepositoryQuery
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 interface org.apache.ignite.mxbean.ThreadPoolMXBean
Gets current size of the execution queue.
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
Gets time interval for MemoryMetrics.getAllocationRate() and MemoryMetrics.getEvictionRate() monitoring purposes.
getRateTimeInterval() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets the length of the time interval for rate-based metrics.
getRealm() - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Get Kerberos realm (optional).
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and provide one new to each next demand request.
getRebalanceBatchSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets size (in number bytes) to be loaded within a single rebalance message.
getRebalanceDelay() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets delay in milliseconds upon a node joining or leaving topology (or crash) after which rebalancing should be started automatically.
getRebalanceMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets rebalance mode for distributed cache.
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.configuration.CacheConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
getRebalanceTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets rebalance timeout (ms).
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
 
getReceiveBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server receive buffer size.
getReceivedBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
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).
getReceivedMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets maximum number of reconnect attempts used when establishing connection with remote nodes.
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.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Gets all addresses registered in this finder.
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.s3.TcpDiscoveryS3IpFinder
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.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Gets all addresses registered in this finder.
getRejectedExecutionHandlerClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the class name of current rejection handler.
getReloginInterval() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
The interval used to re-login from the key tab, in milliseconds.
getRemoteFilter() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets remote filter.
getRemoteFilterFactory() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets remote filter.
getRemoteMapperWeight() - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Get remote mapper weight.
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.tcp.TcpDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteReducerWeight() - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Get remote reducer weight.
getRepositoryBaseClass(RepositoryMetadata) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
getRepositoryFactoryClassName() - Method in class org.apache.ignite.springdata.repository.config.IgniteRepositoryConfigurationExtension
getRepositoryMetadata(Class<?>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
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.
getResourceFactory() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
getResponseProcessor() - Method in class org.apache.ignite.stream.camel.CamelStreamer
Gets the Processor used to generate the response.
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.
getRetryPolicy() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
getRetryStopStrategy() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the retry stop strategy.
getRetryWaitStrategy() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the retry wait strategy.
getRole() - Method in class org.apache.ignite.mesos.IgniteFramework
 
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.
getSecondaryFileSystem() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets the secondary file system.
getSecretAccessKey() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets S3 secret key.
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.ConnectorConfiguration
Gets number of selector threads in REST TCP server.
getSelectorsCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
getSelectorsCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets count of selectors used in TCP server.
getSelectorSpins() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.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.ClusterLocalNodeMetricsMXBean
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.
getSentMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
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.
getSequentialReadsBeforePrefetch() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get amount of sequential block reads before prefetch is triggered.
getSerializer() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets serializer.
getSerializer() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns serializer to be used for BLOBs.
getSerializer() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets serializer.
getSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getServerDefaults() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
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.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
getServiceThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return a thread pool size to be used in grid.
getSharedMemoryPort() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
getSharedMemoryPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets local port for shared memory communication.
getShort(int) - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get short value at the given index.
getSingleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
 
getSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of non-null values in the cache.
getSize() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Get thread pool size.
getSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of non-null values in the cache.
getSleepSummary() - Method in class org.apache.ignite.cache.store.cassandra.common.RandomSleeper
Returns summary sleep time.
getSlowClientQueueLimit() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
getSlowClientQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets slow client queue limit.
getSocketReceiveBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.OdbcConfiguration
Deprecated.
Gets socket receive buffer size.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Gets socket receive buffer size.
getSocketSendBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.OdbcConfiguration
Deprecated.
Gets socket send buffer size.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
getSocketWriteTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets socket write timeout for TCP connections.
getSortOrder() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Returns sort order for the field.
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 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
Gets SQL clause.
getSqlConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets SQL connector configuration.
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.configuration.CacheConfiguration
Gets maximum inline size for sql indexes.
getSqlSchema() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets custom name of the sql schema.
getSslContextFactory() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Deprecated.
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.
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.ClusterLocalNodeMetricsMXBean
Returns the start time of the JVM in milliseconds.
getStartTimestamp() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Get start timestamp of the kernal.
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
Gets string presentation of the kernal start timestamp.
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.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Returns unbind CLQ statement for to be executed inside batch operation.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchLoaderAssistant
Returns CQL statement to use in batch load operation.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Returns CQL statement to be used for an operation.
getStatement() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Returns unbind CLQ statement for to be executed.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Returns unbind CLQ statement for to be executed.
getStatement() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Returns unbind CLQ statement for to be executed.
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).
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.cache.store.cassandra.persistence.PersistenceSettings
Returns persistence strategy to use.
getStreamer() - Static method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask.StreamerContext
Obtains data streamer instance.
getStreamer() - Static method in class org.apache.ignite.stream.storm.StormStreamer.StreamerContext
Obtains data streamer instance.
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.
getStripesActiveStatuses() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getStripesCompletedTasksCounts() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getStripesCount() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getStripesQueueSizes() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getSubIntervals() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Gets a number of sub-intervals the whole MemoryPolicyConfiguration.setRateTimeInterval(long) will be split into to calculate MemoryMetrics.getAllocationRate() and MemoryMetrics.getEvictionRate() rates (5 by default).
getSubIntervals() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets the number of sub-intervals to split the PersistentStoreConfiguration.getRateTimeInterval() into to track the update history.
getSwapFilePath() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
A path to the memory-mapped files the memory region defined by this memory policy will be mapped to.
getSwapFilePath() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
A path to the memory-mapped files the memory region defined by MemoryPolicyConfiguration will be mapped to.
getSystemCacheInitialSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Initial size of a memory region reserved for system cache.
getSystemCacheMaxSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Maximum memory region size reserved for system cache.
getSystemThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal system messages.
getTable() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns Cassandra table to use.
getTable() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Cassandra table to use for an operation.
getTable() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Cassandra table to use for an operation.
getTable() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Cassandra table to use for an operation.
getTable() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Cassandra table to use for an operation.
getTableColumns() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns column names for Cassandra table.
getTableColumns() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns set of database column names, used to persist field values
getTableColumnsDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns Cassandra table columns DDL, corresponding to POJO fields which should be persisted.
getTableColumnsDDL(Set<String>) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns Cassandra table columns DDL, corresponding to POJO fields which should be persisted.
getTableDDLStatement(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns DDL statement to create Cassandra table.
getTableName() - Method in class org.apache.ignite.cache.QueryEntity
Gets table name for this query entity.
getTarget() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Gets target object for method execution.
getTarget() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
Gets target object to execute method on.
getTargetRepository(RepositoryInformation) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
getTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the approximate total number of tasks that have been scheduled for execution.
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.
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.
getThreadCount() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Get number of threads used by this endpoint to process incoming requests.
getThreadCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets thread count for warmup.
getThreadFactoryClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the class name of thread factory used to create new threads.
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
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.ContinuousQuery
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
Gets the query execution timeout in milliseconds.
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.
getTlbSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Property define size thread local buffer.
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).
getTokenDirectoryPath() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Gets directory where shared memory tokens are stored.
getTopHistorySize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
getTopic() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the subscribed topic.
getTopics() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets the topics subscribed to.
getTopology() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets a collection of grid nodes IDs.
getTopologySafe(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets value without waiting for toplogy changes.
getTopologyValidator() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets topology validator.
getTotalAllocatedPages() - Method in interface org.apache.ignite.MemoryMetrics
Gets a total number of allocated pages related to the memory policy.
getTotalAllocatedPages() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Gets a total number of allocated pages related to the memory policy.
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
Gets number of cancelled jobs since node startup.
getTotalCompletedTasksCount() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
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.ClusterLocalNodeMetricsMXBean
Gets total time this node spent idling (not executing any jobs).
getTotalNodes() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of nodes.
getTotalNodes() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
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.
getTotalQueueSize() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
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.ClusterLocalNodeMetricsMXBean
Gets total number of jobs this node rejects during collision resolution operations since node startup.
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.ClusterLocalNodeMetricsMXBean
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.
getTransactionConcurrency() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets transaction concurrency level.
getTransactionConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets transactions configuration.
getTransactionManager() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Gets transaction manager.
getTransactionManagerLookupClassName() - Method in class org.apache.ignite.configuration.CacheConfiguration
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.
getTTL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns ttl to use for while inserting new rows into Cassandra table.
getTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
Deprecated.
getTxCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets committed transaction queue size.
getTxCommitQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets committed transaction queue size.
getTxCommittedVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached committed transaction IDs.
getTxCommittedVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of cached committed transaction IDs.
getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets committed DHT transaction queue size.
getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets committed DHT transaction queue size.
getTxDhtCommittedVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached committed DHT transaction IDs.
getTxDhtCommittedVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of cached committed DHT transaction IDs.
getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets prepared DHT transaction queue size.
getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets prepared DHT transaction queue size.
getTxDhtRolledbackVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached rolled back DHT transaction IDs.
getTxDhtRolledbackVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of cached rolled back DHT transaction IDs.
getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets DHT start version counts map size.
getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets DHT start version counts map size.
getTxDhtThreadMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction DHT per-thread map size.
getTxDhtThreadMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets transaction DHT per-thread map size.
getTxDhtXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction DHT per-Xid map size.
getTxDhtXidMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets transaction DHT per-Xid map size.
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
getTxPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets prepared transaction queue size.
getTxPrepareQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets prepared transaction queue size.
getTxRolledbackVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached rolled back transaction IDs.
getTxRolledbackVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of cached rolled back transaction IDs.
getTxStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets start version counts map size.
getTxStartVersionCountsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets start version counts map size.
getTxThreadMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction per-thread map size.
getTxThreadMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets transaction per-thread map size.
getTxXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction per-Xid map size.
getTxXidMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets transaction per-Xid map size.
getType() - Method in class org.apache.ignite.cache.query.SqlQuery
Gets type for query.
getType() - Method in class org.apache.ignite.cache.query.TextQuery
Gets type for query.
getType() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Gets endpoint type.
getType() - Method in enum org.apache.ignite.stream.zeromq.ZeroMqTypeSocket
 
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
getUnacknowledgedMessagesBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of stored unacknowledged messages per connection to node.
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.ClusterLocalNodeMetricsMXBean
Returns the uptime of the JVM in milliseconds.
getUpTime() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets up-time of the kernal.
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
Gets string presentation of up-time for the kernal.
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
getUri() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Gets file system URI.
getUri() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getUri() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
getUriDefaultPort() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
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.
getUser() - Method in interface org.apache.ignite.cache.store.cassandra.datasource.Credentials
Returns user name
getUser() - Method in class org.apache.ignite.cache.store.cassandra.datasource.PlainCredentials
Returns user name
getUser() - Method in class org.apache.ignite.mesos.IgniteFramework
 
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.IgniteConfiguration
Should return any user-defined attributes to be added to this node.
getUserAttributesFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets a list of formatted user-defined attributes added to this node.
getUserNameMapper() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Get optional user name mapper.
getUserObject() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets user-specific object.
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(Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns field value for the object instance.
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.cassandra.persistence.KeyValuePersistenceSettings
Returns list of Ignite cache value POJO fields to be mapped to Cassandra table columns.
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.
getValueFromObject(Object, Serializer) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Gets field value as an object having Cassandra compatible type.
getValuePersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns persistence settings for Ignite cache values.
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.QueryEntity
Gets value type for this query pair.
getValueType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets value type.
getValueType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Determines the required type of values for this Cache, if any.
getVmName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets VM name.
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.
getWalArchivePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets a path to the WAL archive directory.
getWalArchiveSegments() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the current number of WAL segments in the WAL archive.
getWalArchiveSegments() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the current number of WAL segments in the WAL archive.
getWalAutoArchiveAfterInactivity() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
getWalFlushFrequency() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
This property define how often WAL will be fsync-ed in BACKGROUND mode.
getWalFsyncDelayNanos() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets the fsync delay, in nanoseconds.
getWalFsyncTimeAverage() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalFsyncTimeAverage() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalHistorySize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets a total number of checkpoints to keep in the WAL history.
getWalLoggingRate() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the average number of WAL records per second written during the last time interval.
getWalLoggingRate() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the average number of WAL records per second written during the last time interval.
getWalMode() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Type define behavior wal fsync.
getWalRecordIteratorBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Property define how many bytes iterator read from disk (for one reading), during go ahead wal.
getWalSegments() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets a number of WAL segments to work with.
getWalSegmentSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets size of a WAL segment in bytes.
getWalStorePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets a path to the directory where WAL is stored.
getWalWritingRate() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Gets the average number of bytes per second written during the last time interval.
getWalWritingRate() - Method in interface org.apache.ignite.PersistenceMetrics
Gets the average number of bytes per second written during the last time interval.
getWarmupClosure() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets grid warmup closure.
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.
getWorkDirectory() - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Get work directory.
getWorkingDirectory() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
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.
getWriteBehindBufferSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getWriteBehindCriticalOverflowCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getWriteBehindErrorRetryCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getWriteBehindFlushFrequency() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets the cache flush frequency.
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.
getWriteBehindFlushSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets the maximum size of the write-behind buffer.
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.
getWriteBehindFlushThreadCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets the number of flush threads that will perform store update operations.
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.
getWriteBehindStoreBatchSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
getWriteBehindTotalCriticalOverflowCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets count of write buffer overflow events since initialization.
getWriteStatement(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns CQL statement to insert row into Cassandra table.
getWriteSynchronizationMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets write synchronization mode.
getZkConnectionString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
globalId() - Method in class org.apache.ignite.lang.IgniteUuid
Gets global ID portion of this GridUuid.
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_CONFIG_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
GRID_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
gridCount() - Static method in class org.apache.ignite.osgi.IgniteOsgiUtils
Returns the number of grids currently running in this OSGi container.
gridDiscoveryData(int) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
gridify(ProceedingJoinPoint) - Method in class org.apache.ignite.compute.gridify.aop.aspectj.GridifyAspectJAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
gridify(ProceedingJoinPoint) - Method in class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToSetAspectJAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
gridify(ProceedingJoinPoint) - Method in class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToValueAspectJAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
Gridify - Annotation Type in org.apache.ignite.compute.gridify
Gridify annotation is the main way to grid-enable existing code.
GridifyArgument - Interface in org.apache.ignite.compute.gridify
Gridify task argument created by the system for task execution.
GridifyArgumentAdapter - Class in org.apache.ignite.compute.gridify.aop
Convenience adapter for GridifyArgument interface.
GridifyArgumentAdapter() - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Empty constructor.
GridifyArgumentAdapter(GridifyArgument, Object...) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Copy constructor.
GridifyArgumentAdapter(Class<?>, String, Class<?>[], Object[], Object) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Creates a fully initialized gridify argument.
GridifyAspectJAspect - Class in org.apache.ignite.compute.gridify.aop.aspectj
AspectJ aspect that cross-cuts on all methods grid-enabled with Gridify annotation and potentially executes them on remote node.
GridifyAspectJAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.aspectj.GridifyAspectJAspect
 
GridifyDefaultRangeTask - Class in org.apache.ignite.compute.gridify.aop
Default gridify task which simply executes a method on remote node.
GridifyDefaultRangeTask(Class<?>, GridifyNodeFilter, int, int, boolean) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
 
GridifyDefaultTask - Class in org.apache.ignite.compute.gridify.aop
Default gridify task which simply executes a method on remote node.
GridifyDefaultTask(Class<?>) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
Creates gridify default task with given deployment class.
GridifyInput - Annotation Type in org.apache.ignite.compute.gridify
This annotation can be applied to method parameter for grid-enabled method.
GridifyInterceptor - Interface in org.apache.ignite.compute.gridify
This interface defines an interceptor apply for Gridify annotation.
GridifyNodeFilter - Interface in org.apache.ignite.compute.gridify
Predicate node filter.
GridifyRuntimeException - Exception in org.apache.ignite.compute.gridify
This defines gridify exception.
GridifyRuntimeException(String) - Constructor for exception org.apache.ignite.compute.gridify.GridifyRuntimeException
Creates new gridify runtime exception with specified message.
GridifyRuntimeException(Throwable) - Constructor for exception org.apache.ignite.compute.gridify.GridifyRuntimeException
Creates new gridify runtime exception given throwable as a cause and source of error message.
GridifyRuntimeException(String, Throwable) - Constructor for exception org.apache.ignite.compute.gridify.GridifyRuntimeException
Creates new gridify runtime exception with specified message and cause.
GridifySetToSet - Annotation Type in org.apache.ignite.compute.gridify
GridifySetToSet annotation allows to grid-enable existing code with specific semantics.
GridifySetToSetAbstractAspect - Class in org.apache.ignite.compute.gridify.aop
Convenience adapter with common methods for different aspect implementations (AspectJ, JBoss AOP, Spring AOP).
GridifySetToSetAbstractAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
 
GridifySetToSetAspectJAspect - Class in org.apache.ignite.compute.gridify.aop.aspectj
AspectJ aspect that cross-cuts on all methods grid-enabled with GridifySetToSet annotation and potentially executes them on remote node.
GridifySetToSetAspectJAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToSetAspectJAspect
 
GridifySetToSetSpringAspect - Class in org.apache.ignite.compute.gridify.aop.spring
Spring aspect that cross-cuts on all methods grid-enabled with GridifySetToSet annotation and potentially executes them on remote node.
GridifySetToSetSpringAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySetToSetSpringAspect
 
GridifySetToValue - Annotation Type in org.apache.ignite.compute.gridify
GridifySetToValue annotation is the way to grid-enable existing code with specific semantics.
GridifySetToValueAbstractAspect - Class in org.apache.ignite.compute.gridify.aop
Convenience adapter with common methods for different aspect implementations (AspectJ, JBoss AOP, Spring AOP).
GridifySetToValueAbstractAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
 
GridifySetToValueAspectJAspect - Class in org.apache.ignite.compute.gridify.aop.aspectj
AspectJ aspect that cross-cuts on all methods grid-enabled with GridifySetToValue annotation and potentially executes them on remote node.
GridifySetToValueAspectJAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToValueAspectJAspect
 
GridifySetToValueSpringAspect - Class in org.apache.ignite.compute.gridify.aop.spring
Spring aspect that cross-cuts on all methods grid-enabled with GridifySetToValue annotation and potentially executes them on remote node.
GridifySetToValueSpringAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySetToValueSpringAspect
 
GridifySpringAspect - Class in org.apache.ignite.compute.gridify.aop.spring
Spring aspect that cross-cuts on all methods grid-enabled with Gridify annotation and potentially executes them on remote node.
GridifySpringAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySpringAspect
 
GridifySpringEnhancer - Class in org.apache.ignite.compute.gridify.aop.spring
Spring AOP enhancer.
GridifySpringPointcut - Class in org.apache.ignite.compute.gridify.aop.spring
Pointcut used by gridified aspects to find methods annotated with Gridify, GridifySetToValue and GridifySetToSet annotations.
GridifySpringPointcut(GridifySpringPointcut.GridifySpringPointcutType) - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
Creates pointcut associated with specific aspect.
GridifySpringPointcut.GridifySpringPointcutType - Enum in org.apache.ignite.compute.gridify.aop.spring
Pointcut type.
GridifyTaskAdapter<R> - Class in org.apache.ignite.compute.gridify
Convenience adapter for tasks that work with Gridify annotation for grid-enabling methods.
GridifyTaskAdapter() - Constructor for class org.apache.ignite.compute.gridify.GridifyTaskAdapter
 
GridifyTaskSplitAdapter<R> - Class in org.apache.ignite.compute.gridify
Convenience adapter for tasks that work with Gridify annotation for grid-enabling methods.
GridifyTaskSplitAdapter() - Constructor for class org.apache.ignite.compute.gridify.GridifyTaskSplitAdapter
 
gridStartTime - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Start time of the very first grid node.
groupBlockSize() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file group block size (i.e. block size * group size).
groupByHost(Collection<ClusterNode>) - Static method in class org.apache.ignite.hadoop.planner.HadoopAbstractMapReducePlanner
Groups nodes by host names.
GRP_IDX_UNASSIGNED - Static variable in class org.apache.ignite.thread.IgniteThread
Index for unassigned thread.

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
 
HadoopAbstractMapReducePlanner - Class in org.apache.ignite.hadoop.planner
Base class for map-reduce planners.
HadoopAbstractMapReducePlanner() - Constructor for class org.apache.ignite.hadoop.planner.HadoopAbstractMapReducePlanner
 
HadoopConfiguration - Class in org.apache.ignite.configuration
Ignite Hadoop Accelerator configuration.
HadoopConfiguration() - Constructor for class org.apache.ignite.configuration.HadoopConfiguration
Default constructor.
HadoopConfiguration(HadoopConfiguration) - Constructor for class org.apache.ignite.configuration.HadoopConfiguration
Copy constructor.
HadoopFileSystemFactory - Interface in org.apache.ignite.hadoop.fs
Factory for Hadoop FileSystem used by IgniteHadoopIgfsSecondaryFileSystem.
HadoopInputSplit - Class in org.apache.ignite.hadoop
Abstract fragment of an input data source.
HadoopInputSplit() - Constructor for class org.apache.ignite.hadoop.HadoopInputSplit
 
HadoopJob - Interface in org.apache.ignite.hadoop
Compact job description.
HadoopMapReducePlan - Interface in org.apache.ignite.hadoop
Map-reduce job execution plan.
HadoopMapReducePlanner - Interface in org.apache.ignite.hadoop
Map-reduce execution planner.
HadoopTestRoundRobinMrPlanner - Class in org.apache.ignite.hadoop.planner
Round-robin mr planner.
HadoopTestRoundRobinMrPlanner() - Constructor for class org.apache.ignite.hadoop.planner.HadoopTestRoundRobinMrPlanner
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.apache.ignite.mesos.resource.ResourceHandler
HANDSHAKE_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Handshake message type.
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.
hasCombiner() - Method in interface org.apache.ignite.hadoop.HadoopJob
Checks whether job has combiner.
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.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.hadoop.HadoopInputSplit
This method must be implemented for purpose of internal implementation.
hashCode() - Method in class org.apache.ignite.igfs.IgfsPath
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
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.
hasReducer() - Method in interface org.apache.ignite.hadoop.HadoopJob
Checks whether job has reducer.
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.
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.
HibernateAccessStrategyAdapter - Class in org.apache.ignite.cache.hibernate
Common interface used to implement Hibernate L2 cache access strategies.
HibernateAccessStrategyAdapter(Ignite, HibernateCacheProxy, HibernateExceptionConverter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
HibernateAccessStrategyFactory - Class in org.apache.ignite.cache.hibernate
Access strategy factory.
HibernateCacheProxy - Class in org.apache.ignite.cache.hibernate
Hibernate cache proxy used to substitute hibernate keys with ignite keys.
HibernateExceptionConverter - Interface in org.apache.ignite.cache.hibernate
Converts Ignite errors into Hibernate runtime exceptions.
HibernateKeyTransformer - Interface in org.apache.ignite.cache.hibernate
An interface for transforming hibernate keys to Ignite keys.
HibernateNonStrictAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of NONSTRICT_READ_WRITE cache access strategy.
HibernateReadOnlyAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of READ_ONLY cache access strategy.
HibernateReadOnlyAccessStrategy(Ignite, HibernateCacheProxy, HibernateExceptionConverter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
 
HibernateReadWriteAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of READ_WRITE cache access strategy.
HibernateReadWriteAccessStrategy(Ignite, HibernateCacheProxy, ThreadLocal, HibernateExceptionConverter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
 
HibernateTransactionalAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of {TRANSACTIONAL cache access strategy.
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.
host - Variable in class org.apache.ignite.mesos.IgniteTask
 
host() - Method in class org.apache.ignite.mesos.IgniteTask
 
HOST_IP - Static variable in class org.apache.ignite.cache.store.cassandra.common.SystemHelper
Host IP address
HOST_NAME - Static variable in class org.apache.ignite.cache.store.cassandra.common.SystemHelper
Host name.
hostnameConstraint(Pattern) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets hostname constraint.
hostnameConstraint() - Method in class org.apache.ignite.mesos.ClusterProperties
 
hostnameConstraint(Pattern) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets hostname constraint.
hostnameConstraint() - Method in class org.apache.ignite.yarn.ClusterProperties
 
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.
hosts - Variable in class org.apache.ignite.hadoop.HadoopInputSplit
 
hosts() - Method in class org.apache.ignite.hadoop.HadoopInputSplit
Array of hosts where this input split resides.
hosts() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
Compliant with Hadoop interface.
httpServerHost() - Method in class org.apache.ignite.mesos.ClusterProperties
 
httpServerPort() - Method in class org.apache.ignite.mesos.ClusterProperties
 

I

icon() - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
Tab and menu icon 16x16 px.
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.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 interface org.apache.ignite.spi.IgniteSpiTimeoutObject
 
id - Variable in class org.apache.ignite.yarn.IgniteContainer
 
id() - Method in class org.apache.ignite.yarn.IgniteContainer
 
idleTimeout() - Method in class org.apache.ignite.mesos.ClusterProperties
Sets the maximum Idle time for a http connection, which will be used for jetty server.
IGFS_SCHEME - Static variable in interface org.apache.ignite.IgniteFileSystem
IGFS scheme name.
IgfsBlockLocation - Interface in org.apache.ignite.igfs
IGFS file's data block location in the grid.
IgfsByteDelimiterRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
Record resolver which adjusts records based on provided delimiters.
IgfsByteDelimiterRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
Empty constructor required for Externalizable support.
IgfsByteDelimiterRecordResolver(byte[]...) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
Creates delimiter-based record resolver.
IgfsConcurrentModificationException - Exception in org.apache.ignite.igfs
IGFS exception indicating that file system structure was modified concurrently.
IgfsConcurrentModificationException(String) - Constructor for exception org.apache.ignite.igfs.IgfsConcurrentModificationException
Constructor.
IgfsConcurrentModificationException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsConcurrentModificationException
Constructor.
IgfsConcurrentModificationException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsConcurrentModificationException
Constructor.
IgfsCorruptedFileException - Exception in org.apache.ignite.igfs
Exception thrown when target file's block is not found in data cache.
IgfsCorruptedFileException(String) - Constructor for exception org.apache.ignite.igfs.IgfsCorruptedFileException
Constructor.
IgfsCorruptedFileException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsCorruptedFileException
Constructor.
IgfsCorruptedFileException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsCorruptedFileException
Constructor.
igfsDataSpaceUsed() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Get current amount of used IGFS space in bytes.
IgfsDirectoryNotEmptyException - Exception in org.apache.ignite.igfs
Exception indicating that directory can not be deleted because it is not empty.
IgfsDirectoryNotEmptyException(String) - Constructor for exception org.apache.ignite.igfs.IgfsDirectoryNotEmptyException
Constructor.
IgfsDirectoryNotEmptyException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsDirectoryNotEmptyException
Constructor.
IgfsDirectoryNotEmptyException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsDirectoryNotEmptyException
Constructor.
IgfsEvent - Class in org.apache.ignite.events
IGFS event.
IgfsEvent(IgfsPath, ClusterNode, int) - Constructor for class org.apache.ignite.events.IgfsEvent
Constructs an event instance.
IgfsEvent(IgfsPath, IgfsPath, ClusterNode, int) - Constructor for class org.apache.ignite.events.IgfsEvent
Constructs an event instance for path modification event (EventType.EVT_IGFS_FILE_RENAMED, EventType.EVT_IGFS_DIR_RENAMED).
IgfsEvent(IgfsPath, ClusterNode, int, long) - Constructor for class org.apache.ignite.events.IgfsEvent
Constructs an event instance for close events: (EventType.EVT_IGFS_FILE_CLOSED_READ, EventType.EVT_IGFS_FILE_CLOSED_WRITE).
IgfsEvent(IgfsPath, ClusterNode, int, Map<String, String>) - Constructor for class org.apache.ignite.events.IgfsEvent
Constructs an event instance for file metadata update events (EventType.EVT_IGFS_META_UPDATED).
IgfsEvictionFilter - Class in org.apache.ignite.cache.eviction.igfs
IGFS eviction filter which will not evict blocks of particular files.
IgfsEvictionFilter() - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsEvictionFilter
 
IgfsException - Exception in org.apache.ignite.igfs
IGFS exception thrown by file system components.
IgfsException(String) - Constructor for exception org.apache.ignite.igfs.IgfsException
Constructor.
IgfsException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsException
Constructor.
IgfsException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsException
Constructor.
IgfsFile - Interface in org.apache.ignite.igfs
IGFS file or directory descriptor.
IgfsFileRange - Class in org.apache.ignite.igfs.mapreduce
Entity representing part of IGFS file identified by file path, start position, and length.
IgfsFileRange(IgfsPath, long, long) - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsFileRange
Creates file range.
IgfsFixedLengthRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
Record resolver which adjusts records to fixed length.
IgfsFixedLengthRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
Empty constructor required for Externalizable support.
IgfsFixedLengthRecordResolver(long) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
Creates fixed-length record resolver.
IgfsGroupDataBlocksKeyMapper - Class in org.apache.ignite.igfs
IGFS class providing ability to group file's data blocks together on one node.
IgfsGroupDataBlocksKeyMapper() - Constructor for class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
Default constructor.
IgfsGroupDataBlocksKeyMapper(int) - Constructor for class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
Constructs affinity mapper to group several data blocks with the same key.
IgfsInputStream - Class in org.apache.ignite.igfs
IGFS input stream to read data from the file system.
IgfsInputStream() - Constructor for class org.apache.ignite.igfs.IgfsInputStream
 
IgfsInputStreamJobAdapter - Class in org.apache.ignite.igfs.mapreduce
Convenient IgfsJob adapter.
IgfsInputStreamJobAdapter() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsInputStreamJobAdapter
 
IgfsInvalidHdfsVersionException - Exception in org.apache.ignite.igfs
Exception thrown when Ignite detects that remote HDFS version differs from version of HDFS libraries in Ignite classpath.
IgfsInvalidHdfsVersionException(String) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidHdfsVersionException
Constructor.
IgfsInvalidHdfsVersionException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidHdfsVersionException
Constructor.
IgfsInvalidHdfsVersionException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidHdfsVersionException
Constructor.
IgfsInvalidPathException - Exception in org.apache.ignite.igfs
IGFS exception indicating that operation target is invalid (e.g. not a file while expecting to be a file).
IgfsInvalidPathException(String) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidPathException
Constructor.
IgfsInvalidPathException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidPathException
Constructor.
IgfsInvalidPathException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidPathException
Constructor.
IgfsIpcEndpointConfiguration - Class in org.apache.ignite.igfs
IGFS IPC endpoint configuration.
IgfsIpcEndpointConfiguration() - Constructor for class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default constructor.
IgfsIpcEndpointConfiguration(IgfsIpcEndpointConfiguration) - Constructor for class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Copying constructor.
IgfsIpcEndpointType - Enum in org.apache.ignite.igfs
IGFS endpoint type.
IgfsJob - Interface in org.apache.ignite.igfs.mapreduce
Defines executable unit for IgfsTask.
IgfsJobAdapter - Class in org.apache.ignite.igfs.mapreduce
Adapter for IgfsJob with no-op implementation of IgfsJobAdapter.cancel() method.
IgfsJobAdapter() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsJobAdapter
 
IgfsMetrics - Interface in org.apache.ignite.igfs
IGFS metrics snapshot for the file system.
IgfsMode - Enum in org.apache.ignite.igfs
IGFS mode defining interactions with underlying secondary Hadoop file system.
igfsName() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
Gets IGFS name.
IgfsNewLineRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
Record resolver based on new line detection.
IgfsNewLineRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
Empty constructor required for Externalizable support.
IgfsOutOfSpaceException - Exception in org.apache.ignite.igfs
IGFS exception that is thrown when it detected out-of-space condition.
IgfsOutOfSpaceException(String) - Constructor for exception org.apache.ignite.igfs.IgfsOutOfSpaceException
Constructor.
IgfsOutOfSpaceException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsOutOfSpaceException
Constructor.
IgfsOutOfSpaceException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsOutOfSpaceException
Constructor.
IgfsOutputStream - Class in org.apache.ignite.igfs
IGFS output stream to write data into the file system.
IgfsOutputStream() - Constructor for class org.apache.ignite.igfs.IgfsOutputStream
 
IgfsParentNotDirectoryException - Exception in org.apache.ignite.igfs
Exception thrown when parent supposed to be a directory is a file.
IgfsParentNotDirectoryException(String) - Constructor for exception org.apache.ignite.igfs.IgfsParentNotDirectoryException
Constructor.
IgfsParentNotDirectoryException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsParentNotDirectoryException
Constructor.
IgfsParentNotDirectoryException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsParentNotDirectoryException
Constructor.
IgfsPath - Class in org.apache.ignite.igfs
IGFS path to file in the file system.
IgfsPath() - Constructor for class org.apache.ignite.igfs.IgfsPath
Default constructor.
IgfsPath(URI) - Constructor for class org.apache.ignite.igfs.IgfsPath
Constructs a path from an URI
IgfsPath(String) - Constructor for class org.apache.ignite.igfs.IgfsPath
Constructs a path from the URI string.
IgfsPath(IgfsPath, String) - Constructor for class org.apache.ignite.igfs.IgfsPath
Resolve a child path against a parent path.
IgfsPathAlreadyExistsException - Exception in org.apache.ignite.igfs
Exception thrown when target path supposed to be created already exists.
IgfsPathAlreadyExistsException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathAlreadyExistsException
Constructor.
IgfsPathAlreadyExistsException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathAlreadyExistsException
Constructor.
IgfsPathAlreadyExistsException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathAlreadyExistsException
Constructor.
IgfsPathIsDirectoryException - Exception in org.apache.ignite.igfs
Exception indicating that path is directory, while it is expected to be a file.
IgfsPathIsDirectoryException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsDirectoryException
Constructor.
IgfsPathIsDirectoryException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsDirectoryException
Constructor.
IgfsPathIsDirectoryException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsDirectoryException
Constructor.
IgfsPathIsNotDirectoryException - Exception in org.apache.ignite.igfs
Exception indicating that path is not directory.
IgfsPathIsNotDirectoryException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsNotDirectoryException
Constructor.
IgfsPathIsNotDirectoryException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsNotDirectoryException
Constructor.
IgfsPathIsNotDirectoryException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsNotDirectoryException
Constructor.
IgfsPathNotFoundException - Exception in org.apache.ignite.igfs
IGFS exception indicating that target resource is not found.
IgfsPathNotFoundException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathNotFoundException
Constructor.
IgfsPathNotFoundException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathNotFoundException
Constructor.
IgfsPathNotFoundException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathNotFoundException
Constructor.
IgfsPathSummary - Class in org.apache.ignite.igfs
Path summary: total files count, total directories count, total length.
IgfsPathSummary() - Constructor for class org.apache.ignite.igfs.IgfsPathSummary
Empty constructor required by Externalizable.
IgfsPathSummary(IgfsPath) - Constructor for class org.apache.ignite.igfs.IgfsPathSummary
Construct empty path summary.
IgfsPerBlockLruEvictionPolicy - Class in org.apache.ignite.cache.eviction.igfs
IGFS eviction policy which evicts particular blocks.
IgfsPerBlockLruEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Default constructor.
IgfsPerBlockLruEvictionPolicy(long, int) - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Constructor.
IgfsPerBlockLruEvictionPolicy(long, int, Collection<String>) - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Constructor.
IgfsPerBlockLruEvictionPolicyMXBean - Interface in org.apache.ignite.cache.eviction.igfs
MBean for IGFS per-block LRU eviction policy.
IgfsRangeInputStream - Class in org.apache.ignite.igfs.mapreduce
Decorator for regular IgfsInputStream which streams only data within the given range.
IgfsRangeInputStream(IgfsInputStream, long, long) - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Constructor.
IgfsRangeInputStream(IgfsInputStream, IgfsFileRange) - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Constructor.
IgfsRecordResolver - Interface in org.apache.ignite.igfs.mapreduce
IGFS record resolver.
IgfsSecondaryFileSystem - Interface in org.apache.ignite.igfs.secondary
Secondary file system interface.
IgfsSecondaryFileSystemPositionedReadable - Interface in org.apache.ignite.igfs.secondary
The simplest data input interface to read from secondary file system.
IgfsStringDelimiterRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
Record resolver based on delimiters represented as strings.
IgfsStringDelimiterRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
Empty constructor required for Externalizable support.
IgfsStringDelimiterRecordResolver(Charset, String...) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
Creates record resolver from given string and given charset.
IgfsStringDelimiterRecordResolver(String...) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
Creates record resolver based on given string with default charset.
IgfsTask<T,R> - Class in org.apache.ignite.igfs.mapreduce
IGFS task which can be executed on the grid using one of IgniteFs.execute() methods.
IgfsTask() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsTask
 
IgfsTaskArgs<T> - Interface in org.apache.ignite.igfs.mapreduce
IGFS task arguments.
IgfsTaskNoReduceAdapter<T,R> - Class in org.apache.ignite.igfs.mapreduce
Convenient IgfsTask adapter with empty reduce step.
IgfsTaskNoReduceAdapter() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsTaskNoReduceAdapter
 
IgfsUserContext - Class in org.apache.ignite.igfs
Provides ability to execute IGFS code in a context of a specific user.
IgfsUserContext() - Constructor for class org.apache.ignite.igfs.IgfsUserContext
 
ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Grid.
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 - Variable in class org.apache.ignite.hadoop.planner.HadoopAbstractMapReducePlanner
Injected 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.osgi.IgniteAbstractOsgiContextActivator
The instance of Ignite started by this Activator.
ignite - Variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Ignite 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_AFFINITY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for affinity assignment history.
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_MAX_CONCURRENT_DHT_UPDATES - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum amount of concurrent updates per system thread in atomic caches in case of PRIMARY_SYNC or FULL_ASYNC write synchronization mode.
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_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
Deprecated.
Should be removed in Apache Ignite 2.0.
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
Flag indicating whether validation of keys put to cache should be disabled.
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_CFG_FILE_PATH_PARAM - Static variable in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
Configuration file path parameter name.
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_CLUSTER_NAME - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_CONFIG_URL - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold optional configuration URL.
IGNITE_CONFIG_XML - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_CONFIG_XML - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_CONFIG_XML_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
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_DAEMON - Static variable in class org.apache.ignite.IgniteSystemProperties
Presence of this system property with value true will make the grid node start as a daemon node.
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_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_DIAGNOSTIC_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_DISABLE_HOSTNAME_VERIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to disable HostnameVerifier for SSL connections.
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_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for discovery messages history.
IGNITE_DISK_SPACE_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_DUMP_PENDING_OBJECTS_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of times pending cache objects will be dumped to the log in case of partition exchange timeout.
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_H2_DEBUG_CONSOLE - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property set then debug console will be opened for H2 indexing SPI.
IGNITE_H2_DEBUG_CONSOLE_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to specify user defined port which H2 indexing SPI will use to start H2 debug console on.
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_HOSTNAME_CONSTRAINT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HOSTNAME_CONSTRAINT - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_HTTP_SERVER_HOST - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HTTP_SERVER_IDLE_TIMEOUT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HTTP_SERVER_IDLE_TIMEOUT_DEFAULT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HTTP_SERVER_PORT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Indexing discovery history size.
IGNITE_INSTANCE_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
Hibernate L2 cache Ignite instance name property name.
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
If this property is set to true then shared memory space native debug will be enabled.
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
System property to override default job metrics processor property defining concurrency level for structure holding job metrics snapshots.
IGNITE_JVM_OPTS - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_JVM_OPTS - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_LOCAL_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of system property to set system-wide local IP address or host.
IGNITE_LOCAL_STORE_KEEPS_PRIMARY_ONLY - Static variable in class org.apache.ignite.IgniteSystemProperties
Indicating whether local store keeps primary only.
IGNITE_LOCAL_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
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_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_MAP_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Concurrency level for all concurrent hash maps created by Ignite.
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_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_MEMORY_OVERHEAD_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
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_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_MEMORY_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
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_MIN_CPU_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_MIN_MEMORY_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
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_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 false - no shutdown hook will be set.
IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
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_MCAST_GRP - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override multicast group taken from configuration.
IGNITE_PACKAGE_PATH - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_PACKAGE_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_PATH - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_PDS_PARTITION_DESTROY_CHECKPOINT_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
WAL rebalance threshold.
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
WAL rebalance threshold.
IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag indicating whether performance suggestions output on start should be disabled.
IGNITE_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
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_REBALANCE_STATISTICS_TIME_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Time interval for calculating rebalance rate statistics, in milliseconds.
IGNITE_REFLECTION_CACHE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override default reflection cache size.
IGNITE_RELEASES_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
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_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_RUN_CPU_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_RUN_CPU_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
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_SERVICES_COMPATIBILITY_MODE - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages backward compatibility of IgniteServices.
IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
Property allowing to skip configuration consistency checks.
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_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_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_SUCCESS_FILE - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property defining success file name.
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_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_TO_STRING_INCLUDE_SENSITIVE - Static variable in class org.apache.ignite.IgniteSystemProperties
Setting to true enables writing sensitive information in toString() output.
IGNITE_TOTAL_CPU - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_TOTAL_DISK_SPACE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_TOTAL_MEMORY - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
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_SALVAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout after which all uncompleted transactions originated by left node will be salvaged (i.e. invalidated and committed).
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_URL - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_USERS_LIBS - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_USERS_LIBS - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_USERS_LIBS_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_VERSION - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_WORK_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
Environment variable to set work directory.
IGNITE_WORK_DIR - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_WORKING_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IgniteAbstractOsgiContextActivator - Class in org.apache.ignite.osgi
This BundleActivator starts Apache Ignite inside the OSGi container when the bundle is started.
IgniteAbstractOsgiContextActivator() - Constructor for class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
 
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(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.
igniteCfg() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteCfg() - Method in class org.apache.ignite.yarn.ClusterProperties
 
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.
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
 
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.
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 class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
Override this method to provide the Ignite configuration this bundle will start.
igniteConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
igniteConfiguration() - Method in interface org.apache.ignite.plugin.PluginContext
 
igniteConfigUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteConfigUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
IgniteContainer - Class in org.apache.ignite.yarn
Information about launched task.
IgniteContainer(ContainerId, NodeId, double, double) - Constructor for class org.apache.ignite.yarn.IgniteContainer
Ignite launched task.
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.
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.
IgniteFileSystem - Interface in org.apache.ignite
IGnite File System API.
IgniteFramework - Class in org.apache.ignite.mesos
Ignite mesos framework.
IgniteFramework() - Constructor for class org.apache.ignite.mesos.IgniteFramework
 
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.
IgniteHadoopClientProtocolProvider - Class in org.apache.ignite.hadoop.mapreduce
Ignite Hadoop client protocol provider.
IgniteHadoopClientProtocolProvider() - Constructor for class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
 
IgniteHadoopFileSystem - Class in org.apache.ignite.hadoop.fs.v1
IGFS Hadoop 1.x file system driver over file system API.
IgniteHadoopFileSystem() - Constructor for class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
 
IgniteHadoopFileSystem - Class in org.apache.ignite.hadoop.fs.v2
IGFS Hadoop 2.x file system driver over file system API.
IgniteHadoopFileSystem(URI, Configuration) - Constructor for class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
 
IgniteHadoopFileSystemCounterWriter - Class in org.apache.ignite.hadoop.fs
Statistic writer implementation that writes info into any Hadoop file system.
IgniteHadoopFileSystemCounterWriter() - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter
 
IgniteHadoopIgfsSecondaryFileSystem - Class in org.apache.ignite.hadoop.fs
Secondary file system which delegates calls to Hadoop org.apache.hadoop.fs.FileSystem.
IgniteHadoopIgfsSecondaryFileSystem() - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Default constructor for Spring.
IgniteHadoopIgfsSecondaryFileSystem(String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
IgniteHadoopIgfsSecondaryFileSystem(String, String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
IgniteHadoopIgfsSecondaryFileSystem(String, String, String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
IgniteHadoopWeightedMapReducePlanner - Class in org.apache.ignite.hadoop.mapreduce
Map-reduce planner which assigns mappers and reducers based on their "weights".
IgniteHadoopWeightedMapReducePlanner() - Constructor for class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
 
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
 
IgniteJdbcThinDriver - Class in org.apache.ignite
JDBC driver thin implementation for In-Memory Data Grid.
IgniteJdbcThinDriver() - Constructor for class org.apache.ignite.IgniteJdbcThinDriver
 
igniteLocalWorkDir() - Method in class org.apache.ignite.yarn.ClusterProperties
 
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.
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, 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.
IgniteOsgiUtils - Class in org.apache.ignite.osgi
Helper class for OSGi.
IgniteOutClosure<T> - Interface in org.apache.ignite.lang
Closure that does not take any parameters and returns a value.
ignitePackagePath() - Method in class org.apache.ignite.mesos.ClusterProperties
Path on local file system to ignite archive.
ignitePackageUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
URL to ignite package.
ignitePath() - Method in class org.apache.ignite.yarn.ClusterProperties
 
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.
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
 
IgniteProvider - Class in org.apache.ignite.mesos.resource
Class downloads and stores Ignite.
IgniteProvider(String) - Constructor for class org.apache.ignite.mesos.resource.IgniteProvider
 
IgniteProvider - Class in org.apache.ignite.yarn
Downloads and stores Ignite.
IgniteProvider(ClusterProperties, FileSystem) - Constructor for class org.apache.ignite.yarn.IgniteProvider
 
IgniteProvider.VersionComparator - Class in org.apache.ignite.yarn
Ignite version comparator.
IgniteQuery - Class in org.apache.ignite.springdata.repository.query
Ignite query helper class.
IgniteQuery(String, boolean, IgniteQuery.Option) - Constructor for class org.apache.ignite.springdata.repository.query.IgniteQuery
 
IgniteQueryGenerator - Class in org.apache.ignite.springdata.repository.query
Ignite query generator for Spring Data framework.
IgniteQueryGenerator() - Constructor for class org.apache.ignite.springdata.repository.query.IgniteQueryGenerator
 
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.
igniteReleasesDir() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteRepositoriesRegistar - Class in org.apache.ignite.springdata.repository.config
Apache Ignite specific implementation of RepositoryBeanDefinitionRegistrarSupport.
IgniteRepositoriesRegistar() - Constructor for class org.apache.ignite.springdata.repository.config.IgniteRepositoriesRegistar
 
IgniteRepository<T,ID extends Serializable> - Interface in org.apache.ignite.springdata.repository
Apache Ignite repository that extends basic capabilities of CrudRepository.
IgniteRepositoryConfigurationExtension - Class in org.apache.ignite.springdata.repository.config
Apache Ignite specific implementation of RepositoryConfigurationExtension.
IgniteRepositoryConfigurationExtension() - Constructor for class org.apache.ignite.springdata.repository.config.IgniteRepositoryConfigurationExtension
 
IgniteRepositoryFactory - Class in org.apache.ignite.springdata.repository.support
Crucial for spring-data functionality class.
IgniteRepositoryFactory(Ignite) - Constructor for class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
Creates the factory with initialized Ignite instance.
IgniteRepositoryFactory(IgniteConfiguration) - Constructor for class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
Initializes the factory with provided IgniteConfiguration that is used to start up an underlying Ignite instance.
IgniteRepositoryFactory(String) - Constructor for class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactory
Initializes the factory with provided a configuration under springCfgPath that is used to start up an underlying Ignite instance.
IgniteRepositoryFactoryBean<T extends org.springframework.data.repository.Repository<S,ID>,S,ID extends Serializable> - Class in org.apache.ignite.springdata.repository.support
Apache Ignite repository factory bean.
IgniteRepositoryFactoryBean(Class<? extends T>) - Constructor for class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactoryBean
 
IgniteRepositoryImpl<T,ID extends Serializable> - Class in org.apache.ignite.springdata.repository.support
General Apache Ignite repository implementation.
IgniteRepositoryImpl(IgniteCache<ID, T>) - Constructor for class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
Repository constructor.
IgniteRepositoryQuery - Class in org.apache.ignite.springdata.repository.query
Ignite SQL query implementation.
IgniteRepositoryQuery(RepositoryMetadata, IgniteQuery, Method, ProjectionFactory, IgniteCache) - Constructor for class org.apache.ignite.springdata.repository.query.IgniteRepositoryQuery
 
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.
IgniteScheduler - Class in org.apache.ignite.mesos
Ignite scheduler receives offers from Mesos and decides how many resources will be occupied.
IgniteScheduler(ClusterProperties, ResourceProvider) - Constructor for class org.apache.ignite.mesos.IgniteScheduler
 
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.
IgniteSink<IN> - Class in org.apache.ignite.sink.flink
Apache Flink Ignite sink implemented as a RichSinkFunction.
IgniteSink(String, String) - Constructor for class org.apache.ignite.sink.flink.IgniteSink
Default IgniteSink constructor.
IgniteSink - Class in org.apache.ignite.stream.flume
Flume sink for Apache Ignite.
IgniteSink() - Constructor for class org.apache.ignite.stream.flume.IgniteSink
Empty constructor.
IgniteSinkConnector - Class in org.apache.ignite.stream.kafka.connect
Sink connector to manage sink tasks that transfer Kafka data to Ignite grid.
IgniteSinkConnector() - Constructor for class org.apache.ignite.stream.kafka.connect.IgniteSinkConnector
 
IgniteSinkConstants - Class in org.apache.ignite.stream.flume
Configuration strings for sending data to cache.
IgniteSinkConstants() - Constructor for class org.apache.ignite.stream.flume.IgniteSinkConstants
 
IgniteSinkConstants - Class in org.apache.ignite.stream.kafka.connect
Sink configuration strings.
IgniteSinkConstants() - Constructor for class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
 
IgniteSinkTask - Class in org.apache.ignite.stream.kafka.connect
Task to consume sequences of SinkRecords and write data to grid.
IgniteSinkTask() - Constructor for class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
 
IgniteSinkTask.StreamerContext - Class in org.apache.ignite.stream.kafka.connect
Streamer context initializing grid and data streamer instances on demand.
IgniteSourceConnector - Class in org.apache.ignite.stream.kafka.connect
Source connector to manage source tasks that listens to registered Ignite grid events and forward them to Kafka.
IgniteSourceConnector() - Constructor for class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
 
IgniteSourceConstants - Class in org.apache.ignite.stream.kafka.connect
Sink configuration strings.
IgniteSourceConstants() - Constructor for class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
 
IgniteSourceTask - Class in org.apache.ignite.stream.kafka.connect
Task to consume remote cluster cache events from the grid and inject them into Kafka.
IgniteSourceTask() - Constructor for class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
 
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.
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) - 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.
IgniteTask - Class in org.apache.ignite.mesos
Information about launched task.
IgniteTask(String, double, double, double) - Constructor for class org.apache.ignite.mesos.IgniteTask
Ignite launched task.
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, 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) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance.
IgniteThread(ThreadGroup, String, String, Runnable, int, int) - 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) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadFactory(String, String) - 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() - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with default initial parameters.
IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(String) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with default initial parameters.
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(int, int, long, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - 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.
igniteUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
igniteUrl() - Method in class org.apache.ignite.yarn.ClusterProperties
 
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 GridUuid from a global and local identifiers.
igniteVer() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteWorkDir() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteWorkDir() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteYarnClient - Class in org.apache.ignite.yarn
Ignite yarn client.
IgniteYarnClient() - Constructor for class org.apache.ignite.yarn.IgniteYarnClient
 
IgniteYarnUtils - Class in org.apache.ignite.yarn.utils
Utils.
IgniteYarnUtils() - Constructor for class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
IgniteZeroMqStreamer<K,V> - Class in org.apache.ignite.stream.zeromq
This streamer uses https://github.com/zeromq/jeromq/.
IgniteZeroMqStreamer(int, ZeroMqTypeSocket, String, byte[]) - Constructor for class org.apache.ignite.stream.zeromq.IgniteZeroMqStreamer
 
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
 
implicit() - Method in interface org.apache.ignite.transactions.Transaction
Flag indicating whether transaction was started automatically by the system or not.
incomeConnLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
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.
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.
IndexingQueryFilter - Interface in org.apache.ignite.spi.indexing
Cache entry filter.
IndexingSpi - Interface in org.apache.ignite.spi.indexing
Indexing SPI allows user to index cache content.
indexReadyFuture() - Method in interface org.apache.ignite.IgniteCache
Returns future that will be completed when all indexes for this cache are ready to use.
info(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Gets file information for the specified path.
info(IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Gets file information for the specified path.
info(IgfsPath) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Gets file information for the specified path.
info(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Gets file information for the specified path.
info(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.log4j.Log4JLogger
Logs out information message.
info(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.
init() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Class instance initialization.
init(FilterConfig) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
init(ClusterProperties, IgniteProvider, String) - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
init(PlatformAffinityFunction) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Initializes this instance.
init(ServiceContext) - Method in interface org.apache.ignite.services.Service
Pre-initializes service before execution.
init() - Method in class org.apache.ignite.startup.servlet.ServletStartup
init() - Method in class org.apache.ignite.yarn.ApplicationMaster
 
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.
initialize(URI, Configuration) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
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.
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.communication.tcp.TcpCommunicationSpi
Injects resources.
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.
input() - Method in interface org.apache.ignite.hadoop.HadoopJob
Gets collection of input splits for this job.
inputIterator(Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns iterator of input records.
insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate inserted object in the database but before transaction completed.
insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate inserted object in the database but before transaction completed.
insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate inserted object in the database but before transaction completed.
insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate inserted object in the database but before transaction completed.
insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate inserted object in the database but before transaction completed.
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.yarn.IgniteProvider.VersionComparator
 
instances() - Method in class org.apache.ignite.mesos.ClusterProperties
 
instances() - Method in class org.apache.ignite.yarn.ClusterProperties
 
instances(int) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets instance count limit.
internal() - Method in class org.apache.ignite.events.TaskEvent
Returns true if task is created by Ignite and is used for system needs.
INTL_BATCH_SIZE - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
Size of one chunk drained from the internal buffer.
INTL_BUF_SIZE - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
Internal buffer size.
invoke(AffinityTopologyVersion, Object, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invoke(Object, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySetToSetSpringAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySetToValueSpringAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
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(IN) - Method in class org.apache.ignite.sink.flink.IgniteSink
Transfers data into grid.
invokeAll(Map, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAll(Set, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAll(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
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, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAllAsync(Set, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAllAsync(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously version of the IgniteCache.invokeAll(Set, EntryProcessor, 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(Object, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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
IP finder clean frequency.
isActiveOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets flag indicating whether the cluster will be active on start.
isAllowDuplicateRegistrations() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
* @return The value of this flag.
isAllSegmentationResolversPassRequired() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets all segmentation resolvers pass required flag.
isAlwaysWriteFullPages() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
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();
 
isAutoUnsubscribe() - Method in class org.apache.ignite.cache.query.ContinuousQuery
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.
isBlockUntilConnected() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets whether to block the start() method until connected for the first time.
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.
isCassandraCompatibleTypes(Class, Class) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if two Java classes are Cassandra compatible - mapped to the same Cassandra type.
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
Tests whether or not this node is connected to cluster as a client.
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 static 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.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.
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.
isClosed() - Method in class org.apache.ignite.cache.CacheManager
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
 
isColocateMetadata() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get whether to co-locate metadata on a single node.
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.log4j.Log4JLogger
Checks if Log4j is already configured within this VM or not.
isConnected() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Returns whether this streamer is connected by delegating to the underlying MqttClient.isConnected()
isCopyOnRead() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether copy of of the value stored in cache should be created for cache operation implying return value.
isDaemon() - Method in interface org.apache.ignite.cluster.ClusterNode
Tests whether or not this node is a daemon.
isDaemon() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Whether or not this node should be a daemon node.
isDaemon() - Static method in class org.apache.ignite.Ignition
Gets daemon flag.
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.log4j.Log4JLogger
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.
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 class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets flag that indicates whether direct or heap allocated buffer is used.
isDirectBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets flag that indicates whether direct or heap allocated buffer is used.
isDirectory() - Method in class org.apache.ignite.events.IgfsEvent
Checks if this is a directory-related event.
isDirectory() - Method in interface org.apache.ignite.igfs.IgfsFile
Check this file is a directory.
isDirectSendBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets flag defining whether direct send buffer should be used.
isDirectSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets flag defining whether direct send buffer should be used.
isDisconnectForcibly() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Gets whether this MQTT client will disconnect forcibly when shutting down.
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
Check if distributed joins are enabled for this query.
isDone() - Method in interface org.apache.ignite.lang.IgniteFuture
Returns true if this task completed.
isEagerTtl() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
isEmpty() - Method in interface org.apache.ignite.cache.CacheMetrics
Returns true if this cache is empty.
isEmpty() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Returns true if this map contains no key-value mappings.
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
isEmpty() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Returns true if this cache is empty.
isEnabled(int) - Method in interface org.apache.ignite.IgniteEvents
Check if event is enabled.
isEnforceJoinOrder() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Checks if join order of tables if enforced.
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.
isEventRecordable(int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Checks whether all provided event types are recordable.
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).
isExistingTransaction(Object) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
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.
isFieldQuery() - Method in class org.apache.ignite.springdata.repository.query.IgniteQuery
Returns true if it's Ignite SQL fields query, false otherwise.
isFile() - Method in interface org.apache.ignite.igfs.IgfsFile
Check this file is a data file.
isForceServerMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
If true TcpDiscoverySpi will started in server mode regardless of IgniteConfiguration.isClientMode()
isFragmentizerEnabled() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets flag indicating whether IGFS fragmentizer is enabled.
isGlobalNodeAuthentication() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
Gets global node authentication flag.
isGridify(Annotation, GridifyArgument) - Method in interface org.apache.ignite.compute.gridify.GridifyInterceptor
This method is called before actual grid-enabling happens.
isHeaderWritten() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
 
isHeldByCurrentThread() - Method in interface org.apache.ignite.IgniteLock
Queries if this lock is held by the current thread.
isHostsAvailabilityError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra host availability error occur, thus host became unavailable.
isIgfsDataCache() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks whether this cache is IGFS data cache.
isIncludeExpired() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets the flag value defining whether to notify about EventType.EXPIRED events.
isIndexed() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Indicates if secondary index should be created for the field.
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.log4j.Log4JLogger
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.
isInvalidate() - Method in class org.apache.ignite.configuration.CacheConfiguration
Invalidation flag.
isInvalidate() - Method in interface org.apache.ignite.transactions.Transaction
Get invalidation flag for this transaction.
isIpcEndpointEnabled() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get IPC endpoint enabled flag.
isKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
isKeyspaceAbsenceError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra keyspace absence error occur.
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.
isLoadPreviousValue() - Method in class org.apache.ignite.configuration.CacheConfiguration
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.
isLocalLocked(K, boolean) - Method in interface org.apache.ignite.IgniteCache
Checks if specified key is locked.
isLocked(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks if any node owns a lock for this key.
isLocked() - Method in interface org.apache.ignite.IgniteLock
Queries if this lock is held by any thread on any node.
isLockedByThread(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks if current thread owns a lock on this key.
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.
isManagementEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether management is enabled on this cache.
isManagementEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Checks whether management is enabled on this cache.
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.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Gets whether memory metrics are enabled by default on node startup.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Gets flag indicating whether persistence metrics collection is enabled.
isMongoDataCache() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks whether this cache is Mongo data cache.
isMongoMetaCache() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks whether this cache is Mongo meta cache.
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.
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
 
isolation() - Method in interface org.apache.ignite.transactions.Transaction
Cache transaction isolation level.
isOnheapCacheEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Checks if the on-heap cache is enabled for the off-heap based page memory.
isOsgi() - Static method in class org.apache.ignite.osgi.IgniteOsgiUtils
Returns whether we are running in an OSGi environment.
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
Returns true if peer class loading is enabled, false otherwise.
isPersistentStoreEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
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.
isPreparedStatementClusterError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra error occur because of prepared statement created in one session was used in another session.
isPrimary(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if given node is the primary node for given key.
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.
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.log4j.Log4JLogger
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.configuration.CacheConfiguration
Gets flag indicating whether data can be read from backup.
isReadOnly() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Indicates if it's read-only field.
isReadThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines if a Cache should operate in read-through mode.
isReadThrough() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Determines if a Cache should operate in read-through mode.
isRelaxedConsistency() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get relaxed consistency flag.
isReplicatedOnly() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Check is the query contains only replicated tables.
isReplicatedOnly() - Method in class org.apache.ignite.cache.query.SqlQuery
Check is the query contains only replicated tables.
isRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
If transaction was marked as rollback-only.
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.
isShutdown() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
isShutdown() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns true if this executor has been shut down.
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
 
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.configuration.CacheConfiguration
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
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.ConnectorConfiguration
Whether secure socket layer should be enabled on binary rest server.
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 interface org.apache.ignite.mxbean.CacheMetricsMXBean
Checks whether statistics collection is enabled in this cache.
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.
isStopped() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Returns whether this streamer is stopped.
isStopping() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
isStoreByValue() - Method in interface org.apache.ignite.cache.CacheMetrics
Whether storeByValue true or storeByReference false.
isStoreByValue() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
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.
isSubDirectoryOf(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
Checks whether this path is a sub-directory of argument.
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.
isTableAbsenceError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra table absence error occur.
isTcpNoDelay() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Get TCP NO_DELAY flag.
isTcpNoDelay() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets value for TCP_NODELAY socket option.
isTcpNoDelay() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets value for TCP_NODELAY socket option.
isTerminated() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
Note that isTerminated() is never true unless either shutdown() or shutdownNow() was called first.
isTerminated() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
isTerminating() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns true if this executor is in the process of terminating after shutdown() or shutdownNow() but has not completely terminated.
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.log4j.Log4JLogger
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.
isUpdateFileLengthOnFlush() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get whether to update file length on flush.
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.
isUseDefaultUserName() - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Get whether to use default user name when there is no mapping for current user name.
isUseJtaSynchronization() - Method in class org.apache.ignite.configuration.TransactionConfiguration
 
isUsePairedConnections() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
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.
isValidSegment() - Method in interface org.apache.ignite.plugin.segmentation.SegmentationResolver
Checks whether segment is valid.
isValueRequired() - Method in interface org.apache.ignite.spi.indexing.IndexingQueryFilter
Is the value required for filtering logic?
isWaitForSegmentOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets wait for segment on startup flag.
isWithinTransaction() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Returns true if performing store operation within a transaction, false otherwise.
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 interface org.apache.ignite.mxbean.CacheMetricsMXBean
Returns true if write-behind is enabled.
isWriteThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines if a Cache should operate in "write-through" mode.
isWriteThrough() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Determines if a Cache should operate in "write-through" mode.
iterator() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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

J

JAR_NAME - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
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.
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
 
JavaSerializer - Class in org.apache.ignite.cache.store.cassandra.serializer
Serializer based on standard Java serialization.
JavaSerializer() - Constructor for class org.apache.ignite.cache.store.cassandra.serializer.JavaSerializer
 
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.
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
 
jdkMarshaller(String) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Create JDK marshaller with provided node name.
JettyServer - Class in org.apache.ignite.mesos.resource
Embedded jetty server.
JettyServer() - Constructor for class org.apache.ignite.mesos.resource.JettyServer
 
JmsStreamer<T extends javax.jms.Message,K,V> - Class in org.apache.ignite.stream.jms11
Streamer that consumes from a JMS destination and feeds key-value pairs into an IgniteDataStreamer instance.
JmsStreamer() - Constructor for class org.apache.ignite.stream.jms11.JmsStreamer
 
jmvOpts() - Method in class org.apache.ignite.mesos.ClusterProperties
 
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.
jobName() - Method in interface org.apache.ignite.hadoop.HadoopJob
Gets job name.
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.
jvmOpts() - Method in class org.apache.ignite.yarn.ClusterProperties
 

K

KafkaStreamer<K,V> - Class in org.apache.ignite.stream.kafka
Server that subscribes to topic messages from Kafka broker and streams its to key-value pairs into IgniteDataStreamer instance.
KafkaStreamer() - Constructor for class org.apache.ignite.stream.kafka.KafkaStreamer
 
keepBinary() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Creates projection that will operate with binary objects.
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.
KerberosHadoopFileSystemFactory - Class in org.apache.ignite.hadoop.fs
Secure Hadoop file system factory that can work with underlying file system protected with Kerberos.
KerberosHadoopFileSystemFactory() - Constructor for class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
Constructor.
KerberosUserNameMapper - Class in org.apache.ignite.hadoop.util
Kerberos user name mapper.
KerberosUserNameMapper() - Constructor for class org.apache.ignite.hadoop.util.KerberosUserNameMapper
 
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 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.
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
 
KeyPersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings for Ignite cache key
KeyPersistenceSettings(Element) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates key persistence settings object based on it's XML configuration.
keySet() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Set of keys cached on this node.
keySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
keyTransformer() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
 
keyType() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
KeyValuePersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings for Ignite cache key and value
KeyValuePersistenceSettings(String) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Constructs Ignite cache key/value persistence settings.
KeyValuePersistenceSettings(File) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Constructs Ignite cache key/value persistence settings.
KeyValuePersistenceSettings(Resource) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Constructs Ignite cache key/value persistence settings.
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.
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
 
KryoSerializer - Class in org.apache.ignite.cache.store.cassandra.serializer
Serializer based on Kryo serialization.
KryoSerializer() - Constructor for class org.apache.ignite.cache.store.cassandra.serializer.KryoSerializer
 

L

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.
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.
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).
length() - Method in interface org.apache.ignite.hadoop.io.RawMemory
Get length.
length() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
Length of the data block in the file.
length() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file's length.
length() - Method in class org.apache.ignite.igfs.IgfsInputStream
Gets file length during file open.
length() - Method in class org.apache.ignite.igfs.mapreduce.IgfsFileRange
Gets range length.
length() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Gets file length during file open.
LIBS_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
LICENCE_PATH - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
LICENCE_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
licencePath() - Method in class org.apache.ignite.yarn.ClusterProperties
 
licenceUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
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.
LINE_SEPARATOR - Static variable in class org.apache.ignite.cache.store.cassandra.common.SystemHelper
System line separator.
listen(IgniteInClosure<? super IgniteFuture<V>>) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers listener closure to be asynchronously notified whenever future completes.
listenAsync(IgniteInClosure<? super IgniteFuture<V>>, Executor) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers listener closure to be asynchronously notified whenever future completes.
listFiles(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Lists files under the specified path.
listFiles(IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Lists files under the specified path.
listFiles(IgfsPath) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Lists files under the specified path.
listFiles(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Lists files under the specified path.
listPaths(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Lists file paths under the specified path.
listPaths(IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Lists file paths under the specified path.
listPaths(IgfsPath) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Lists file paths under the specified path.
listPaths(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Lists file paths under the specified path.
listStatus(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
listStatus(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
load(K) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
load(K) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
load(K) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
load(K) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
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.cassandra.CassandraCacheStore
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
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.cassandra.CassandraCacheStore
Loads all values from underlying persistent storage.
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.
LoadCacheCustomQueryWorker<K,V> - Class in org.apache.ignite.cache.store.cassandra.session
Worker for load cache using custom user query.
LoadCacheCustomQueryWorker(CassandraSession, String, PersistenceController, IgniteLogger, IgniteBiInClosure<K, V>) - Constructor for class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
 
LoadCacheCustomQueryWorker(CassandraSession, Statement, PersistenceController, IgniteLogger, IgniteBiInClosure<K, V>) - Constructor for class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
 
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.
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.s3.S3CheckpointSpi
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.
loadClass(String, boolean) - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
Loads a class trying the BundleDelegatingClassLoader.bundle first, falling back to the ClassLoader BundleDelegatingClassLoader.clsLdr.
loadClass(String, boolean) - Method in class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
Runs the same logic to find the class as BundleDelegatingClassLoader, but if not found, sweeps the OSGi container to locate the first Bundle that can load the class, and uses it to do so.
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.
locAddr - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local address.
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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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 GridUuid.
LocalIgfsSecondaryFileSystem - Class in org.apache.ignite.igfs.secondary.local
Secondary file system which delegates to local file system.
LocalIgfsSecondaryFileSystem() - Constructor for class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
 
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.
localLoadCache(IgniteBiPredicate, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Delegates to CacheStore.loadCache(IgniteBiInClosure, Object...) method to load state from the underlying persistent storage.
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, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously delegates to CacheStore.loadCache(IgniteBiInClosure, Object...) method to reload 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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets local metrics (statistics) for this cache.
localMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets local snapshot metrics (statistics) for this cache.
localMxBean() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets local metrics (statistics) for this cache.
localMxBean() - Method in interface org.apache.ignite.IgniteCache
Gets local MxBean 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.
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(Object, CachePeekMode[], IgniteCacheExpiryPolicy) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localPeek(K, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Peeks at in-memory cached value using default optional peek mode.
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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localSize(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node.
localSizeLong(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localSizeLong(int, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
localSpaceSize() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets local used space in bytes.
localTasks() - Method in interface org.apache.ignite.IgniteCompute
Gets map of all locally deployed tasks keyed by their task name .
locHost - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local host.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Synchronously acquires lock on a cached object with given key only if the passed in filter (if any) passes.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
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, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
All or nothing synchronous lock for passed in keys.
lockAll(Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Creates a Lock instance associated with passed keys.
lockAllAsync(Collection, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
All or nothing synchronous lock for passed in keys.
lockAsync(Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously acquires lock on a cached object with given key only if the passed in filter (if any) passes.
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.
lockRegion() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called during database transaction execution before Hibernate executed update operation which should invalidate entire cache region.
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.hibernate.HibernateAccessStrategyAdapter
 
log - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Auto-injected logger instance.
log - Variable in class org.apache.ignite.hadoop.planner.HadoopAbstractMapReducePlanner
Logger.
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.stream.twitter.TwitterStreamer
Logger.
log - Variable in class org.apache.ignite.stream.zeromq.IgniteZeroMqStreamer
Logger.
log - Static variable in class org.apache.ignite.yarn.ApplicationMaster
 
log - Static variable in class org.apache.ignite.yarn.IgniteYarnClient
 
Log4J2Logger - Class in org.apache.ignite.logger.log4j2
Log4j2-based implementation for logging.
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.
Log4JDailyRollingFileAppender - Class in org.apache.ignite.logger.log4j
Log4J DailyRollingFileAppender with added support for grid node IDs.
Log4JDailyRollingFileAppender() - Constructor for class org.apache.ignite.logger.log4j.Log4JDailyRollingFileAppender
Default constructor (does not do anything).
Log4JDailyRollingFileAppender(Layout, String, String) - Constructor for class org.apache.ignite.logger.log4j.Log4JDailyRollingFileAppender
Instantiate a FileAppender with given parameters.
Log4JExternallyRolledFileAppender - Class in org.apache.ignite.logger.log4j
Log4J ExternallyRolledFileAppender with added support for grid node IDs.
Log4JExternallyRolledFileAppender() - Constructor for class org.apache.ignite.logger.log4j.Log4JExternallyRolledFileAppender
Default constructor (does not do anything).
Log4JFileAppender - Class in org.apache.ignite.logger.log4j
Log4J FileAppender with added support for grid node IDs.
Log4JFileAppender() - Constructor for class org.apache.ignite.logger.log4j.Log4JFileAppender
Default constructor (does not do anything).
Log4JFileAppender(Layout, String) - Constructor for class org.apache.ignite.logger.log4j.Log4JFileAppender
Instantiate a FileAppender with given parameters.
Log4JFileAppender(Layout, String, boolean) - Constructor for class org.apache.ignite.logger.log4j.Log4JFileAppender
Instantiate a FileAppender with given parameters.
Log4JFileAppender(Layout, String, boolean, boolean, int) - Constructor for class org.apache.ignite.logger.log4j.Log4JFileAppender
Instantiate a FileAppender with given parameters.
Log4JLogger - Class in org.apache.ignite.logger.log4j
Log4j-based implementation for logging.
Log4JLogger() - Constructor for class org.apache.ignite.logger.log4j.Log4JLogger
Creates new logger and automatically detects if root logger already has appenders configured.
Log4JLogger(boolean) - Constructor for class org.apache.ignite.logger.log4j.Log4JLogger
Creates new logger.
Log4JLogger(Logger) - Constructor for class org.apache.ignite.logger.log4j.Log4JLogger
Creates new logger with given implementation.
Log4JLogger(String) - Constructor for class org.apache.ignite.logger.log4j.Log4JLogger
Creates new logger with given configuration path.
Log4JLogger(File) - Constructor for class org.apache.ignite.logger.log4j.Log4JLogger
Creates new logger with given configuration cfgFile.
Log4JLogger(URL) - Constructor for class org.apache.ignite.logger.log4j.Log4JLogger
Creates new logger with given configuration cfgUrl.
Log4jRollingFileAppender - Class in org.apache.ignite.logger.log4j
Log4J RollingFileAppender with added support for grid node IDs.
Log4jRollingFileAppender() - Constructor for class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
Default constructor (does not do anything).
Log4jRollingFileAppender(Layout, String) - Constructor for class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
Instantiate a FileAppender with given parameters.
Log4jRollingFileAppender(Layout, String, boolean) - Constructor for class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
Instantiate a FileAppender with given parameters.
logFiles() - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
Gets files for all registered file appenders.
logger() - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Get logger.
LoggerNodeIdAware - Interface in org.apache.ignite.logger
Interface for Ignite file appenders to attach node ID to log file names.
LoggerResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of IgniteLogger.
login() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Login provided via subject security credentials.
logPanel(String, String, List<String>) - Method in interface org.apache.ignite.visor.plugin.VisorPluginComponentsFactory
Create panel with list of log events.
lostPartitions() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
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.

M

main(String[]) - Static method in class org.apache.ignite.cache.store.cassandra.utils.DDLGenerator
DDLGenerator entry point.
main(String[]) - Static method in class org.apache.ignite.mesos.IgniteFramework
Main methods has only one optional parameter - path to properties files.
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.
main(String[]) - Static method in class org.apache.ignite.yarn.ApplicationMaster
 
main(String[]) - Static method in class org.apache.ignite.yarn.IgniteYarnClient
Main methods has one mandatory parameter and one optional parameter.
maintenance() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets maintenance version number.
major() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets major version number.
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.
map(List<ClusterNode>, GridifyRangeArgument) - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
This method is called to map or split grid task into multiple grid jobs.
map(List<ClusterNode>, GridifyArgument) - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
This method is called to map or split grid task into multiple grid jobs.
map(String) - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Map user name.
map(String) - Method in class org.apache.ignite.hadoop.util.ChainedUserNameMapper
Map user name.
map(String) - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Map user name.
map(String) - Method in interface org.apache.ignite.hadoop.util.UserNameMapper
Map user name.
map(List<ClusterNode>, IgfsTaskArgs<T>) - Method in class org.apache.ignite.igfs.mapreduce.IgfsTask
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.
mapperNodeIds() - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets collection of all node IDs involved in map part of job execution.
mappers(UUID) - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets collection of file blocks for which mappers should be executed.
mappers() - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets overall number of mappers for the job.
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.
masterUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
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_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.
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.
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.services.ServiceDescriptor
Gets maximum allowed number of deployed services on each node, 0 for unlimited.
maxRangeLength() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
Optional maximum allowed range length, 0 by default.
maxSpaceSize() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Gets maximum amount of data that can be stored on local node.
MEM - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Mem.
mem - Variable in class org.apache.ignite.mesos.IgniteTask
 
mem() - Method in class org.apache.ignite.mesos.IgniteTask
 
mem - Variable in class org.apache.ignite.yarn.IgniteContainer
 
mem() - Method in class org.apache.ignite.yarn.IgniteContainer
 
memory() - Method in class org.apache.ignite.mesos.ClusterProperties
 
memory(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets mem limit.
MemoryConfiguration - Class in org.apache.ignite.configuration
A page memory configuration for an Apache Ignite node.
MemoryConfiguration() - Constructor for class org.apache.ignite.configuration.MemoryConfiguration
 
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
Returns a collection of MemoryMetrics that reflects page memory usage on this Apache Ignite node instance.
memoryMetrics(String) - Method in interface org.apache.ignite.Ignite
Returns the latest MemoryMetrics snapshot for the memory region of the given name.
memoryMetrics() - Method in class org.apache.ignite.IgniteSpringBean
Returns a collection of MemoryMetrics that reflects page memory usage on this Apache Ignite node instance.
memoryMetrics(String) - Method in class org.apache.ignite.IgniteSpringBean
Returns the latest MemoryMetrics snapshot for the memory region of the given name.
MemoryMetrics - Interface in org.apache.ignite
This interface provides page memory related metrics of a specific Apache Ignite node.
MemoryMetricsMXBean - Interface in org.apache.ignite.mxbean
This interface defines a JMX view on MemoryMetrics.
memoryOverHeadPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
memoryOverHeadPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets memory overhead requested to YARN.
memoryPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
memoryPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets mem limit.
memoryPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
memoryPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets mem limit.
MemoryPolicyConfiguration - Class in org.apache.ignite.configuration
This class allows defining custom memory policies' configurations with various parameters for Apache Ignite page memory (see MemoryConfiguration.
MemoryPolicyConfiguration() - Constructor for class org.apache.ignite.configuration.MemoryPolicyConfiguration
 
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.
MESOS_MASTER_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
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.TcpCommunicationSpi.HandshakeMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
Full message size (with message type) in bytes.
messageArrived(String, MqttMessage) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Implements the MqttCallback.messageArrived(String, MqttMessage) to receive an MQTT message.
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
Factory for communication messages.
messageFactory() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets message factory.
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.
MessageTransformer<T extends javax.jms.Message,K,V> - Interface in org.apache.ignite.stream.jms11
Implement this interface to transform from a Message to a set of cache entries in the form of a Map.
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.
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.IgniteFileSystem
Gets metrics snapshot for this file system.
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.
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.
minCpuPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
minCpuPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets min cpu count per node.
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.
minMemoryPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
minMemoryPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets min memory.
minor() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets minor version number.
mkdir(Path, FsPermission, boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
mkdirs(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Creates directories under specified path.
mkdirs(IgfsPath, Map<String, String>) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Creates directories under specified path with the specified properties.
mkdirs(Path, FsPermission) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
mkdirs(IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Creates directories under specified path.
mkdirs(IgfsPath, Map<String, String>) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Creates directories under specified path with the specified properties.
mkdirs(IgfsPath) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Creates directories under specified path.
mkdirs(IgfsPath, Map<String, String>) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Creates directories under specified path with the specified properties.
mkdirs(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Creates directories under specified path.
mkdirs(IgfsPath, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
Creates directories under specified path with the specified properties.
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.
mode(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Get mode for the given path.
model() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
 
modificationTime() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file last modification time.
MqttStreamer<K,V> - Class in org.apache.ignite.stream.mqtt
Streamer that consumes from a MQTT topic and feeds key-value pairs into an IgniteDataStreamer instance, using Eclipse Paho as an MQTT client.
MqttStreamer() - Constructor for class org.apache.ignite.stream.mqtt.MqttStreamer
 
MSG_EXPIRE_TIME_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Stealing request expiration time attribute name.
Mutation - Interface in org.apache.ignite.cache.store.cassandra.session.transaction
Provides information about particular mutation operation performed withing transaction.
mxBean() - Method in interface org.apache.ignite.IgniteCache
Gets whole cluster MxBean for this cache.
MXBeanDescription - Annotation Type in org.apache.ignite.mxbean
Provides description for MBean classes and methods.
MXBeanParametersDescriptions - Annotation Type in org.apache.ignite.mxbean
Provides MBean method parameters description.
MXBeanParametersNames - Annotation Type in org.apache.ignite.mxbean
Provides MBean method parameters names.
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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets name of this cache (null for default cache).
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 class org.apache.ignite.igfs.IgfsPath
Returns the final component of this path.
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.IgniteFileSystem
Gets IGFS name.
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.mxbean.CacheMetricsMXBean
Gets name of this cache.
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 class org.apache.ignite.visor.plugin.VisorExtensionPoint
 
name() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
 
names() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
Compliant with Hadoop interface.
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.
nearSize() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets size of near cache key set.
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.
NEW_LINE - Static variable in class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
Singleton new line resolver.
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
 
newPath() - Method in class org.apache.ignite.events.IgfsEvent
New file or directory path for this event (used in EventType.EVT_IGFS_FILE_RENAMED 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.
nextTimeoutChunk(long) - Method in class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Returns a timeout value to use for the next network operation.
node() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
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_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").
nodeAttributes() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets node attributes.
nodeAttributes(Map<String, Object>) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets node attributes.
nodeAttributes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
nodeAuth - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Node authenticator.
nodeFilter - Variable in class org.apache.ignite.services.ServiceConfiguration
Node filter.
nodeForReducer(int) - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets node ID for reducer.
nodeId(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.TcpCommunicationSpi.HandshakeMessage
 
nodeId() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
nodeId() - Method in interface org.apache.ignite.transactions.Transaction
ID of the node on which this transaction started.
nodeId - Variable in class org.apache.ignite.yarn.IgniteContainer
 
nodeId() - Method in class org.apache.ignite.yarn.IgniteContainer
 
nodeIds() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
Nodes this block belongs to.
nodeIds() - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
 
nodeLocalMap() - Method in interface org.apache.ignite.IgniteCluster
Gets node-local storage instance.
nodeName(String) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Set node name.
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.
nodesPanel(String, String, List<String>, boolean) - Method in interface org.apache.ignite.visor.plugin.VisorPluginComponentsFactory
Create panel with 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
 
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
 
NoopEventStorageSpi - Class in org.apache.ignite.spi.eventstorage
No-op implementation of EventStorageSpi.
NoopEventStorageSpi() - Constructor for class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
 
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
 
notifyListener(UUID, Message, IgniteRunnable) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
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

OAuthSettings - Class in org.apache.ignite.stream.twitter
OAuth keys holder.
OAuthSettings(String, String, String, String) - Constructor for class org.apache.ignite.stream.twitter.OAuthSettings
 
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
offerRescinded(SchedulerDriver, Protos.OfferID) - Method in class org.apache.ignite.mesos.IgniteScheduler
offHeapAllocatedSize() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets memory size allocated in off-heap.
offHeapEntriesCount() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets number of cache entries stored in off-heap memory.
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).
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.TcpCommunicationSpi.HandshakeMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.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.
onAfterStart(BundleContext, Throwable) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
This method is called after Ignite initialises, only if initialization succeeded.
onAfterStop(BundleContext, Throwable) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
This method is called after Ignite stops, only if the operation succeeded.
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(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
This method is called before Ignite initialises.
onBeforeStart() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method is called by built-in managers implementation to avoid repeating SPI start attempts.
onBeforeStop(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
This method is called before Ignite stops.
onChange(Collection<T>) - Method in interface org.apache.ignite.visor.plugin.VisorSelectionListener
On selection changed.
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.
onClosed() - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
Will be executed on tab close.
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.
onConnected() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
Will be executed on Visor connect to grid.
onContainersAllocated(List<Container>) - Method in class org.apache.ignite.yarn.ApplicationMaster
onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.ignite.yarn.ApplicationMaster
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.tcp.TcpDiscoverySpi
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.
onDisconnected(UUID) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
Callback invoked when connection with remote node is lost.
onDisconnected() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
Will be executed on Visor disconnect from grid.
onDiscovery(int, long, ClusterNode, Collection<ClusterNode>, Map<Long, Collection<ClusterNode>>, DiscoverySpiCustomMessage) - 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.
onEntryAccessed(boolean, EvictableEntry<IgfsBlockKey, byte[]>) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Callback for whenever entry is accessed.
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.
onError(Throwable) - Method in class org.apache.ignite.yarn.ApplicationMaster
onEventsChanged() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
Will be executed on Visor events changed.
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.
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.
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.
onLocalNodeInitialized(ClusterNode) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
Notification of local node initialization.
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.
onModelChanged() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
Will be executed on Visor model changed.
onNodeFailed(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
Action that should be done on node failed.
onNodeJoin(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
Action that should be done on node join.
onNodeLeft(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
Action that should be done on node left.
onNodeSegmented(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
Action that should be done on node segmented.
onNodesUpdated(List<NodeReport>) - Method in class org.apache.ignite.yarn.ApplicationMaster
onReceive(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
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.
onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
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.
onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
On session start callback.
onShutdownRequest() - Method in class org.apache.ignite.yarn.ApplicationMaster
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.
onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
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.
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..
open(IgfsPath, int) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Opens a file for reading.
open(Path, int) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
open(Path, int) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
open(IgfsPath, int) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Opens a file for reading.
open(IgfsPath, int) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Opens a file for reading.
open(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Opens a file for reading.
open(IgfsPath, int) - Method in interface org.apache.ignite.IgniteFileSystem
Opens a file for reading.
open(IgfsPath, int, int) - Method in interface org.apache.ignite.IgniteFileSystem
Opens a file for reading.
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.
operationName() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Display name for the batch operation.
operationName() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchLoaderAssistant
Returns name of the batch load operation.
operationName() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Returns operation name.
options() - Method in class org.apache.ignite.springdata.repository.query.IgniteQuery
Advanced querying option.
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.cluster.ClusterNode
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.igfs - package org.apache.ignite.cache.eviction.igfs
Contains IGFS LRU 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.hibernate - package org.apache.ignite.cache.hibernate
Contains implementation of Hibernate L2 cache.
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.spring - package org.apache.ignite.cache.spring
Contains implementation of Spring cache abstraction and @Cacheable annotation.
org.apache.ignite.cache.store - package org.apache.ignite.cache.store
Contains cache store interfaces.
org.apache.ignite.cache.store.cassandra - package org.apache.ignite.cache.store.cassandra
Contains CacheStore implementation backed by Cassandra database
org.apache.ignite.cache.store.cassandra.common - package org.apache.ignite.cache.store.cassandra.common
Contains commonly used helper classes
org.apache.ignite.cache.store.cassandra.datasource - package org.apache.ignite.cache.store.cassandra.datasource
Contains data source implementation
org.apache.ignite.cache.store.cassandra.persistence - package org.apache.ignite.cache.store.cassandra.persistence
Contains persistent settings configuration
org.apache.ignite.cache.store.cassandra.serializer - package org.apache.ignite.cache.store.cassandra.serializer
Contains serializers implementation, to store BLOBs into Cassandra
org.apache.ignite.cache.store.cassandra.session - package org.apache.ignite.cache.store.cassandra.session
Contains classes responsible for handling sessions and communication with Cassandra
org.apache.ignite.cache.store.cassandra.session.pool - package org.apache.ignite.cache.store.cassandra.session.pool
Contains session pool implenetation for Cassandra sessions
org.apache.ignite.cache.store.cassandra.session.transaction - package org.apache.ignite.cache.store.cassandra.session.transaction
Contains mutations implementation, to store changes made inside Ignite transaction
org.apache.ignite.cache.store.cassandra.utils - package org.apache.ignite.cache.store.cassandra.utils
Contains utility classes
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.store.spring - package org.apache.ignite.cache.store.spring
Contains cache store session listener based on Spring transaction management.
org.apache.ignite.cache.websession - package org.apache.ignite.cache.websession
Contains classes for Web Sessions Caching.
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.compute.gridify - package org.apache.ignite.compute.gridify
Contains APIs utilized for AOP-based grid-enabling.
org.apache.ignite.compute.gridify.aop - package org.apache.ignite.compute.gridify.aop
Contains common classes for different AOP providers.
org.apache.ignite.compute.gridify.aop.aspectj - package org.apache.ignite.compute.gridify.aop.aspectj
Contains all classes used by AspectJ AOP implementation.
org.apache.ignite.compute.gridify.aop.spring - package org.apache.ignite.compute.gridify.aop.spring
Contains all classes used by Spring AOP implementation.
org.apache.ignite.configuration - package org.apache.ignite.configuration
Contains configuration-related classes.
org.apache.ignite.events - package org.apache.ignite.events
Contains Event Subscription functionality together with various events emitted by Ignite.
org.apache.ignite.hadoop - package org.apache.ignite.hadoop
Contains Hadoop Accelerator APIs.
org.apache.ignite.hadoop.fs - package org.apache.ignite.hadoop.fs
Ignite Hadoop Accelerator file system API.
org.apache.ignite.hadoop.fs.v1 - package org.apache.ignite.hadoop.fs.v1
Contains Ignite Hadoop 1.x FileSystem implementation.
org.apache.ignite.hadoop.fs.v2 - package org.apache.ignite.hadoop.fs.v2
Contains Ignite Hadoop 2.x FileSystem implementation.
org.apache.ignite.hadoop.io - package org.apache.ignite.hadoop.io
Contains Hadoop Accelerator API for input-output operations.
org.apache.ignite.hadoop.mapreduce - package org.apache.ignite.hadoop.mapreduce
Ignite Hadoop Accelerator map-reduce classes.
org.apache.ignite.hadoop.planner - package org.apache.ignite.hadoop.planner
Ignite Hadoop Accelerator planner classes.
org.apache.ignite.hadoop.util - package org.apache.ignite.hadoop.util
Ignite Hadoop Accelerator utility classes.
org.apache.ignite.igfs - package org.apache.ignite.igfs
Contains IGnite File System APIs.
org.apache.ignite.igfs.mapreduce - package org.apache.ignite.igfs.mapreduce
Contains APIs for In-Memory MapReduce over IGFS.
org.apache.ignite.igfs.mapreduce.records - package org.apache.ignite.igfs.mapreduce.records
Contains record resolvers for In-Memory MapReduce over IGFS.
org.apache.ignite.igfs.secondary - package org.apache.ignite.igfs.secondary
Contains APIs for IGFS secondary file system base on local file system.
org.apache.ignite.igfs.secondary.local - package org.apache.ignite.igfs.secondary.local
Contains APIs for IGFS secondary file system.
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.log4j - package org.apache.ignite.logger.log4j
Contains default Log4j 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.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.mesos - package org.apache.ignite.mesos
Contains classes to support integration with Apache Mesos.
org.apache.ignite.mesos.resource - package org.apache.ignite.mesos.resource
Contains classes provide access to resources.
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.osgi - package org.apache.ignite.osgi
Contains OSGi related classes.
org.apache.ignite.osgi.classloaders - package org.apache.ignite.osgi.classloaders
Contains implementation of OSGi class loaders.
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.sink.flink - package org.apache.ignite.sink.flink
IgniteSink -- streaming connector integration with Apache Flink.
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.s3 - package org.apache.ignite.spi.checkpoint.s3
Contains S3-based implementation for checkpoint SPI.
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.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.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.cloud - package org.apache.ignite.spi.discovery.tcp.ipfinder.cloud
Contains Apache jclouds based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.gce - package org.apache.ignite.spi.discovery.tcp.ipfinder.gce
Contains Google Cloud Storage IP finder.
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.s3 - package org.apache.ignite.spi.discovery.tcp.ipfinder.s3
Contains AWS S3-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.tcp.ipfinder.zk - package org.apache.ignite.spi.discovery.tcp.ipfinder.zk
Contains TCP Discovery IP Finder uses Apache ZooKeeper (ZK) to locate peer nodes.
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.springdata.repository - package org.apache.ignite.springdata.repository
Package contains Apache Ignite Spring Data integration.
org.apache.ignite.springdata.repository.config - package org.apache.ignite.springdata.repository.config
Package includes Spring Data integration related configuration files.
org.apache.ignite.springdata.repository.query - package org.apache.ignite.springdata.repository.query
Package includes classes that integrates with Apache Ignite SQL engine.
org.apache.ignite.springdata.repository.support - package org.apache.ignite.springdata.repository.support
Package contains supporting files required by Spring Data framework.
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.camel - package org.apache.ignite.stream.camel
Contains implementation of Camel Streamer.
org.apache.ignite.stream.flume - package org.apache.ignite.stream.flume
Contains implementation of Flume Sink.
org.apache.ignite.stream.jms11 - package org.apache.ignite.stream.jms11
Contains implementation of JMS queue and topic messages consumer.
org.apache.ignite.stream.kafka - package org.apache.ignite.stream.kafka
Contains implementation of Kafka Streamer.
org.apache.ignite.stream.kafka.connect - package org.apache.ignite.stream.kafka.connect
Contains implementation of Kafka Streamer Connector.
org.apache.ignite.stream.kafka.connect.serialization - package org.apache.ignite.stream.kafka.connect.serialization
Contains implementation of Kafka Streamer Serializer.
org.apache.ignite.stream.mqtt - package org.apache.ignite.stream.mqtt
Contains implementation of MQTT topic messages consumer.
org.apache.ignite.stream.rocketmq - package org.apache.ignite.stream.rocketmq
Contains implementation of RocketMQStreamer tests.
org.apache.ignite.stream.socket - package org.apache.ignite.stream.socket
Contains socket streamer implementation.
org.apache.ignite.stream.storm - package org.apache.ignite.stream.storm
StormStreamer -- integration with Apache Storm.
org.apache.ignite.stream.twitter - package org.apache.ignite.stream.twitter
Contains implementation of Twitter Streamer.
org.apache.ignite.stream.zeromq - package org.apache.ignite.stream.zeromq
Contains implementation of ZeroMQ Streamer.
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.
org.apache.ignite.transactions.spring - package org.apache.ignite.transactions.spring
Contains implementation of Spring transaction manager.
org.apache.ignite.visor.plugin - package org.apache.ignite.visor.plugin
Contains Visor Plugin extension functionality.
org.apache.ignite.yarn - package org.apache.ignite.yarn
Contains classes to support integration with Apache Hadoop Yarn.
org.apache.ignite.yarn.utils - package org.apache.ignite.yarn.utils
Utility and helper classes.
originNodeId() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets ID of grid node that initiated the service deployment.
OSGI_SERVICE_PROP_IGNITE_NAME - Static variable in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
OSGI service property name.
OsgiClassLoadingStrategyType - Enum in org.apache.ignite.osgi.classloaders
Enum for the user to indicate which type of ClassLoader Ignite should use.
OUT_OF_RESOURCES_TCP_MSG - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
IPC error message.

P

parent() - Method in class org.apache.ignite.igfs.IgfsPath
Returns the parent of a path or null if at root.
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.
PartiallyRawComparator<T> - Interface in org.apache.ignite.hadoop.io
Partially raw comparator.
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 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.
PartitionLossPolicy - Enum in org.apache.ignite.cache
Partition loss policy.
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.
path() - Method in class org.apache.ignite.events.IgfsEvent
Path of the file or directory, on which event has occurred.
path() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets path to file.
path() - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
path(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
path() - Method in class org.apache.ignite.igfs.mapreduce.IgfsFileRange
Gets file path.
paths() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
Gets file paths to process.
pattern() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets scheduling pattern.
peek() - Method in interface org.apache.ignite.IgniteQueue
PERFORMANCE_COUNTER_FILE_NAME - Static variable in class org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter
 
permissions() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Authorized permission set for the subject.
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.
PersistenceController - Class in org.apache.ignite.cache.store.cassandra.persistence
Intermediate layer between persistent store (Cassandra) and Ignite cache key/value classes.
PersistenceController(KeyValuePersistenceSettings) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Constructs persistence controller from Ignite cache persistence settings.
PersistenceMetrics - Interface in org.apache.ignite
Persistence metrics used to obtain statistics on persistence.
PersistenceMetricsMXBean - Interface in org.apache.ignite.mxbean
An MX bean allowing to monitor and tune persistence metrics.
PersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings, which describes how particular key/value from Ignite cache should be stored in Cassandra.
PersistenceSettings(Element) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Constructs persistence settings from corresponding XML element.
PersistenceStrategy - Enum in org.apache.ignite.cache.store.cassandra.persistence
Describes persistence strategy to be used to persist object data into Cassandra.
PersistentStoreConfiguration - Class in org.apache.ignite.configuration
Configures Apache Ignite Persistent store.
PersistentStoreConfiguration() - Constructor for class org.apache.ignite.configuration.PersistentStoreConfiguration
 
persistentStoreMetrics() - Method in interface org.apache.ignite.Ignite
 
persistentStoreMetrics() - Method in class org.apache.ignite.IgniteSpringBean
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.tcp.TcpDiscoverySpi
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.
PlainCredentials - Class in org.apache.ignite.cache.store.cassandra.datasource
Simple implementation of Credentials which just uses its constructor to hold user/password values.
PlainCredentials(String, String) - Constructor for class org.apache.ignite.cache.store.cassandra.datasource.PlainCredentials
Creates credentials object.
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.
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
TODO: Add class description.
PluginValidationException(String, String, UUID) - Constructor for exception org.apache.ignite.plugin.PluginValidationException
Constructs invalid plugin exception.
PojoField - Class in org.apache.ignite.cache.store.cassandra.persistence
Descriptor for particular field in a POJO object, specifying how this field should be written to or loaded from Cassandra.
PojoField(Element, Class<?>) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Creates instance of PojoField based on it's description in XML element.
PojoField(PojoFieldAccessor) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Creates instance of PojoField from its field accessor.
PojoFieldAccessor - Class in org.apache.ignite.cache.store.cassandra.persistence
Property accessor provides read/write access to POJO object properties defined through: 1) Getter/setter methods 2) Raw class members
PojoFieldAccessor(PropertyDescriptor, Field) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Constructs object instance from Java Bean property descriptor, providing access to getter/setter.
PojoFieldAccessor(Field) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Constructs object instance from Field, providing direct access to class member.
PojoKeyField - Class in org.apache.ignite.cache.store.cassandra.persistence
Descriptor for Ignite key POJO class
PojoKeyField(Element, Class) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Constructs Ignite cache key POJO object descriptor.
PojoKeyField(PojoFieldAccessor) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Constructs Ignite cache key POJO object descriptor.
PojoKeyField.SortOrder - Enum in org.apache.ignite.cache.store.cassandra.persistence
Specifies sort order for POJO key field
PojoValueField - Class in org.apache.ignite.cache.store.cassandra.persistence
Descriptor for Ignite value POJO class
PojoValueField(Element, Class) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Constructs Ignite cache value field descriptor.
PojoValueField(PojoFieldAccessor) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Constructs Ignite cache value field descriptor.
poll() - Method in interface org.apache.ignite.IgniteQueue
poll(long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
poll() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
position() - Method in class org.apache.ignite.igfs.IgfsInputStream
Get the current position in the input stream.
position() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Get the current position in the input stream.
predicate() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets predicate that defines a subset of nodes for this cluster group.
prepare(int[]) - Method in class org.apache.ignite.cache.query.Query
Prepares the partitions.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.ignite.stream.storm.StormStreamer
Initializes Ignite client instance from a configuration file and declares the output collector of the bolt.
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.
preparePlan(HadoopJob, Collection<ClusterNode>, HadoopMapReducePlan) - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlanner
Prepares map-reduce execution plan for the given job and topology.
preparePlan(HadoopJob, Collection<ClusterNode>, HadoopMapReducePlan) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Prepares map-reduce execution plan for the given job and topology.
preparePlan(HadoopJob, Collection<ClusterNode>, HadoopMapReducePlan) - Method in class org.apache.ignite.hadoop.planner.HadoopTestRoundRobinMrPlanner
Prepares map-reduce execution plan for the given job and topology.
previousAssignment(int) - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets affinity assignment for given partition on previous topology version.
primaryPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which the given cluster node has primary ownership.
primarySize() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all primary entries cached on this node.
primarySizeLong() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all primary entries cached on this node as a long value.
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.
process(Row, int) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Processes particular row inside batch operation.
process(Row) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchLoaderAssistant
Processes each row returned by batch load operation.
process(Row) - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Processes Cassandra database table row returned by specified CQL statement.
process(Row, int) - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Processes particular row inside batch operation.
process(Row) - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Processes particular row inside batch operation.
process(Exchange) - Method in class org.apache.ignite.stream.camel.CamelStreamer
Processes the incoming Exchange and adds the tuple(s) to the underlying streamer.
process() - Method in class org.apache.ignite.stream.flume.IgniteSink
Processes Flume events.
processedCount() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
 
processedCount() - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
processedData() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
 
processedData() - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
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_HOST - Static variable in class org.apache.ignite.IgniteJdbcDriver
Hostname property name.
PROP_LOCAL - Static variable in class org.apache.ignite.IgniteJdbcDriver
Local property name.
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_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.
PROP_ZK_CONNECTION_STRING - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
System property name to provide the ZK Connection String.
properties() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Gets current session properties.
properties() - Method in interface org.apache.ignite.igfs.IgfsFile
Get properties of the file.
property(String) - Method in interface org.apache.ignite.hadoop.HadoopJob
Gets optional configuration property for the job.
property(String) - Method in interface org.apache.ignite.igfs.IgfsFile
Get file's property for specified name.
property(String, String) - Method in interface org.apache.ignite.igfs.IgfsFile
Get file's property for specified name.
PropertyMappingHelper - Class in org.apache.ignite.cache.store.cassandra.common
Helper class providing bunch of methods to discover fields of POJO objects and map builtin Java types to appropriate Cassandra types.
PropertyMappingHelper() - Constructor for class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
 
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(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache.
put(CassandraSessionImpl, Session, long) - Static method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
Returns Cassandra driver session to sessions pool.
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, K, V, long) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Puts object in cache.
put(Collection<SinkRecord>) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
Buffers records.
putAll(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pairs in cache.
putAll(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.IgniteCache
putAll(Map<? extends V1, ? extends V2>) - Method in class org.apache.ignite.lang.IgniteBiTuple
putAllAsync(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pairs in cache.
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.
putAllConflict(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Store DR data.
putAllConflictAsync(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Store DR data asynchronously.
putAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache.
putAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified value with the specified key in the cache.
putFromLoad(Object, Object, boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
putFromLoad(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Puts in cache value loaded from the database.
putFromLoad(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Puts in cache value loaded from the database.
putFromLoad(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Puts in cache value loaded from the database.
putIfAbsent(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if cache had no previous mapping for it.
putIfAbsent(K, V) - Method in interface org.apache.ignite.IgniteCache
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(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
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
Base class for all Ignite cache queries.
query() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
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(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.
Query - Annotation Type in org.apache.ignite.springdata.repository.config
Annotation to provide a user defined SQL query for a method.
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.
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.
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.
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.
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.
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.

R

RandomSleeper - Class in org.apache.ignite.cache.store.cassandra.common
Provides sleep method with randomly selected sleep time from specified range and incrementally shifts sleep time range for each next sleep attempt
RandomSleeper(int, int, int, IgniteLogger) - Constructor for class org.apache.ignite.cache.store.cassandra.common.RandomSleeper
Creates sleeper instance.
randomUuid() - Static method in class org.apache.ignite.lang.IgniteUuid
Creates new pseudo-random ID.
rateTimeInterval(long) - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
rateTimeInterval(long) - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Sets time interval for rate-based metrics.
RawMemory - Interface in org.apache.ignite.hadoop.io
Memory abstraction for raw comparison.
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(long, byte[], int, int) - Method in class org.apache.ignite.igfs.IgfsInputStream
 
read() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
read(byte[], int, int) - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
read(long, byte[], int, int) - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
read(long, byte[], int, int) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystemPositionedReadable
Read up to the specified number of bytes, from a given position within a file, and return the number of bytes read.
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.igfs.IgfsPath
Reads fields from provided reader.
readBinary(BinaryReader) - Method in class org.apache.ignite.igfs.IgfsPathSummary
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.igfs.IgfsPerBlockLruEvictionPolicy
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
readExternal(ObjectInput) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
readExternal(ObjectInput) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
readExternal(ObjectInput) - Method in class org.apache.ignite.igfs.IgfsPath
readExternal(ObjectInput) - Method in class org.apache.ignite.igfs.IgfsPathSummary
readExternal(ObjectInput) - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
readExternal(ObjectInput) - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
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.TcpCommunicationSpi.HandshakeMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage2
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
Reads this message from provided byte buffer.
readFully(long, byte[]) - Method in class org.apache.ignite.igfs.IgfsInputStream
Read bytes from the given position in the stream to the given buffer.
readFully(long, byte[], int, int) - Method in class org.apache.ignite.igfs.IgfsInputStream
 
readFully(long, byte[]) - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Read bytes from the given position in the stream to the given buffer.
readFully(long, byte[], int, int) - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
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.
readRawBinary(BinaryRawReader) - Method in class org.apache.ignite.igfs.IgfsPath
Read raw binary.
readReceipt(Socket, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Reads message delivery receipt from the socket.
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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Forces this cache node to re-balance its partitions.
rebalance() - Method in interface org.apache.ignite.IgniteCache
This cache node to re-balance its partitions.
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.TcpCommunicationSpi.HandshakeMessage
 
received() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
 
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).
receiver(StreamReceiver<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets custom stream receiver to this data streamer.
reconnect() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Force reconnect to cluster.
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.
recordResolver() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
Gets record resolver for the task.
RECOVERY_LAST_ID_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Recovery last received ID message type.
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(List<ComputeJobResult>) - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
Reduces (or aggregates) results received so far into one compound result to be returned to caller via ComputeTaskFuture.get() method.
reduce(List<ComputeJobResult>) - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
Reduces (or aggregates) results received so far into one compound result to be returned to caller via ComputeTaskFuture.get() method.
reduce(List<ComputeJobResult>) - Method in class org.apache.ignite.igfs.mapreduce.IgfsTaskNoReduceAdapter
Default implementation which will ignore all results sent from execution nodes.
reduce() - Method in interface org.apache.ignite.lang.IgniteReducer
Reduces collected values into one.
reducerNodeIds() - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets collection of all node IDs involved in reduce part of job execution.
reducers() - Method in interface org.apache.ignite.hadoop.HadoopJob
 
reducers(UUID) - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets reducer IDs that should be started on given node.
reducers() - Method in interface org.apache.ignite.hadoop.HadoopMapReducePlan
Gets overall number of reducers for the job.
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.
refreshJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Refreshes collection of job siblings.
REGION_CACHE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
Property prefix used to specify region name to cache name mapping.
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.cloud.TcpDiscoveryCloudIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Registers new addresses.
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.s3.TcpDiscoveryS3IpFinder
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.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Registers new addresses.
registerClassName(byte, int, String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Method to register typeId->class name mapping in marshaller context cluster-wide.
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.
registered(SchedulerDriver, Protos.FrameworkID, Protos.MasterInfo) - Method in class org.apache.ignite.mesos.IgniteScheduler
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.
registerMBean(String, T, Class<T>) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Registers SPI MBean.
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.
release() - Static method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
Releases all session from pool and closes all their connections to Cassandra database.
release() - Method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionWrapper
Closes wrapped Cassandra driver session
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.
remoteDaemonNodes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a collection of all remote daemon nodes in topology.
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.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mapping from cache.
remove(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mapping from cache if one exists and value is equal to the passed in value.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(K) - Method in interface org.apache.ignite.IgniteCache
remove(K, V) - Method in interface org.apache.ignite.IgniteCache
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() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called during database transaction execution to clear entire cache region after Hibernate executed database update, but before transaction completed.
removeAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mappings from cache.
removeAll() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes mappings from cache.
removeAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
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(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mappings from cache for entries.
removeAllAsync() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
removeAllConflict(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes DR data.
removeAllConflictAsync(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes DR data asynchronously.
removeAppender(FileAppender) - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
Removes file appender.
removeAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mapping from cache.
removeAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mapping from cache if one exists and value is equal to the passed in 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.s3.S3CheckpointSpi
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.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.
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.
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.
removeSelectionListener(VisorSelectionListener<UUID>) - Method in interface org.apache.ignite.visor.plugin.VisorPluginNodesPanel
Remove selection listener.
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
 
removeTopologyListener(VisorTopologyListener) - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Uninstall topology listener.
rename(IgfsPath, IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Renames/moves a file.
rename(Path, Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
rename(IgfsPath, IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Renames/moves a file.
rename(IgfsPath, IgfsPath) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Renames/moves a file.
rename(IgfsPath, IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Renames/moves a file.
renameInternal(Path, Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
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(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if only if there is a previous mapping for it.
replace(Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if only if the previous value is equal to the 'oldVal' passed in.
replace(K, V, V) - Method in interface org.apache.ignite.IgniteCache
replace(K, V) - Method in interface org.apache.ignite.IgniteCache
replaceAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if only if there is a previous mapping for it.
replaceAsync(Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if only if the previous value is equal to the 'oldVal' passed in.
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.
RepositoryConfig - Annotation Type in org.apache.ignite.springdata.repository.config
The annotation can be used to pass Ignite specific parameters to a bound repository.
reregistered(SchedulerDriver, Protos.MasterInfo) - Method in class org.apache.ignite.mesos.IgniteScheduler
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.
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.IgniteFileSystem
Resets metrics for this file system.
resetMetrics() - Method in interface org.apache.ignite.IgniteTransactions
Resets transaction metrics.
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.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.
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.
resolveRecords(IgniteFileSystem, IgfsInputStream, IgfsFileRange) - Method in interface org.apache.ignite.igfs.mapreduce.IgfsRecordResolver
Adjusts record start offset and length.
resolveRecords(IgniteFileSystem, IgfsInputStream, IgfsFileRange) - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
Adjusts record start offset and length.
resolveRecords(IgniteFileSystem, IgfsInputStream, IgfsFileRange) - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
Adjusts record start offset and length.
ResourceHandler - Class in org.apache.ignite.mesos.resource
HTTP controller which provides on slave resources.
ResourceHandler(String, String, String) - Constructor for class org.apache.ignite.mesos.resource.ResourceHandler
 
resourceOffers(SchedulerDriver, List<Protos.Offer>) - Method in class org.apache.ignite.mesos.IgniteScheduler
ResourceProvider - Class in org.apache.ignite.mesos.resource
Provides path to user's libs and config file.
ResourceProvider() - Constructor for class org.apache.ignite.mesos.resource.ResourceProvider
 
resourceUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
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.
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.
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
 
revisionHash() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision hash.
revisionTimestamp() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision timestamp.
RocketMQStreamer<K,V> - Class in org.apache.ignite.stream.rocketmq
Streamer that subscribes to a RocketMQ topic amd feeds messages into IgniteDataStreamer instance.
RocketMQStreamer() - Constructor for class org.apache.ignite.stream.rocketmq.RocketMQStreamer
 
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.transactions.TransactionMetrics
Gets last time transaction was rollback.
ROOT - Static variable in class org.apache.ignite.igfs.IgfsPath
Root path.
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.
row() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read results set row.
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
run() - Method in class org.apache.ignite.yarn.ApplicationMaster
Runs application master.
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

S3CheckpointSpi - Class in org.apache.ignite.spi.checkpoint.s3
This class defines Amazon S3-based implementation for checkpoint SPI.
S3CheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
 
S3CheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.s3
Management bean for S3CheckpointSpi.
safeSnapshot() - Static method in class org.apache.ignite.IgniteSystemProperties
Does the same as IgniteSystemProperties.snapshot() but filters out possible sensitive user data.
save(ID, S) - Method in interface org.apache.ignite.springdata.repository.IgniteRepository
Saves a given entity using provided key.
save(Map<ID, S>) - Method in interface org.apache.ignite.springdata.repository.IgniteRepository
Saves all given keys and entities combinations.
save(ID, S) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
Saves a given entity using provided key.
save(Map<ID, S>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
Saves all given keys and entities combinations.
save(S) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
save(Iterable<S>) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryImpl
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.s3.S3CheckpointSpi
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.
scanIterator(boolean, IgniteBiPredicate) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
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.
secondarySpaceSize() - Method in interface org.apache.ignite.igfs.IgfsMetrics
Get used space in bytes used in the secondary file system.
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.
seek(long) - Method in class org.apache.ignite.igfs.IgfsInputStream
Seek to the specified position.
seek(long) - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Seek to the specified position.
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.
selected() - Method in interface org.apache.ignite.visor.plugin.VisorPluginNodesPanel
Get selected elements.
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.
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.tcp.TcpDiscoverySpi
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.
serialize(Object) - Method in class org.apache.ignite.cache.store.cassandra.serializer.JavaSerializer
Serializes object into byte buffer.
serialize(Object) - Method in class org.apache.ignite.cache.store.cassandra.serializer.KryoSerializer
Serializes object into byte buffer.
serialize(Object) - Method in interface org.apache.ignite.cache.store.cassandra.serializer.Serializer
Serializes object into byte buffer.
serialize(String, CacheEvent) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventSerializer
Serializer - Interface in org.apache.ignite.cache.store.cassandra.serializer
Interface which should be implemented by all serializers responsible for writing/loading data to/from Cassandra in binary (BLOB) format.
service(String) - Method in interface org.apache.ignite.IgniteServices
Gets locally deployed service with specified name.
Service - Interface in org.apache.ignite.services
An instance of grid-managed service.
serviceClass() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service class.
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.
ServiceDescriptor - Interface in org.apache.ignite.services
Service deployment descriptor.
serviceDescriptors() - Method in interface org.apache.ignite.IgniteServices
Gets metadata about all deployed services in the grid.
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>, boolean) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service.
serviceProxy(String, Class<? super T>, boolean, long) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service with 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.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(String) - Method in interface org.apache.ignite.IgniteServices
Gets all locally deployed services with specified name.
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.
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(IgniteLogger) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Creates Cassandra session wrapper if it wasn't created yet and returns it
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.cassandra.CassandraCacheStore
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.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.
SessionPool - Class in org.apache.ignite.cache.store.cassandra.session.pool
Cassandra driver sessions pool.
SessionPool() - Constructor for class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
 
SessionWrapper - Class in org.apache.ignite.cache.store.cassandra.session.pool
Wrapper for Cassandra driver session, responsible for monitoring session expiration and its closing.
SessionWrapper(Session, long) - Constructor for class org.apache.ignite.cache.store.cassandra.session.pool.SessionWrapper
Creates instance of Cassandra driver session wrapper.
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, 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.
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.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Specifies the path to the service token file.
setAckSendThreshold(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets number of received messages per connection to node after which acknowledgment message is sent.
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
Sets flag indicating whether the cluster will be active on start.
setAddr(InetAddress) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets server address.
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.
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.communication.tcp.TcpCommunicationSpi
Sets address resolver.
setAddressResolver(AddressResolver) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets address resolver.
setAddressTranslator(AddressTranslator) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets address translator.
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
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.
setAllowDuplicateRegistrations(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setAllowOverwrite(boolean) - Method in class org.apache.ignite.sink.flink.IgniteSink
Enables overwriting existing values in cache.
setAllowOverwrite(boolean) - Method in class org.apache.ignite.stream.storm.StormStreamer
Enables overwriting existing values in cache.
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.PersistentStoreConfiguration
 
setApiParams(Map<String, String>) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Sets API Params.
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.IgniteSpringBean
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.springdata.repository.support.IgniteRepositoryFactoryBean
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
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
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.
setAtomicConfiguration(AtomicConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
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.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.
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.
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.tcp.TcpDiscoverySpi
Sets discovery SPI node authenticator.
setAuthProvider(AuthProvider) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets authentication provider.
setAutoFlushFrequency(long) - Method in class org.apache.ignite.sink.flink.IgniteSink
Specifies data flush frequency into the grid.
setAutoFlushFrequency(long) - Method in class org.apache.ignite.stream.storm.StormStreamer
Specifies data flush frequency into the grid.
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets automatic unsubscribe flag.
setAwsCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets AWS credentials.
setAwsCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets AWS credentials.
setAwsCredentialsProvider(AWSCredentialsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets AWS credentials provider.
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.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
 
setBasePath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setBatchClosureMillis(long) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
When using batched consumption, sets the time in milliseconds that will elapse before a batch is committed.
setBatchClosureSize(int) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
When using batched consumption, sets the amount of messages that will be received before a batch is committed.
setBatched(boolean) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Batch consumption leverages JMS Transactions to minimise round trips to the broker.
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.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.IgniteConfiguration
Sets configuration for Ignite Binary objects.
setBinaryConfiguration(PlatformDotNetBinaryConfiguration) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
setBlockSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets file's data block size.
setBlockUntilConnected(boolean) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets whether to block the start() method until connected for the first time.
setBrokerUrl(String) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the broker URL (compulsory).
setBucketName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets Google Cloud Storage bucket name.
setBucketName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets bucket name for IP finder.
setBucketNameSuffix(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets bucket name suffix.
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.
setBufferCapacity(Integer) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Sets Buffer capacity.
setBufferSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets read/write buffers size for IGFS stream operations (bytes).
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
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.
setCacheName(String) - Method in class org.apache.ignite.stream.storm.StormStreamer
Sets the cache name.
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
setCamelContext(CamelContext) - Method in class org.apache.ignite.stream.camel.CamelStreamer
Explicitly sets the CamelContext to use.
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.
setCheckpointingFrequency(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
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
Sets amount of memory allocated for the checkpointing temporary buffer.
setCheckpointingThreads(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
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.s3.S3CheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets the checkpoint listener.
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.
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.
setClientConfiguration(ClientConfiguration) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets Amazon client configuration.
setClientConfiguration(ClientConfiguration) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets Amazon client configuration.
setClientFailureDetectionTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure detection timeout to use in TcpDiscoverySpi and TcpCommunicationSpi.
setClientId(String) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Sets the client ID of the JMS Connection.
setClientId(String) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the MQTT client ID (optional).
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 static flag.
setClientReconnectDisabled(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets client reconnect disabled flag.
setClusterProps(ClusterProperties) - Method in class org.apache.ignite.mesos.IgniteScheduler
 
setCollectMetrix(boolean) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Enables metrics collection.
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
 
setColocateMetadata(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set metadata co-location flag.
setCommunicationSpi(CommunicationSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CommunicationSpi.
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
 
setCompression(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets compression algorithm to use for the transport.
setConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Sets the number of concurrent segments in Ignite internal page mapping tables.
setConfigPaths(String...) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Set paths to additional file system configuration files (e.g. core-site.xml).
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets configuration bean.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Sets Ignite configuration.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets configuration bean.
setConfigurationPath(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets configuration file path.
setConfigurationPath(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets configuration file path.
setConnectionFactory(ConnectionFactory) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Sets the JMS ConnectionFactory.
setConnectionsPerNode(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets number of connections to each remote node. if TcpCommunicationSpi.isUsePairedConnections() is true then number of connections is doubled and half is used for incoming and half for outgoing messages.
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.
setConnectOptions(MqttConnectOptions) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the MQTT client connect options, where users can configured the last will and testament, durability, etc.
setConnectorConfiguration(ConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setConnectTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets connect timeout used when establishing connection with remote nodes.
setConsistentId(Serializable) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets consistent globally unique node ID which survives node restarts.
setConsumerConfig(ConsumerConfig) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
Sets the consumer config.
setConsumerGrp(String) - Method in class org.apache.ignite.stream.rocketmq.RocketMQStreamer
Sets the name of the consumer group.
setContactPoints(String...) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets list of contact points to connect to Cassandra cluster.
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.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.
setCredential(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets credential that is used during authentication on the cloud.
setCredentialPath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets the path to a credential that is used during authentication on the cloud.
setCredentials(Credentials) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets credentials to use for authentication.
setCurator(CuratorFramework) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
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.
setDaemon(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets daemon flag.
setDaemon(boolean) - Static method in class org.apache.ignite.Ignition
Sets daemon flag.
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.
setDataCacheConfiguration(CacheConfiguration) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Cache config to store IGFS data.
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.tcp.TcpDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets data source.
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.cache.store.spring.CacheSpringStoreSessionListener
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.cassandra.CassandraCacheStoreFactory
Sets data source bean name.
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.
setDataStreamerThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set thread pool size that will be used to process data stream messages.
setDefaultAllowAll(boolean) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set default allow all.
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.configuration.CacheConfiguration
Sets default lock timeout in milliseconds.
setDefaultMemoryPolicyName(String) - Method in class org.apache.ignite.configuration.MemoryConfiguration
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
Overrides size of default memory policy which is created automatically.
setDefaultMode(IgfsMode) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets IGFS mode to specify how it should interact with secondary Hadoop file system, like HDFS.
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.
setDefaultSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultTxConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction concurrency.
setDefaultTxIsolation(TransactionIsolation) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction isolation.
setDefaultTxTimeout(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction timeout in milliseconds.
setDefaultUserName(String) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Sets default user name.
setDefaultUserName(String) - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Set default user name (optional).
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.
setDestination(Destination) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Sets the JMS Destination explicitly.
setDestinationName(String) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Sets the name of the JMS destination to consume from.
setDestinationType(Class<? extends Destination>) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Sets the type of the destination to create, when used in combination with JmsStreamer.setDestinationName(String).
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.
setDirectBuffer(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets flag to allocate direct or heap buffer in SPI.
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.
setDirectSendBuffer(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets whether to use direct buffer for sending.
setDisconnectForcibly(boolean) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets whether to disconnect forcibly or not when shutting down.
setDisconnectForciblyTimeout(Integer) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the timeout if disconnecting forcibly.
setDisconnectQuiesceTimeout(Integer) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the quiesce timeout on disconnection.
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
Sets time in milliseconds after which a certain metric value is considered expired.
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
Specify if distributed joins are enabled for this query.
setDurableSubscription(boolean) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
A true value is only accepted in combination with topic consumption.
setDurableSubscriptionName(String) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
When using Durable Subscribers, sets the name of the durable subscriber.
setDynamicCacheConfiguration(CacheConfiguration<Object, Object>) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets dynamic cache configuration template.
setDynamicNearCacheConfiguration(NearCacheConfiguration<Object, Object>) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets dynamic cache configuration template.
setEagerTtl(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eager ttl flag.
setEmptyPagesPoolSize(int) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
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.
setEndpointAddress(String) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Set ODBC endpoint address.
setEndpointUri(String) - Method in class org.apache.ignite.stream.camel.CamelStreamer
Sets the endpoint URI from which to consume.
setEndpointUrl(String) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Sets Endpoint URL.
setEnforceJoinOrder(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets flag to enforce join order of tables in the query.
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.
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
Sets cache eviction policy.
setEvictionThreshold(double) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
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).
setExcludePaths(Collection<String>) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Sets collection of regex for paths whose blocks must not be evicted.
setExcludePaths(Collection<String>) - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Sets collection of regex for paths whose blocks must not be evicted.
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.
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class org.apache.ignite.configuration.CacheConfiguration
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.
setFetchSize(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets number of rows to immediately fetch in CQL statement execution.
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.
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JDailyRollingFileAppender
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JExternallyRolledFileAppender
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JFileAppender
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
setFileIOFactory(FileIOFactory) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
setFileSystemConfiguration(FileSystemConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets IGFS (Ignite In-Memory File System) configurations.
setFileSystemFactory(HadoopFileSystemFactory) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Sets secondary file system factory.
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.
setFinishedJobInfoTtl(long) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets finished job info time-to-live.
setForceServerMode(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets force server mode flag.
setFragmentizerConcurrentFiles(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets number of files to process concurrently by fragmentizer.
setFragmentizerEnabled(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets property indicating whether fragmentizer is enabled.
setFragmentizerThrottlingBlockLength(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets length of file chunk to transmit before throttling is delayed.
setFragmentizerThrottlingDelay(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets delay in milliseconds for which fragmentizer is paused.
setFs(FileSystem) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets file system.
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.cache.spring.SpringCacheManager
setGridName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setGridName(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
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
 
setGroupSize(int) - Method in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
Set group size.
setHadoopConfiguration(HadoopConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets hadoop configuration.
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.
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
Set host.
setHost(String) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Sets the host endpoint is bound to.
setIdentity(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets the identity that is used as a user name during a connection to the cloud.
setIdleConnectionTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets maximum idle connection timeout upon which a connection to client will be closed.
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.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
 
setIgfsThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set thread pool size that will be used to process outgoing IGFS messages.
setIgnite(Ignite) - Method in class org.apache.ignite.stream.StreamAdapter
 
setIgniteConfigFile(String) - Method in class org.apache.ignite.stream.storm.StormStreamer
Specifies Ignite configuration file.
setIgniteHome(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite installation folder.
setIgniteInstance(IgniteEx) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
 
setIgniteInstanceName(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets Ignite instance name.
setIgniteInstanceName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets of local instance name.
setIgniteInstanceName(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets Ignite instance name.
setIgniteTupleField(String) - Method in class org.apache.ignite.stream.storm.StormStreamer
Names Ignite tuple field, by which tuple data is obtained in topology.
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.ContinuousQuery
Sets the flag value defining whether to notify about EventType.EXPIRED events.
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.ContinuousQuery
Sets initial query.
setInitialSize(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Sets initial memory region size defined by this memory policy.
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 inline size.
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.
setInstance(String) - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Set Kerberos instance (optional).
setInterceptor(CacheInterceptor<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache interceptor.
setInvalidate(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets invalidation flag for near cache entries in this transaction.
setIpcEndpointConfiguration(IgfsIpcEndpointConfiguration) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets IPC endpoint configuration.
setIpcEndpointEnabled(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set IPC endpoint enabled flag.
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
 
setJettyPath(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets path, either absolute or relative to IGNITE_HOME, to JETTY XML configuration file.
setJmxReporting(boolean) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Enables JMX reporting of the metrics.
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.
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.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.
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.ssl.SslContextFactory
Sets key store password.
setKeyStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key store type used in context initialization.
setKeyTab(String) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
Sets the key tab file name.
setKeyTabPrincipal(String) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
Set the key tab principal name.
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.
setLateAffinityAssignment(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Starting from Ignite 2.1 late affinity assignment is always enabled.
setLevel(Level) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Sets level for internal log4j implementation.
setLevel(Level) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Sets level for internal log4j implementation.
setLifecycleBeans(LifecycleBean...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets a collection of lifecycle beans.
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
Set communication listener.
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
Sets a listener for discovery events.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets a listener for discovery events.
setLoadBalancingPolicy(LoadBalancingPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets load balancing policy.
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 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
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.communication.tcp.TcpCommunicationSpi
Sets local host address for socket binding.
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 local host IP address that discovery SPI uses.
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 local callback.
setLocalMapperWeight(int) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Set local mapper weight.
setLocalPort(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets local port for socket binding.
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.communication.tcp.TcpCommunicationSpi
Sets local port range for local host ports (value must greater than or equal to 0).
setLocalPortRange(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Range for local ports.
setLocalReducerWeight(int) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Set local reducer weight.
setLocksCount(int) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
 
setLockWaitTime(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Time out in milliseconds to wait when acquiring persistence store lock file before failing the local node.
setLogin(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets login.
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets timeout in milliseconds after which long query warning will be printed.
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
setManagementPort(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets management endpoint port.
setManagementThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets management thread pool size to use within grid.
setMappers(UserNameMapper...) - Method in class org.apache.ignite.hadoop.util.ChainedUserNameMapper
Set child mappers.
setMappings(Map<String, String>) - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Set mappings.
setMapReducePlanner(HadoopMapReducePlanner) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets Hadoop map-reduce planner, a component which defines job execution plan based on job configuration and current grid topology.
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.
setMasterUrl(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Sets the host name of the Kubernetes API server.
setMaxAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets maximum timeout for receiving acknowledgement for sent message.
setMaxBlocks(int) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Sets maximum allowed amount of blocks.
setMaxBlocks(int) - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Sets maximum allowed amount of blocks.
setMaxConcurrentAsyncOperations(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of concurrent asynchronous operations.
setMaxConnectTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets maximum connect timeout.
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.
setMaximumTaskRangeLength(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set maximum default range size of a file being split during IGFS task execution.
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.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.SqlConnectorConfiguration
Sets maximum number of opened cursors per connection.
setMaxParallelTasks(int) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets max number of local tasks that may be executed in parallel.
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.
setMaxPoolSize(int) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Set Maximum workers thread count.
setMaxQueryIteratorsCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of query iterators that can be stored.
setMaxSchemaAgreementWaitSeconds(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets maximum time to wait for schema agreement before returning from a DDL query.
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.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(long) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
Sets maximum allowed size of data in all blocks in bytes.
setMaxSize(long) - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
Sets maximum allowed size of data in all blocks in bytes.
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.MemoryPolicyConfiguration
Sets maximum memory region size defined by this memory policy.
setMaxTaskQueueSize(int) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets max task queue size.
setMBeanServer(MBeanServer) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets initialized and started MBean server.
setMemoryConfiguration(MemoryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets page memory configuration.
setMemoryPolicies(MemoryPolicyConfiguration...) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Sets memory policies configurations.
setMemoryPolicyName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets a name of MemoryPolicyConfiguration for this cache.
setMemorySize(int) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Sets shared memory size in bytes allocated for endpoint communication.
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.
setMessageQueueLimit(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets message queue limit for incoming and outgoing messages.
setMetaCacheConfiguration(CacheConfiguration) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Cache config to store IGFS meta information.
setMethodClass(Class<?>) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets method class.
setMethodName(String) - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Sets method name.
setMethodName(String) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets method name.
setMethodParameters(Object...) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets method parameters.
setMethodParameterTypes(Class<?>...) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets method parameter types.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Sets memory metrics enabled flag.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
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.tcp.TcpDiscoverySpi
Sets discovery metrics provider.
setMetricsUpdateFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite metrics update frequency in milliseconds.
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
 
setName(String) - Method in class org.apache.ignite.cache.QueryIndex
Sets index name.
setName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache name.
setName(String) - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Set thread pool name.
setName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets IGFS instance name.
setName(String) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
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.s3.S3CheckpointSpi
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.communication.tcp.TcpCommunicationSpi
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.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Sets the namespace the Kubernetes service belongs to.
setNameSrvAddr(String) - Method in class org.apache.ignite.stream.rocketmq.RocketMQStreamer
Sets the name server address.
setNativeLibraryNames(String...) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Set native library names.
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
Sets near eviction policy.
setNearStartSize(int) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Start size for near cache.
setNettyOptions(NettyOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets netty options to use.
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.
setNmClient(NMClient) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets NMClient.
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.tcp.TcpDiscoverySpi
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
setNodeId(UUID) - Method in class org.apache.ignite.logger.java.JavaLogger
Sets node ID.
setNodeId(UUID) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Sets node ID.
setNodeId(UUID) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Sets node ID.
setNodeId(UUID) - Method in interface org.apache.ignite.logger.LoggerNodeIdAware
Sets node ID.
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.
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
setOffHeapMaxMemory(long) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Configures on-heap cache for the off-heap based page memory.
setOwner(Path, String, String) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
setOwner(Path, String, String) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
setPageEvictionMode(DataPageEvictionMode) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Sets memory pages eviction 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.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
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.MemoryConfiguration
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.ScanQuery
Sets partition number over which this query should iterate.
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
Sets partitions for a query.
setPassword(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets password to use for authentication.
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(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.
setPathModes(Map<String, IgfsMode>) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets map of path prefixes to IGFS modes used for them.
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.
setPermission(Path, FsPermission) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
setPermission(Path, FsPermission) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
setPerNodeBatchSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets number of file blocks collected on local node before sending batch to remote node.
setPerNodeParallelBatchCount(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets number of file block batches that can be concurrently sent to remote node.
setPersistence(MqttClientPersistence) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the persistence mechanism.
setPersistenceSettings(KeyValuePersistenceSettings) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets persistence settings.
setPersistenceSettingsBean(String) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets persistence settings bean name.
setPersistentStoreConfiguration(PersistentStoreConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets persistence configuration activating Apache Ignite Persistent Store.
setPersistentStorePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
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
Sets cleanup delay for pessimistic transaction recovery log for failed node, in milliseconds.
setPessimisticTxLogSize(int) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets pessimistic transactions log size.
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
Sets plugin configurations.
setPoolingOptions(PoolingOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets pooling options.
setPort(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets port to use for Cassandra connection.
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
Set port.
setPort(int) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Sets the port endpoint is bound to.
setPort(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets port number.
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
Set port range.
setPreferLocalReducerThresholdWeight(int) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Set reducer migration threshold weight.
setPrefetchBlocks(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets the number of pre-fetched blocks if specific file's chunk is requested.
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.
setProjectName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets Google Cloud Platforms project name.
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.SslContextFactory
Sets protocol for secure transport.
setProtocolVersion(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets the native protocol version to use.
setProvider(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets the cloud provider to use.
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.
setQualitiesOfService(List<Integer>) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the qualities of service to use for multiple topic subscriptions.
setQualityOfService(Integer) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the quality of service to use for a single topic subscription (optional).
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.
setQueryEntities(Collection<QueryEntity>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets query entities configuration.
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
Sets time interval for MemoryMetrics.getAllocationRate() and MemoryMetrics.getEvictionRate() monitoring purposes.
setRateTimeInterval(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Sets the length of the time interval for rate-based metrics.
setReadConsistency(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Set consistency level for READ operations.
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
setRealm(String) - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Set Kerberos realm (optional).
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and provide one new to each next demand request.
setRebalanceBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets rebalance batch size.
setRebalanceDelay(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets rebalance delay (see CacheConfiguration.getRebalanceDelay() for more information).
setRebalanceMode(CacheRebalanceMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache rebalance mode.
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.configuration.CacheConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
setRebalanceTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets rebalance timeout (ms).
setReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server receive buffer size.
setReconnectCount(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets maximum number of reconnect attempts used when establishing connection with remote nodes.
setReconnectCount(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Number of times node tries to (re)establish connection to another node.
setReconnectionPolicy(ReconnectionPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets reconnection policy.
setRegions(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets list of regions where VMs are located.
setRelaxedConsistency(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set relaxed consistency flag.
setReloginInterval(long) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
Sets the relogin interval in milliseconds.
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.ContinuousQuery
Sets optional key-value filter factory.
setRemoteMapperWeight(int) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Set remote mapper weight.
setRemoteReducerWeight(int) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
Set remote reducer weight.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Specify if the query contains only replicated tables.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Specify if the query contains only replicated tables.
setReplication(Path, short) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
setResponseProcessor(Processor) - Method in class org.apache.ignite.stream.camel.CamelStreamer
Sets the Processor used to generate the response.
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.
setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets retry policy.
setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setRetryStopStrategy(StopStrategy) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the strategy to determine when to stop retrying to (re-)connect.
setRetryTimeout(long) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
Sets the retry timeout.
setRetryWaitStrategy(WaitStrategy) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the strategy to determine how long to wait between retry attempts.
setRmClient(AMRMClientAsync<AMRMClient.ContainerRequest>) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets RMClient
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.
setSchedulerTimeout(long) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets scheduler timeout.
setSchema(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Set schema for the query.
setSecondaryFileSystem(IgfsSecondaryFileSystem) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets the secondary file system.
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.ConnectorConfiguration
Sets number of selector threads for REST TCP server.
setSelectorsCount(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets the count of selectors te be used in TCP server.
setSelectorSpins(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Defines how many non-blocking selector.selectNow() should be made before falling into selector.select(long) in NIO server.
setSendBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server send buffer size.
setSendQueueLimit(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server send queue limit.
setSequentialReadsBeforePrefetch(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets amount of sequential block reads before prefetch is triggered.
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
 
setService(Service) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service instance.
setServiceAccountId(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets the service account ID (typically an e-mail address).
setServiceAccountP12FilePath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets a full path to the private key in PKCS12 format of the Service Account.
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.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Sets the name of Kubernetes service for Ignite pods' IP addresses lookup.
setServiceName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
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.
setSessionExpirationTimeout(long) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets expiration timeout for Cassandra driver session.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets shared flag.
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.s3.TcpDiscoveryS3IpFinder
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.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Sets shared flag.
setSharedMemoryPort(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets local port to accept shared memory connections.
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.
setSkipStore(boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
setSlowClientQueueLimit(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets slow client queue limit.
setSocketOptions(SocketOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets socket options to use.
setSocketReceiveBuffer(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets receive buffer size for sockets created or accepted by this SPI.
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
Sets socket receive buffer size.
setSocketSendBuffer(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets send buffer size for sockets created or accepted by this SPI.
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
Sets socket send buffer size.
setSocketTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets socket operations timeout.
setSocketWriteTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets socket write timeout for TCP connection.
setSpeculativeExecutionPolicy(SpeculativeExecutionPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets speculative execution policy.
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
Sets SQL clause.
setSqlConnectorConfiguration(SqlConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets SQL connector configuration.
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.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.configuration.CacheConfiguration
Sets maximum inline size for sql indexes.
setSqlSchema(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets sql schema to be used for current cache.
setSslClientAuth(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets flag indicating whether or not SSL client authentication is required.
setSslContextFactory(GridSslContextFactory) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
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.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.
setSslOptions(SSLOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets SSL options.
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.configuration.CacheConfiguration
setStatisticsPrintFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets statistics print frequency.
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.
setStopped(boolean) - Static method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
Used by unit test to avoid restart node and valid state of the stopped flag.
setStopped(boolean) - Static method in class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
Used by unit test to avoid restart node and valid state of the stopped flag.
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
Sets a number of sub-intervals the whole MemoryPolicyConfiguration.setRateTimeInterval(long) will be split into to calculate MemoryMetrics.getAllocationRate() and MemoryMetrics.getEvictionRate() rates (5 by default).
setSubIntervals(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Sets the number of sub-intervals to split the PersistentStoreConfiguration.getRateTimeInterval() into to track the update history.
setSwapFilePath(String) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Sets a path to the memory-mapped file.
setSystemCacheInitialSize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Sets initial size of a memory region reserved for system cache.
setSystemCacheMaxSize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Sets maximum memory region size reserved for system cache.
setSystemPermissions(Collection<SecurityPermission>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set collection system permission.
setSystemThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets system thread pool size to use within grid.
setTableName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets table name for this query entity.
setTarget(Object) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets target object for method execution.
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.SqlConnectorConfiguration
Set TCP NO_DELAY flag.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets value for TCP_NODELAY socket option.
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.
setThreadCount(int) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Set number of threads used by this endpoint to process incoming requests.
setThreadCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets thread count for warmup.
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
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.jms11.JmsStreamer
Sets the number of threads to concurrently consume JMS messages.
setThreads(int) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
Sets the threads.
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.
setThreadsCount(int) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Sets Threads count.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQuery
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
Sets the query execution timeout.
setTimes(IgfsPath, long, long) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Set times for the given path.
setTimes(Path, long, long) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
setTimes(Path, long, long) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
setTimes(IgfsPath, long, long) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Set times for the given path.
setTimes(IgfsPath, long, long) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Set times for the given path.
setTimes(IgfsPath, long, long) - Method in interface org.apache.ignite.IgniteFileSystem
Sets last access time and last modification time for a given path.
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
 
setTokenDirectoryPath(String) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Sets directory where shared memory tokens are stored.
setTopHistorySize(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets size of topology snapshots history.
setTopic(String) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
Sets the topic name.
setTopic(String) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the topic to subscribe to, if a single topic.
setTopic(String) - Method in class org.apache.ignite.stream.rocketmq.RocketMQStreamer
Sets the topic to subscribe to.
setTopics(List<String>) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Sets the topics to subscribe to, if many.
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.
setTransacted(boolean) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Instructs the streamer whether to use local JMS transactions or not.
setTransactionConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets transaction concurrency level.
setTransactionConfiguration(TransactionConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets transactions configuration.
setTransactionManager(PlatformTransactionManager) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Sets transaction manager.
setTransactionManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
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.
setTransformer(MessageTransformer<T, K, V>) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Compulsory.
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.
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
setTxSerializableEnabled(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
This method has no effect, TransactionIsolation.SERIALIZABLE isolation is always enabled.
setType(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Sets type for query.
setType(Class<?>) - Method in class org.apache.ignite.cache.query.SqlQuery
 
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.
setType(IgfsIpcEndpointType) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Sets endpoint type.
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
 
setUnacknowledgedMessagesBufferSize(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets maximum number of stored unacknowledged messages per connection to node.
setUpdateFileLengthOnFlush(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set whether to update file length on flush.
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.
setupFile(Path, FileSystem, LocalResourceType) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
setUri(String) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Sets file system URI.
setUriList(List<String>) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets list of URI which point to GAR file and which should be scanned by SPI for the new tasks.
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.
setUseDefaultUserName(boolean) - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
Set whether to use default user name when there is no mapping for current user name.
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.
setUsePairedConnections(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Set this to true if TcpCommunicationSpi should maintain connection for outgoing and incoming messages separately.
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.cassandra.datasource.DataSource
Sets user name to use for authentication.
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, ?>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets user attributes for this node.
setUserNameMapper(UserNameMapper) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
Set optional user name mapper.
setUserObject(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets user-specific object.
setUseSSL(boolean) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Enables SSL for communications with Cassandra.
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.
setValue(Object, Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Assigns value for the object field.
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.
setValueFromRow(Row, Object, Serializer) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Sets object field value from a Row returned by Cassandra CQL statement.
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.
setVerifyChecksum(boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
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.PersistentStoreConfiguration
Sets a path for the WAL archive directory.
setWalAutoArchiveAfterInactivity(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Note: setting this value with WALMode.DEFAULT may generate file size overhead for WAL segments in case grid is used rarely.
setWalFlushFrequency(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
This property define how often WAL will be fsync-ed in BACKGROUND mode.
setWalFsyncDelayNanos(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
setWalHistorySize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Sets a total number of checkpoints to keep in the WAL history.
setWalMode(WALMode) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
setWalRecordIteratorBufferSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
 
setWalSegments(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Sets a number of WAL segments to work with.
setWalSegmentSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Sets size of a WAL segment.
setWalStorePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Sets a path to the directory where WAL is stored .
setWarmupClosure(IgniteInClosure<IgniteConfiguration>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets warmup closure to execute before grid startup.
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.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Set work directory.
setWorkDirectory(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Set work directory.
setWorkingDirectory(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
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.
setWriteConsistency(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Set consistency level for WRITE operations.
setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write synchronization mode.
setWriteThrough(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setZkConnectionString(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setZones(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets list of zones where VMs are located.
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.
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() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
shutdownNow() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
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
Stops service threads to simulate node failure.
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
SINGLE_TUPLE_EXTRACTOR_CLASS - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSinkConstants
Class to transform the entry before feeding into cache.
size() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Returns entry size in bytes.
size() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all entries cached on this node.
size(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
size(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached across all nodes.
size(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Determines size of the file denoted by provided path.
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
sizeAsync(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeAsync(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached across all nodes.
sizeLong() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all entries cached on this node as a long value.
sizeLong(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeLong(int, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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 class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeLongAsync(int, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
skipNonExistentFiles() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
Flag indicating whether to fail or simply skip non-existent files.
skipStore() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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.
SLASH - Static variable in class org.apache.ignite.igfs.IgfsPath
The directory separator.
slaveLost(SchedulerDriver, Protos.SlaveID) - Method in class org.apache.ignite.mesos.IgniteScheduler
sleep() - Method in class org.apache.ignite.cache.store.cassandra.common.RandomSleeper
Sleeps
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() - Static method in class org.apache.ignite.IgniteSystemProperties
Gets snapshot of system properties.
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.
SortedEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.sorted
MBean for sorted eviction policy.
SPACE - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
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
 
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.s3.S3CheckpointSpi
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.tcp.TcpDiscoverySpi
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.
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.s3.S3CheckpointSpi
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.tcp.TcpDiscoverySpi
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.
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.
SpringCacheManager - Class in org.apache.ignite.cache.spring
Implementation of Spring cache abstraction based on Ignite cache.
SpringCacheManager() - Constructor for class org.apache.ignite.cache.spring.SpringCacheManager
 
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.
SpringResource.DEFAULT() - Constructor for class org.apache.ignite.resources.SpringResource.DEFAULT
 
SpringTransactionManager - Class in org.apache.ignite.transactions.spring
Implementation of Spring transaction abstraction based on Ignite transaction.
SpringTransactionManager() - Constructor for class org.apache.ignite.transactions.spring.SpringTransactionManager
Constructs the transaction manager with no target Ignite instance.
sql() - Method in class org.apache.ignite.springdata.repository.query.IgniteQuery
Text string of the query.
SqlConnectorConfiguration - Class in org.apache.ignite.configuration
SQL connector configuration.
SqlConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.SqlConnectorConfiguration
Creates SQL connector configuration with all default values.
SqlConnectorConfiguration(SqlConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.SqlConnectorConfiguration
Creates SQL connector configuration by copying all properties from given configuration.
SqlFieldsQuery - Class in org.apache.ignite.cache.query
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.
SqlQuery<K,V> - Class in org.apache.ignite.cache.query
SQL Query.
SqlQuery(String, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Constructs query for the given type name and SQL query.
SqlQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Constructs query for the given type and SQL query.
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
 
SslContextFactory - Class in org.apache.ignite.ssl
This SSL context factory that provides ssl context configuration with specified key and trust stores.
SslContextFactory() - Constructor for class org.apache.ignite.ssl.SslContextFactory
 
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.
start(Properties) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
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() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.hadoop.util.ChainedUserNameMapper
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Starts grid component, called on grid start.
start() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
Start position in the file this block relates to.
start() - Method in class org.apache.ignite.igfs.mapreduce.IgfsFileRange
Gets range start position.
start() - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Starts grid component, called on grid start.
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(Handler, ClusterProperties) - Method in class org.apache.ignite.mesos.resource.JettyServer
Starts jetty server.
start(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
Method invoked by OSGi to start the bundle.
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() - Method in class org.apache.ignite.sink.flink.IgniteSink
Starts streamer.
start() - Method in class org.apache.ignite.stream.camel.CamelStreamer
Starts the streamer.
start() - Method in class org.apache.ignite.stream.flume.IgniteSink
Starts a grid and initializes an event transformer.
start() - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Starts streamer.
start(Map<String, String>) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkConnector
A sink lifecycle method.
start(Map<String, String>) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
Initializes grid client from configPath.
start(Map<String, String>) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
start(Map<String, String>) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
Filtering is done remotely.
start() - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
Starts streamer.
start() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Starts streamer.
start() - Method in class org.apache.ignite.stream.rocketmq.RocketMQStreamer
Starts streamer.
start() - Method in class org.apache.ignite.stream.socket.SocketStreamer
Starts streamer.
start() - Method in class org.apache.ignite.stream.storm.StormStreamer
Starts streamer.
start() - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Starts streamer.
start() - Method in class org.apache.ignite.stream.zeromq.IgniteZeroMqStreamer
Starts ZeroMQ streamer.
start() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
started() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Checks if IgniteSpiAdapter.onBeforeStart() has been called on this SPI instance.
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.
startOffset() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
Since range input stream represents a part of larger file stream, there is an offset at which this range input stream starts in original input stream.
startStopwatch() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Starts startup stopwatch.
startTime() - Method in interface org.apache.ignite.transactions.Transaction
Start time of this transaction.
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 interface org.apache.ignite.transactions.Transaction
Gets current transaction state value.
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.
statusUpdate(SchedulerDriver, Protos.TaskStatus) - Method in class org.apache.ignite.mesos.IgniteScheduler
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 class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.hadoop.util.ChainedUserNameMapper
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Stops grid component, called on grid shutdown.
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.mesos.resource.JettyServer
Stops server.
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(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
Stops Ignite when the bundle is stopping.
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.sink.flink.IgniteSink
Stops streamer.
stop() - Method in class org.apache.ignite.stream.camel.CamelStreamer
Stops the streamer.
stop() - Method in class org.apache.ignite.stream.flume.IgniteSink
Stops the grid.
stop() - Method in class org.apache.ignite.stream.jms11.JmsStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkConnector
stop() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
Stops the grid client.
stop() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
stop() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
Stops the grid client.
stop() - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.stream.rocketmq.RocketMQStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.stream.socket.SocketStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.stream.storm.StormStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Stops streamer.
stop() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
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.
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.
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.
stopRemoteListen() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
Stops the remote listener.
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.
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.
StormStreamer<K,V> - Class in org.apache.ignite.stream.storm
Apache Storm streamer implemented as a Storm bolt.
StormStreamer() - Constructor for class org.apache.ignite.stream.storm.StormStreamer
 
StormStreamer.StreamerContext - Class in org.apache.ignite.stream.storm
Streamer context initializing grid and data streamer instances on demand.
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
 
StripedExecutorMXBean - Interface in org.apache.ignite.mxbean
MBean that provides access to information about striped executor service.
subIntervals(int) - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Sets a number of sub-intervals the whole MemoryMetricsMXBean.rateTimeInterval(long) will be split into to calculate MemoryMetricsMXBean.getAllocationRate() and MemoryMetricsMXBean.getEvictionRate() rates (5 by default).
subIntervals(int) - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Sets a number of sub-intervals the whole PersistenceMetricsMXBean.rateTimeInterval(long) will be split into to calculate rate-based metrics.
subjectId() - Method in class org.apache.ignite.events.CacheEvent
Gets security subject ID initiated this cache event, if available.
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.TaskEvent
Gets security subject ID initiated this task event, if available.
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.
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
suffix(String) - Method in class org.apache.ignite.igfs.IgfsPath
Adds a suffix to the final name in the path.
summary(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
Gets summary (total number of files, total number of directories and total length) for a given path.
supportsSymlinks() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
swap() - Method in class org.apache.ignite.lang.IgniteBiTuple
Swaps values.
sweepContainer(String) - Method in class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
Sweeps the OSGi container to find the first Bundle that can load the class.
SYM_CR - Static variable in class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
CR symbol.
SYM_LF - Static variable in class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
LF symbol.
SystemHelper - Class in org.apache.ignite.cache.store.cassandra.common
Helper class providing system information about the host (ip, hostname, os and etc.)
SystemHelper() - Constructor for class org.apache.ignite.cache.store.cassandra.common.SystemHelper
 
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).

T

tableExistenceRequired() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Indicates if Cassandra tables existence is required for this batch operation.
tableExistenceRequired() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Indicates if Cassandra table existence is required for an operation.
tableExistenceRequired() - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Indicates if Cassandra tables existence is required for this batch operation.
tableExistenceRequired() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Indicates if Cassandra tables existence is required for this operation.
tableExistenceRequired() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Indicates if Cassandra tables existence is required for this operation.
tableExistenceRequired() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Indicates if Cassandra tables existence is required for this operation.
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
take() - Method in interface org.apache.ignite.IgniteQueue
taskClass() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkConnector
Obtains a sink task class to be instantiated for feeding data into grid.
taskClass() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
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.
taskConfigs(int) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkConnector
Builds each config for maxTasks tasks.
taskConfigs(int) - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
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.
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.
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.
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
 
TcpCommunicationSpi.HandshakeMessage - Class in org.apache.ignite.spi.communication.tcp
Handshake message.
TcpCommunicationSpi.HandshakeMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage
Default constructor required by Message.
TcpCommunicationSpi.HandshakeMessage(UUID, long, long) - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage
 
TcpCommunicationSpi.HandshakeMessage2 - Class in org.apache.ignite.spi.communication.tcp
Updated handshake message.
TcpCommunicationSpi.HandshakeMessage2() - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage2
 
TcpCommunicationSpi.NodeIdMessage - Class in org.apache.ignite.spi.communication.tcp
Node ID message.
TcpCommunicationSpi.NodeIdMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
 
TcpCommunicationSpi.RecoveryLastReceivedMessage - Class in org.apache.ignite.spi.communication.tcp
Recovery acknowledgment message.
TcpCommunicationSpi.RecoveryLastReceivedMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
Default constructor required by Message.
TcpCommunicationSpi.RecoveryLastReceivedMessage(long) - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
 
TcpCommunicationSpiMBean - Interface in org.apache.ignite.spi.communication.tcp
MBean provide access to TCP-based communication SPI.
TcpDiscoveryCloudIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.cloud
IP finder for automatic lookup of nodes running in a cloud.
TcpDiscoveryCloudIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Constructor.
TcpDiscoveryGoogleStorageIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.gce
Google Cloud Storage based IP finder.
TcpDiscoveryGoogleStorageIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
 
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.
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.
TcpDiscoveryS3IpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.s3
AWS S3-based IP finder.
TcpDiscoveryS3IpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Constructor.
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.
TcpDiscoveryZookeeperIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.zk
This TCP Discovery IP Finder uses Apache ZooKeeper (ZK) to locate peer nodes when bootstrapping in order to join the cluster.
TcpDiscoveryZookeeperIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Constructor.
TextPartiallyRawComparator - Class in org.apache.ignite.hadoop.io
Partial raw comparator for Text data type.
TextPartiallyRawComparator() - Constructor for class org.apache.ignite.hadoop.io.TextPartiallyRawComparator
 
TextQuery<K,V> - Class in org.apache.ignite.cache.query
Query for Lucene based fulltext search.
TextQuery(String, String) - 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.
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).
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.
ThreadPoolMXBean - Interface in org.apache.ignite.mxbean
MBean that provides access to information about executor service.
threadPri - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Thread priority for all threads started by SPI.
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 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.
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.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.
toConnectData(String, byte[]) - Method in class org.apache.ignite.stream.kafka.connect.serialization.CacheEventConverter
toEnvs() - Method in class org.apache.ignite.yarn.ClusterProperties
Convert to properties to map.
tooltip() - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
Tab tooltip.
topHistSize - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Size of topology snapshots history.
TOPIC_NAMES - Static variable in class org.apache.ignite.stream.kafka.connect.IgniteSourceConstants
Kafka topic.
topology(Collection<ClusterNode>) - Static method in class org.apache.ignite.hadoop.planner.HadoopAbstractMapReducePlanner
Create plan topology.
topology(long) - Method in interface org.apache.ignite.IgniteCluster
Gets a topology by version.
topologyNodes() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets topology nodes from topology snapshot.
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.
TopologyValidator - Interface in org.apache.ignite.configuration
Topology validator is used to verify that cluster topology is valid for further cache operations.
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.
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.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
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.QueryIndex
toString() - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
toString() - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
toString() - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
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.compute.gridify.aop.GridifyArgumentAdapter
toString() - Method in class org.apache.ignite.configuration.AtomicConfiguration
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.CollectionConfiguration
toString() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
toString() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
toString() - Method in class org.apache.ignite.configuration.HadoopConfiguration
toString() - Method in class org.apache.ignite.configuration.IgniteConfiguration
toString() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
toString() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
toString() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
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.IgfsEvent
toString() - Method in class org.apache.ignite.events.JobEvent
toString() - Method in class org.apache.ignite.events.TaskEvent
toString() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
toString() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
toString() - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopWeightedMapReducePlanner
toString() - Method in class org.apache.ignite.hadoop.util.BasicUserNameMapper
toString() - Method in class org.apache.ignite.hadoop.util.ChainedUserNameMapper
toString() - Method in class org.apache.ignite.hadoop.util.KerberosUserNameMapper
toString() - Method in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
toString() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
toString() - Method in class org.apache.ignite.igfs.IgfsPath
toString() - Method in class org.apache.ignite.igfs.IgfsPathSummary
toString() - Method in class org.apache.ignite.igfs.mapreduce.IgfsFileRange
toString() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
toString() - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
toString() - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
toString() - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
toString() - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
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.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.log4j.Log4JLogger
toString() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
toString() - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
toString() - Method in class org.apache.ignite.mesos.IgniteTask
 
toString() - Method in class org.apache.ignite.messaging.MessagingListenActor
toString() - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
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.s3.S3CheckpointSpi
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.TcpCommunicationSpi.HandshakeMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage2
toString() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.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.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
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.s3.TcpDiscoveryS3IpFinder
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.eventstorage.memory.MemoryEventStorageSpi
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.ssl.SslContextFactory
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
toString() - Method in class org.apache.ignite.yarn.IgniteContainer
totalCnt - Variable in class org.apache.ignite.services.ServiceConfiguration
Total count.
totalCount() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets maximum allowed total number of deployed services in the grid, 0 for unlimited.
totalLength() - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
totalLength(long) - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
totalMemoryPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
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) - 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.log4j.Log4JLogger
Logs out trace message.
trace(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.
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.
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.
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.
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.Ignite
Gets grid transactions facade.
transactions() - Method in class org.apache.ignite.IgniteSpringBean
Gets grid transactions facade.
TransactionState - Enum in org.apache.ignite.transactions
Cache transaction state.
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.
transferFrom(DataInput, int) - Method in class org.apache.ignite.igfs.IgfsOutputStream
Transfers specified amount of bytes from data input to this output stream.
transform(Object) - Method in interface org.apache.ignite.cache.hibernate.HibernateKeyTransformer
 
transform(String...) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
 
transform(List<Event>) - Method in interface org.apache.ignite.stream.flume.EventTransformer
Transforms a list of Flume Events to cache entries.
transformer - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Types transformer.
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.
TwitterStreamer<K,V> - Class in org.apache.ignite.stream.twitter
Streamer that consumes from a Twitter Streaming API and feeds transformed key-value pairs, by default , into an IgniteDataStreamer instance.
TwitterStreamer(OAuthSettings) - Constructor for class org.apache.ignite.stream.twitter.TwitterStreamer
 
tx() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets transaction started by this thread or null if this thread does not have a transaction.
tx() - Method in interface org.apache.ignite.IgniteTransactions
Gets transaction started by this thread or null if this thread does not have a transaction.
txCommits() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction commits.
txRollbacks() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction rollbacks.
txStart(TransactionConcurrency, TransactionIsolation) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Starts new transaction with the specified concurrency and isolation.
txStart(TransactionConcurrency, TransactionIsolation, long, int) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Starts transaction with specified isolation, concurrency, timeout, invalidation flag, and number of participating entries.
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.
txStartEx(TransactionConcurrency, TransactionIsolation) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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(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.
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(String) - Method in interface org.apache.ignite.IgniteBinary
Gets type ID for given type name.
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.
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.
types() - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for all known types.

U

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.
UNLIMITED - Static variable in class org.apache.ignite.mesos.ClusterProperties
Unlimited.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Unlocks given key only if current thread owns the lock.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock() - Method in interface org.apache.ignite.IgniteLock
Releases the lock.
unlockAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Unlocks given keys only if current thread owns the locks.
unlockRegion() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after transaction clearing entire cache region completed.
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.cloud.TcpDiscoveryCloudIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Unregisters provided addresses.
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.s3.TcpDiscoveryS3IpFinder
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.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Unregisters provided addresses.
unregisterMBean() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Unregisters MBean.
unwrap(Class<T>) - Method in class org.apache.ignite.cache.CacheManager
unwrapCacheEntry(Cache.Entry<K, V>, Class<T>) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Unwrap entry to specified type.
update(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate updated object in the database but before transaction completed.
update(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate updated object in the database but before transaction completed.
update(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate updated object in the database but before transaction completed.
update(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate updated object in the database but before transaction completed.
update(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate updated object in the database but before transaction completed.
update(IgfsPath, Map<String, String>) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Updates file information for the specified path.
update(IgfsPath, Map<String, String>) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Updates file information for the specified path.
update(IgfsPath, Map<String, String>) - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Updates file information for the specified path.
update(IgfsPath, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
Updates file information for the specified path.
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
 
updatedMeta() - Method in class org.apache.ignite.events.IgfsEvent
Updated file metadata properties.
updateFilePath(IgniteClosure<String, String>) - Method in class org.apache.ignite.logger.log4j.Log4JDailyRollingFileAppender
Sets closure that later evaluate file path.
updateFilePath(IgniteClosure<String, String>) - Method in class org.apache.ignite.logger.log4j.Log4JExternallyRolledFileAppender
Sets closure that later evaluate file path.
updateFilePath(IgniteClosure<String, String>) - Method in class org.apache.ignite.logger.log4j.Log4JFileAppender
Sets closure that later evaluate file path.
updateFilePath(IgniteClosure<String, String>) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Sets closure that later evaluate file path.
updateFilePath(IgniteClosure<String, String>) - Method in class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
Sets closure that later evaluate file path.
updateMethodParameter(Object, int) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Updates method parameter.
updateMethodParameterType(Class<?>, int) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Updates parameter type.
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.
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.
URL_PREFIX - Static variable in class org.apache.ignite.IgniteJdbcDriver
URL prefix.
usedSpaceSize() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Gets used space in bytes.
usedSpaceSize() - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Gets used space in bytes.
usedSpaceSize() - Method in class org.apache.ignite.igfs.secondary.local.LocalIgfsSecondaryFileSystem
Gets used space in bytes.
usedSpaceSize() - Method in interface org.apache.ignite.IgniteFileSystem
Gets used space in bytes.
user() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Returns the user name this File System is created on behalf of.
user() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
Returns the user name this File System is created on behalf of.
user() - Method in interface org.apache.ignite.hadoop.HadoopJob
Gets user name.
userArgument() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
User argument provided for task execution.
userLibs() - Method in class org.apache.ignite.mesos.ClusterProperties
 
userLibs() - Method in class org.apache.ignite.yarn.ClusterProperties
 
UserNameMapper - Interface in org.apache.ignite.hadoop.util
Hadoop file system name mapper.
usersLibsUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 

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.
validateConfig() - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
Validates config at start.
validateNewNode(ClusterNode) - 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.
validateRemote(CacheConfiguration, CacheConfiguration, ClusterNode) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Checks that remote caches has configuration compatible with the local.
value(BinaryObject) - Method in interface org.apache.ignite.binary.BinaryField
Get field's value from the given object.
value() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry value.
value() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current value.
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.store.cassandra.persistence.PersistenceStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField.SortOrder
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.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.compute.gridify.aop.spring.GridifySpringPointcut.GridifySpringPointcutType
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.WALMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.igfs.IgfsIpcEndpointType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.igfs.IgfsMode
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.osgi.classloaders.OsgiClassLoadingStrategyType
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.spi.IgnitePortProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.stream.zeromq.ZeroMqTypeSocket
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.
ValuePersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings for Ignite cache value
ValuePersistenceSettings(Element) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates class instance from XML configuration.
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.store.cassandra.persistence.PersistenceStrategy
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.cassandra.persistence.PojoKeyField.SortOrder
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.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.compute.gridify.aop.spring.GridifySpringPointcut.GridifySpringPointcutType
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.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.igfs.IgfsIpcEndpointType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.igfs.IgfsMode
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.osgi.classloaders.OsgiClassLoadingStrategyType
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.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.stream.zeromq.ZeroMqTypeSocket
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
 
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.cluster.ClusterNode
Gets node version.
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.stream.kafka.connect.IgniteSinkConnector
version() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSinkTask
version() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceConnector
version() - Method in class org.apache.ignite.stream.kafka.connect.IgniteSourceTask
VisorExtensionPoint - Class in org.apache.ignite.visor.plugin
Abstract base class for Visor plugin extension point.
VisorExtensionPoint(VisorPluginModel) - Constructor for class org.apache.ignite.visor.plugin.VisorExtensionPoint
 
VisorPluggableTab - Class in org.apache.ignite.visor.plugin
Abstract base class for Visor pluggable tabs.
VisorPluggableTab(VisorPluginModel) - Constructor for class org.apache.ignite.visor.plugin.VisorPluggableTab
 
VisorPlugin - Class in org.apache.ignite.visor.plugin
Base class for Visor plugins.
VisorPlugin(PluginWrapper) - Constructor for class org.apache.ignite.visor.plugin.VisorPlugin
Constructor to be used by plugin manager for plugin instantiation.
VisorPluginComponent - Interface in org.apache.ignite.visor.plugin
Base interface for Visor components.
VisorPluginComponentsFactory - Interface in org.apache.ignite.visor.plugin
Factory for creating ready Visor UI blocks like nodes panel, log panel, etc.
VisorPluginLogPanel - Interface in org.apache.ignite.visor.plugin
Standard Visor panel with log entries.
VisorPluginModel - Interface in org.apache.ignite.visor.plugin
Gateway to Visor functionality from plugins.
VisorPluginNodesPanel - Interface in org.apache.ignite.visor.plugin
Standart Visor panel with nodes.
VisorSelectionListener<T> - Interface in org.apache.ignite.visor.plugin
The listener interface for receiving "selection" events from standard Visor panels.
VisorTopologyListener - Interface in org.apache.ignite.visor.plugin
Listener for grid node topology changes.
VM_ID - Static variable in class org.apache.ignite.lang.IgniteUuid
VM ID.
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.
WALMode - Enum in org.apache.ignite.configuration
WAL Mode.
WalSegmentArchivedEvent - Class in org.apache.ignite.events
Event indicates there was movement of WAL segment file to archive has been completed
WalSegmentArchivedEvent(ClusterNode, long, File) - Constructor for class org.apache.ignite.events.WalSegmentArchivedEvent
Creates WAL segment event
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) - 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) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out warning message.
warning(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) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out warning message.
warning(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.
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.IgniteFileSystem
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.
withExpiryPolicy(ExpiryPolicy) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
withExpiryPolicy(ExpiryPolicy) - Method in interface org.apache.ignite.IgniteCache
Returns cache with the specified expired policy set.
withKeepBinary() - Method in interface org.apache.ignite.IgniteCache
Returns cache that will operate with binary objects.
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.IgniteCompute
Sets no-failover flag for the next task executed in the current thread.
withNoRetries() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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 operations (read, write) regardless of partition loss policy.
withSkipStore() - Method in interface org.apache.ignite.IgniteCache
 
withTimeout(long) - Method in interface org.apache.ignite.IgniteCompute
Sets task timeout for the next executed task in the current thread.
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.cassandra.CassandraCacheStore
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
write(HadoopJobEx, HadoopCounters) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter
Writes counters of given job to some statistics storage.
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.cassandra.CassandraCacheStore
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
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.igfs.IgfsPath
Writes fields to provided writer.
writeBinary(BinaryWriter) - Method in class org.apache.ignite.igfs.IgfsPathSummary
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.igfs.IgfsPerBlockLruEvictionPolicy
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
writeExternal(ObjectOutput) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
writeExternal(ObjectOutput) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
writeExternal(ObjectOutput) - Method in class org.apache.ignite.igfs.IgfsPath
writeExternal(ObjectOutput) - Method in class org.apache.ignite.igfs.IgfsPathSummary
writeExternal(ObjectOutput) - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
writeExternal(ObjectOutput) - Method in class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
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.
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.
WriteMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Mutation which writes(inserts) object into Cassandra.
WriteMutation(Cache.Entry, String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Creates instance of delete mutation operation.
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.
writeRawBinary(BinaryRawWriter) - Method in class org.apache.ignite.igfs.IgfsPath
Write raw binary.
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
 
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.TcpCommunicationSpi.HandshakeMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage2
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.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(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 cache transaction or null if there is no surrounding transaction.
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).

Y

YARN_LOG_OUT - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 

Z

ZeroMqTypeSocket - Enum in org.apache.ignite.stream.zeromq
Enumeration of all supported IgniteZeroMqStreamer socket types.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Ignite - In-Memory Data Fabric

2017 Copyright © Apache Software Foundation
Ignite Fabric :   ver. 2.1.0
Release Date :   July 20 2017