Apache 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 

A

AboutDialog - Class in org.apache.ignite.startup.cmdline
About dialog.
AbstractMarshaller - Class in org.apache.ignite.marshaller
Base class for marshallers.
AbstractMarshaller() - Constructor for class org.apache.ignite.marshaller.AbstractMarshaller
 
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcDriver
accessTime() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file last access time.
activate() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Activates the job.
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.
add(E, K, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
Add event to the index.
add(StreamerIndexUpdateSync, E) - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Adds an event to index.
add(StreamerIndexUpdateSync, E) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Add event to the index.
add(E, K, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Add event to the index.
add(E, K, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
Add event to the index.
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteQueue
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteSet
addAllInternal(Collection<E>, Collection<StreamerBoundedSizeSortedWindow.Holder<E>>, Set<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Adds all events to queue implementation.
addAllInternal(Collection<E>, Collection<E>, Set<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
Adds all events to queue implementation.
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.
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.
addEvent(Object, Object...) - Method in interface org.apache.ignite.IgniteStreamer
Submits group of events for processing.
addEvent(StreamerIndexEntry<E, K, V>, K, V, StreamerIndexProviderAdapter.IndexKey<V>, E) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
addEvents(Collection<?>) - Method in interface org.apache.ignite.IgniteStreamer
Submits group of events for processing.
addEventsToStage(String, Collection<?>) - Method in interface org.apache.ignite.IgniteStreamer
Submits events to streamer.
addEventToStage(String, Object, Object...) - Method in interface org.apache.ignite.IgniteStreamer
Submits group of events to streamer.
addInternal(E, Collection<StreamerBoundedSizeSortedWindow.Holder<E>>, Set<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Adds event to queue implementation.
addInternal(E, Collection<E>, Set<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
Adds event to queue implementation.
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.
addMessageListener(GridMessageListener, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Register a message listener to receive messages sent by remote nodes.
addMeta(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Adds a new metadata.
addMeta(UUID, V) - Method in interface org.apache.ignite.transactions.Transaction
Adds a new metadata.
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.GridSecuritySubject
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.
addStreamerFailureListener(StreamerFailureListener) - Method in interface org.apache.ignite.IgniteStreamer
Adds streamer failure listener.
addToCollection(Collection<E>, E) - Static method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
addToMap(Map<E, Integer>, E) - Static method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
addTopologyListener(VisorTopologyListener) - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
Install topology listener.
affinity() - Method in interface org.apache.ignite.cache.GridCache
Gets affinity service to provide information about data partitioning and distribution.
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.
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).
affinityKey(K) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Maps passed in key to a key which will be used for node affinity.
affinityKey() - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
Gets affinity key to use for affinity mapping.
affinityKey(Object) - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
Sets affinity key to use for affinity mapping.
affinityKey(Object) - Method in interface org.apache.ignite.cache.affinity.CacheAffinityKeyMapper
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 CacheAffinityKeyMapped, 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.
affinityKey() - Method in interface org.apache.ignite.streamer.router.StreamerAffinityEventRouter.AffinityEvent
 
affinityKey() - Method in interface org.apache.ignite.streamer.router.StreamerCacheAffinityEventRouter.CacheAffinityEvent
 
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).
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.
afterPropertiesSet() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
afterPropertiesSet() - Method in class org.apache.ignite.cache.spring.SpringDynamicCacheManager
afterPropertiesSet() - Method in class org.apache.ignite.IgniteSpringBean
afterUpdate(Object, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object, SoftLock) - 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.
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 value indicating that this data streamer assumes that there are no other concurrent updates to the cache.
allowOverwrite(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag indicating that this data streamer should assume that there are no other concurrent updates to the cache.
allPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets partition ids for which nodes of the given projection has ownership (either primary or backup).
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, 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.
apply(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on a node in this grid projection.
apply(IgniteClosure<T, R>, Collection<? extends T>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within this grid projection.
apply(IgniteClosure<T, R1>, Collection<? extends T>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within this grid projection.
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.
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.CacheRendezvousAffinityFunction
Returns collection of nodes (primary first) for specified partition.
assignPartitions(CacheAffinityFunctionContext) - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunction
Gets affinity nodes for a partition.
assignPartitions(CacheAffinityFunctionContext) - Method in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Gets affinity nodes for a partition.
assignPartitions(CacheAffinityFunctionContext) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
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, 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.
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, 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, 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, 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.
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_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).
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, GridSecurityCredentials) - 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
 
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() - Static method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Checks whether GridOptimizedMarshaller is able to work on the current JVM.
AVAILABLE_PROC_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
averageExecutionTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average execution time in milliseconds since future was created.
averageExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage average execution time.
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.QueryMetrics
Gets average execution time of query.
averageWaitingTime() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Stage average waiting time.
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.
await() - Method in class org.apache.ignite.streamer.index.StreamerIndexUpdateSync
Waits for a notification from another thread, which should call StreamerIndexUpdateSync.finish(int) with an operation result.
awaitTermination(long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor

B

backupPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets partition ids for which nodes of the given projection has backup ownership.
backups() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunctionContext
Gets number of backups for new assignment.
BasicJdbcDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
Represents a dialect of SQL implemented by a particular RDBMS.
BasicJdbcDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
 
BasicWarmupClosure - Class in org.apache.ignite.startup
Basic warm-up closure which warm-ups cache operations.
BasicWarmupClosure() - Constructor for class org.apache.ignite.startup.BasicWarmupClosure
 
batchSize() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets local batch size for this atomic sequence.
batchSize(int) - Method in interface org.apache.ignite.IgniteAtomicSequence
Sets local batch size for atomic sequence.
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
 
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.
broadcast(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job to all nodes in grid projection.
broadcast(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job to all nodes in grid projection.
broadcast(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given closure job with passed in argument to all nodes in grid projection.
broadcast(IgniteInClosure<StreamerContext>) - Method in interface org.apache.ignite.streamer.StreamerContext
Queries all streamer nodes deployed within grid.
broadcast(IgniteInClosure<StreamerContext>, Collection<ClusterNode>) - Method in interface org.apache.ignite.streamer.StreamerContext
Queries streamer nodes deployed within grid.
BUCKET_NAME_PREFIX - Static variable in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Prefix to use in bucket name generation.
buildAccessStrategy(AccessType) - Method in class org.apache.ignite.cache.hibernate.HibernateCollectionRegion
buildAccessStrategy(AccessType) - Method in class org.apache.ignite.cache.hibernate.HibernateEntityRegion
buildAccessStrategy(AccessType) - Method in class org.apache.ignite.cache.hibernate.HibernateNaturalIdRegion
buildCollectionRegion(String, Properties, CacheDataDescription) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildEntityRegion(String, Properties, CacheDataDescription) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildNaturalIdRegion(String, Properties, CacheDataDescription) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildObject(String, String, Collection<CacheTypeFieldMetadata>, Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Construct object from query result.
buildObject(String, String, Collection<CacheTypeFieldMetadata>, Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Construct object from query result.
buildQueryResultsRegion(String, Properties) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildTimestampsRegion(String, Properties) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
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.
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 - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
Cache instance.
CacheAbstractJdbcStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Base CacheStore implementation 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, CacheTypeMetadata) - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
CacheAffinity<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.
CacheAffinityFunction - Interface in org.apache.ignite.cache.affinity
Cache key affinity which maps keys to nodes.
CacheAffinityFunctionContext - Interface in org.apache.ignite.cache.affinity
Affinity function context.
CacheAffinityKey<K> - Class in org.apache.ignite.cache.affinity
Optional wrapper for cache keys to provide support for custom affinity mapping.
CacheAffinityKey() - Constructor for class org.apache.ignite.cache.affinity.CacheAffinityKey
Empty constructor.
CacheAffinityKey(K) - Constructor for class org.apache.ignite.cache.affinity.CacheAffinityKey
Initializes key wrapper for a given key.
CacheAffinityKey(K, Object) - Constructor for class org.apache.ignite.cache.affinity.CacheAffinityKey
Initializes key together with its affinity key counter-part.
CacheAffinityKeyMapped - Annotation Type in org.apache.ignite.cache.affinity
Optional annotation to specify custom key-to-node affinity.
CacheAffinityKeyMapper - Interface in org.apache.ignite.cache.affinity
Affinity mapper which maps cache key to an affinity key.
CacheAffinityNodeAddressHashResolver - Class in org.apache.ignite.cache.affinity
Node hash resolver which uses ClusterNode.consistentId() as alternate hash value.
CacheAffinityNodeAddressHashResolver() - Constructor for class org.apache.ignite.cache.affinity.CacheAffinityNodeAddressHashResolver
 
CacheAffinityNodeHashResolver - Interface in org.apache.ignite.cache.affinity
Resolver which is used to provide node hash value for affinity function.
CacheAffinityNodeIdHashResolver - Class in org.apache.ignite.cache.affinity
Node hash resolver which uses generated node ID as node hash value.
CacheAffinityNodeIdHashResolver() - Constructor for class org.apache.ignite.cache.affinity.CacheAffinityNodeIdHashResolver
 
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.
CacheAtomicWriteOrderMode - Enum in org.apache.ignite.cache
Cache write ordering mode.
CacheCentralizedAffinityFunction - 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.
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(CompleteConfiguration) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
Copy constructor.
CacheDistributionMode - Enum in org.apache.ignite.cache
This enum defines mode in which partitioned cache operates.
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.
CacheEvictionFilter<K,V> - Interface in org.apache.ignite.cache.eviction
Eviction filter to specify which entries should not be evicted.
CacheEvictionPolicy<K,V> - Interface in org.apache.ignite.cache.eviction
Pluggable cache eviction policy.
CacheFifoEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.fifo
Eviction policy based on First In First Out (FIFO) algorithm.
CacheFifoEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Constructs FIFO eviction policy with all defaults.
CacheFifoEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Constructs FIFO eviction policy with maximum size.
CacheFifoEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.fifo
MBean for FIFO eviction policy.
CacheHibernateBlobStore<K,V> - Class in org.apache.ignite.cache.store.hibernate
CacheStore implementation backed by Hibernate.
CacheHibernateBlobStore() - Constructor for class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
 
CacheHibernateBlobStoreEntry - Class in org.apache.ignite.cache.store.hibernate
Entry that is used by CacheHibernateBlobStore implementation.
CacheIgfsEvictionFilter - Class in org.apache.ignite.cache.eviction.igfs
IGFS eviction filter which will not evict blocks of particular files.
CacheIgfsEvictionFilter() - Constructor for class org.apache.ignite.cache.eviction.igfs.CacheIgfsEvictionFilter
 
CacheIgfsPerBlockLruEvictionPolicy - Class in org.apache.ignite.cache.eviction.igfs
IGFS eviction policy which evicts particular blocks.
CacheIgfsPerBlockLruEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Default constructor.
CacheIgfsPerBlockLruEvictionPolicy(long, int) - Constructor for class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Constructor.
CacheIgfsPerBlockLruEvictionPolicy(long, int, Collection<String>) - Constructor for class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Constructor.
CacheIgfsPerBlockLruEvictionPolicyMXBean - Interface in org.apache.ignite.cache.eviction.igfs
MBean for IGFS per-block LRU eviction policy.
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
 
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
 
CacheJdbcPojoStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Base class for CacheStore that implementation backed by JDBC and POJO via reflection.
CacheJdbcPojoStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
 
CacheJdbcPojoStore.PojoMethodsCache - Class in org.apache.ignite.cache.store.jdbc
POJO methods cache.
CacheJdbcPojoStore.PojoMethodsCache(String, Collection<CacheTypeFieldMetadata>) - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore.PojoMethodsCache
POJO methods cache.
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
 
CacheLoadOnlyStoreAdapter<K,V,I> - Class in org.apache.ignite.cache.store
This adepter designed to support stores with bulk loading from stream-like source.
CacheLoadOnlyStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
 
CacheLruEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.lru
Eviction policy based on Least Recently Used (LRU) algorithm.
CacheLruEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Constructs LRU eviction policy with all defaults.
CacheLruEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Constructs LRU eviction policy with maximum size.
CacheLruEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.lru
MBean for LRU eviction policy.
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.
CacheMemoryMode - Enum in org.apache.ignite.cache
Defines set of memory modes.
CacheMetrics - Interface in org.apache.ignite.cache
Cache metrics used to obtain statistics on cache itself.
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() - Method in interface org.apache.ignite.services.ServiceContext
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in interface org.apache.ignite.streamer.router.StreamerCacheAffinityEventRouter.CacheAffinityEvent
 
CacheNameResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of grid cache name.
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
 
CachePartitionFairAffinity - Class in org.apache.ignite.cache.affinity.fair
Fair affinity function which tries to ensure that all nodes get equal number of partitions with minimum amount of reassignments between existing nodes.
CachePartitionFairAffinity() - Constructor for class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Creates fair affinity with default partition count.
CachePartitionFairAffinity(int) - Constructor for class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
 
CachePeekMode - Enum in org.apache.ignite.cache
Enumeration of all supported cache peek modes.
cachePermissions() - Method in interface org.apache.ignite.plugin.security.GridSecurityPermissionSet
Map of cache names to cache permissions.
CacheQueryConfiguration - Class in org.apache.ignite.configuration
Query configuration object.
CacheQueryConfiguration() - Constructor for class org.apache.ignite.configuration.CacheQueryConfiguration
Default constructor.
CacheQueryConfiguration(CacheQueryConfiguration) - Constructor for class org.apache.ignite.configuration.CacheQueryConfiguration
 
CacheQueryExecutedEvent<K,V> - Class in org.apache.ignite.events
Cache query execution event.
CacheQueryExecutedEvent(ClusterNode, String, int, CacheQueryType, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventFilter<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, CacheQueryType, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventFilter<K, V>, Object[], UUID, String, K, V, V, Object) - Constructor for class org.apache.ignite.events.CacheQueryReadEvent
 
CacheRandomEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.random
Cache eviction policy which will select random cache entry for eviction if cache size exceeds the CacheRandomEvictionPolicy.getMaxSize() parameter.
CacheRandomEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy
Constructs random eviction policy with all defaults.
CacheRandomEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy
Constructs random eviction policy with maximum size.
CacheRandomEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.random
MBean for random eviction policy.
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.
CacheRendezvousAffinityFunction - Class in org.apache.ignite.cache.affinity.rendezvous
Affinity function for partitioned cache based on Highest Random Weight algorithm.
CacheRendezvousAffinityFunction() - Constructor for class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Empty constructor with all defaults.
CacheRendezvousAffinityFunction(boolean) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Initializes affinity with flag to exclude same-host-neighbors from being backups of each other and specified number of backups.
CacheRendezvousAffinityFunction(boolean, int) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Initializes affinity with flag to exclude same-host-neighbors from being backups of each other, and specified number of backups and partitions.
CacheRendezvousAffinityFunction(int, IgniteBiPredicate<ClusterNode, ClusterNode>) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Initializes optional counts for replicas and backups.
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.
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.
CacheTypeFieldMetadata - Class in org.apache.ignite.cache
Type field metadata.
CacheTypeFieldMetadata() - Constructor for class org.apache.ignite.cache.CacheTypeFieldMetadata
Default constructor.
CacheTypeFieldMetadata(String, int, String, Class<?>) - Constructor for class org.apache.ignite.cache.CacheTypeFieldMetadata
Full constructor.
CacheTypeMetadata - Class in org.apache.ignite.cache
Type metadata.
CacheTypeMetadata() - Constructor for class org.apache.ignite.cache.CacheTypeMetadata
Default constructor.
CacheTypeMetadata(CacheTypeMetadata) - Constructor for class org.apache.ignite.cache.CacheTypeMetadata
Copy constructor.
CacheWriteSynchronizationMode - Enum in org.apache.ignite.cache
Mode indicating how Ignite should wait for write replies from other nodes.
CachingProvider - Class in org.apache.ignite.cache
Implementation of JSR-107 CachingProvider.
CachingProvider() - Constructor for class org.apache.ignite.cache.CachingProvider
 
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 in this grid projection.
call(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within this grid projection.
call(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within this grid projection.
callcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callLocal(Callable<R>) - Method in interface org.apache.ignite.IgniteScheduler
Executes given callable on internal system thread pool asynchronously.
cancel() - Method in interface org.apache.ignite.compute.ComputeJob
This method is called when system detects that completion of this job can no longer alter the overall outcome (for example, when parent task has already reduced the results).
cancel() - Method in class org.apache.ignite.compute.ComputeJobAdapter
This method is called when system detects that completion of this job can no longer alter the overall outcome (for example, when parent task has already reduced the results).
cancel() - Method in interface org.apache.ignite.compute.ComputeJobSibling
Sends a request to cancel this sibling.
cancel() - 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.
capacity() - Method in interface org.apache.ignite.IgniteQueue
Gets maximum number of elements of the queue.
cast(String, IOException) - Static method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Cast IO exception to IGFS exception.
centerShow(String, String, String, Date, String) - Static method in class org.apache.ignite.startup.cmdline.AboutDialog
Show about dialog.
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.
checkConfiguration() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Check window configuration.
checkConfiguration() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Check window configuration.
checkConfiguration() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Check window configuration.
checkConfiguration() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Check window configuration.
checkConfiguration() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Check window configuration.
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.
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.
CHK_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Query to check database validity.
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.
classLoader() - Method in class org.apache.ignite.spi.swapspace.SwapContext
 
classLoader(ClassLoader) - Method in class org.apache.ignite.spi.swapspace.SwapContext
 
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.
clause() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query clause.
clause() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query clause.
cleanup() - Method in class org.apache.ignite.spi.IgniteSpiThread
Should be overridden by child classes if cleanup logic is required.
clear() - Method in interface org.apache.ignite.IgniteCache
clear(K) - Method in interface org.apache.ignite.IgniteCache
Clear entry from the cache and swap storage, without notifying listeners or CacheWriters.
clear() - Method in interface org.apache.ignite.IgniteQueue
clear(int) - Method in interface org.apache.ignite.IgniteQueue
Removes all of the elements from this queue.
clear() - Method in interface org.apache.ignite.IgniteSet
clear() - Method in class org.apache.ignite.lang.IgniteBiTuple
clear() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
clear(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Entirely clears data space with given name, if any.
clear(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Entirely clears data space with given name, if any.
clear(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Entirely clears data space with given name, if any.
clearAll(Set<K>) - Method in interface org.apache.ignite.IgniteCache
Clear 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.
clearCache() - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Intended for test purposes only.
clearCache() - Static method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Clears internal caches and frees memory.
clearEvicted() - Method in interface org.apache.ignite.streamer.StreamerWindow
Clears all evicted entries.
clearEvicted() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Clears all evicted entries.
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.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
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.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.IgniteQueue
Removes this queue.
close() - Method in interface org.apache.ignite.IgniteSet
Removes this set.
close() - Method in class org.apache.ignite.IgniteSpringBean
Closes this instance of grid.
close() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.IgniteSpiCloseableIterator
Closes the iterator and frees all the resources held by the iterator.
close() - Method in interface org.apache.ignite.transactions.Transaction
Ends the transaction.
closeConnection(Connection) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes connection.
closureClassName() - Method in class org.apache.ignite.events.CacheEvent
Gets closure class name (applicable only for TRANSFORM operations).
cls - Variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore.PojoMethodsCache
POJO class.
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 grid projection which represents a common functionality over a group of nodes.
clusterGroup() - Method in interface org.apache.ignite.IgniteCompute
Gets grid projection to which this GridCompute instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteEvents
Gets grid projection to which this GridMessaging instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteMessaging
Gets grid projection to which this GridMessaging instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteServices
Gets grid projection to which this GridServices 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 - Interface in org.apache.ignite.cluster
This class represents runtime information on a cluster.
ClusterNode - Interface in org.apache.ignite.cluster
Interface representing a single grid node.
ClusterTopologyException - Exception in org.apache.ignite.cluster
This exception is used to indicate error with grid 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(UUID) - 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.
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.
commitTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets last time transaction was committed.
CommunicationListener<T extends Serializable> - Interface in org.apache.ignite.spi.communication
Listener SPI notifies IO manager with.
CommunicationSpi<T extends Serializable> - Interface in org.apache.ignite.spi.communication
Communication SPI is responsible for data exchange between nodes.
compareAndSet(long, long) - Method in interface org.apache.ignite.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
components() - Method in class org.apache.ignite.igfs.IgfsPath
Split full path on components.
compute() - Method in interface org.apache.ignite.Ignite
Gets compute functionality over this grid projection.
compute(ClusterGroup) - Method in interface org.apache.ignite.Ignite
 
compute() - Method in class org.apache.ignite.IgniteSpringBean
Gets compute functionality over this grid projection.
compute(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
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.
configInfo(String, Object) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformed string for configuration parameter.
configuration() - Method in interface org.apache.ignite.cache.GridCache
Gets configuration bean for this cache.
configuration() - Method in interface org.apache.ignite.Ignite
Gets the configuration of this grid 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 grid instance.
configuration() - Method in interface org.apache.ignite.IgniteStreamer
Gets streamer configuration.
configuration() - Method in interface org.apache.ignite.plugin.PluginContext
 
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
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
 
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.
consistencyCheck(Collection<StreamerBoundedSizeSortedWindow.Holder<E>>, Set<E>, AtomicInteger) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Checks consistency.
consistencyCheck(Collection<E>, Set<E>, AtomicInteger) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
Checks consistency.
consistentId() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets consistent globally unique node ID.
container() - Method in interface org.apache.ignite.visor.plugin.VisorPluginComponent
Get component container.
contains(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
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
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.
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
 
containsValue(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
context() - Method in interface org.apache.ignite.IgniteStreamer
Gets streamer context.
contextDestroyed(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup
contextInitialized(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup
continuous() - Static method in class org.apache.ignite.cache.query.Query
Factory method for continuous queries.
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
 
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.
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(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets number of stored entries (keys) in data space with given name.
count(String, Set<Integer>) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets number of stored entries (keys) in data space with given name.
count(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets number of stored entries (keys) in data space with given name.
count(String, Set<Integer>) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets number of stored entries (keys) in data space with given name.
count(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets number of stored entries (keys) in data space with given name.
count(String, Set<Integer>) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets number of stored entries (keys) in data space with given name.
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.
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 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(byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactory
Creates new message instance of provided type.
CREATE_ADDRS_TABLE_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Query to create addresses table.
createAccessStrategy(AccessType) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
 
createCache(String, C) - Method in class org.apache.ignite.cache.CacheManager
createComponent(PluginContext, Class<T>) - Method in interface org.apache.ignite.plugin.PluginProvider
 
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.
createNioClient(ClusterNode) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
createPanel(VisorPluginComponentsFactory, JPanel) - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
Construct content of pluggable tab.
createSpiAttributeName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Creates new name for the given attribute.
createTcpClient(ClusterNode) - 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.
credentials() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets security credentials.
credentials(GridSecurityCredentials) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets security credentials.
credentials() - Method in class org.apache.ignite.plugin.security.GridSecurityCredentialsBasicProvider
Gets security credentials.
credentials() - Method in interface org.apache.ignite.plugin.security.GridSecurityCredentialsProvider
Gets security credentials.
ctx - Variable in class org.apache.ignite.marshaller.AbstractMarshaller
Context.
currentActiveSessions() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets number of current active sessions.
currentTopologySnapshot() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunctionContext
Gets current topology snapshot.
currentTopologyVersion() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunctionContext
Gets current topology version number.

D

dataSize() - Method in class org.apache.ignite.events.IgfsEvent
Transferred data size for this event.
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 DB2 database.
DB2Dialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
 
debug(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.jcl.IgniteJclLogger
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.NullLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Logs out debug message.
decrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Decrements and gets current value of atomic long.
defaultAllowAll() - Method in interface org.apache.ignite.plugin.security.GridSecurityPermissionSet
Flag indicating whether to allow or deny cache and task operations if they were not explicitly specified.
delete(Object) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
delete(Object) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
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 interface org.apache.ignite.IgniteFileSystem
Deletes file.
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.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.
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).
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.
deployClass(Class<?>) - Method in interface org.apache.ignite.IgniteStreamer
Explicitly sets deployment class.
deployClusterSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
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.
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.
deployNodeSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
Deploys a per-node singleton service.
depth() - Method in class org.apache.ignite.igfs.IgfsPath
Return the number of elements in this path.
dequeue() - Method in interface org.apache.ignite.streamer.StreamerWindow
Dequeues last element from windows.
dequeue(int) - Method in interface org.apache.ignite.streamer.StreamerWindow
Dequeues up to cnt elements from window.
dequeue() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Dequeues last element from windows.
dequeue(int) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Dequeues up to cnt elements from window.
dequeue0(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Dequeues up to cnt elements from window.
dequeue0(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Dequeues up to cnt elements from window.
dequeue0(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Dequeues up to cnt elements from window.
dequeue0(int) - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Dequeues up to cnt elements from window.
dequeue0(int) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Dequeues up to cnt elements from window.
dequeueAll() - Method in interface org.apache.ignite.streamer.StreamerWindow
Dequeues all elements from window.
dequeueAll() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Dequeues all elements from window.
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.
destroy() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
destroy() - Method in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
destroy() - Method in class org.apache.ignite.IgniteSpringBean
destroy() - Method in class org.apache.ignite.startup.servlet.IgniteServletStartup
destroyCache(String) - Method in class org.apache.ignite.cache.CacheManager
DFLT_ACCESS_TYPE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
 
DFLT_ACK_SND_THRESHOLD - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default received messages threshold for sending ack.
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_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_BASE_DIR - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Default base directory.
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.CacheAbstractJdbcStore
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.cache.query.ContinuousQuery
Default buffer size.
DFLT_BUF_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default read/write buffers size (bytes).
DFLT_BUF_SIZE - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Default write buffer size in 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.HibernateRegionFactory
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_CLOCK_SYNC_FREQUENCY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default clock synchronization frequency.
DFLT_CLOCK_SYNC_SAMPLES - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default number of clock sync samples.
DFLT_CONCUR_LVL - Static variable in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
 
DFLT_CONFIG_PATH - Static variable in class org.apache.ignite.logger.java.JavaLogger
 
DFLT_CONN_BUF_FLUSH_FREQ - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default value for connection buffer flush frequency (value is 100 ms).
DFLT_CONN_BUF_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default value for connection buffer size (value is 0).
DFLT_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default connection timeout (value is 1000ms).
DFLT_CONN_URL - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default connection URL (value is jdbc:h2:mem:hibernateCacheStore;DB_CLOSE_DELAY=-1;DEFAULT_LOCK_TIMEOUT=5000).
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 (key other primary key, val other)).
DFLT_DEL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default delete entry query (value is delete from ENTRIES where key=?
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_DISCONNECT_CHECK_INT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Default disconnect check interval.
DFLT_DISCOVERY_STARTUP_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default discovery startup delay in milliseconds (value is 60,000ms).
DFLT_DISK_SCAN_FREQUENCY - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default scan frequency for file:// and classes:// protocols (value is 5000).
DFLT_DISTRIBUTION_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for cache distribution mode.
DFLT_EAGER_TTL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for eager ttl flag.
DFLT_EVICT_KEY_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default eviction key buffer size for batching synchronized evicts.
DFLT_EVICT_NEAR_SYNCHRONIZED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default near nodes eviction synchronized flag.
DFLT_EVICT_SYNCHRONIZED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default eviction synchronized flag.
DFLT_EVICT_SYNCHRONIZED_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default synchronous eviction concurrency level.
DFLT_EVICT_SYNCHRONIZED_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default synchronous eviction timeout in milliseconds.
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_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_LOCAL_WRITES_RATIO - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default fragmentizer local writes ratio.
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_FTP_SCAN_FREQUENCY - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default scan frequency for ftp:// protocol (value is 300000).
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_HBM2DDL_AUTO - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default hibernate.hbm2ddl.auto property value (value is true).
DFLT_HOST - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default host.
DFLT_HTTP_SCAN_FREQUENCY - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default scan frequency for http:// protocol (value is 300000).
DFLT_IDLE_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default idle connection timeout (value is 30000ms).
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 (key, 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_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_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 key=?
DFLT_LOCK_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default lock timeout.
DFLT_LONG_QRY_EXEC_TIMEOUT - Static variable in class org.apache.ignite.configuration.QueryConfiguration
Default query execution time interpreted as long query (3 seconds).
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_CONCURRENT_SESSIONS - Static variable in class org.apache.ignite.streamer.StreamerConfiguration
By default maximum number of concurrent sessions is unlimited.
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_EVICTION_OVERFLOW_RATIO - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default maximum eviction queue ratio.
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_FAILOVER_ATTEMPTS - Static variable in class org.apache.ignite.streamer.StreamerConfiguration
Default value for maximum failover attempts.
DFLT_MAX_MISSED_CLIENT_HEARTBEATS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default max heartbeats count node can miss without failing client node (value is 5).
DFLT_MAX_MISSED_HEARTBEATS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default max heartbeats count node can miss without initiating status check (value is 1).
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.IgniteWebSessionFilter
Default retry on fail flag value.
DFLT_MAX_SPARSITY - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Default maximum sparsity.
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_SIZE - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default shared memory space in bytes.
DFLT_MEMORY_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default memory mode.
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_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_OFFHEAP_MEMORY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default off-heap storage size is -1 which means that off-heap storage is disabled.
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_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.CacheAbstractJdbcStore
Default batch size for put and remove operations.
DFLT_PART_CNT - Static variable in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Default partition count.
DFLT_PARTITION_COUNT - Static variable in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Default number of partitions.
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.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_RANGE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default rest port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default local port range (value is 100).
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default local port range (value is 100).
DFLT_PREVENT_STARVATION_ENABLED - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default flag for preventing starvation of lower priority jobs.
DFLT_PRIORITY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default priority that will be assigned if job does not have a priority attribute set (value is 0).
DFLT_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default priority attribute key (value is grid.task.priority).
DFLT_PROPS - Static variable in class org.apache.ignite.cache.CachingProvider
 
DFLT_PUBLIC_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default keep alive time for public thread pool.
DFLT_PUBLIC_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
DFLT_PUBLIC_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default max queue capacity of public thread pool.
DFLT_QUE_SIZE - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Default write queue size in bytes.
DFLT_QUERY_INDEX_ENABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'queryIndexEnabled' flag.
DFLT_QUERY_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default query timeout.
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_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
Default size of rebalance thread pool.
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_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_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_POOL_SIZE - Static variable in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
 
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.min(4, Runtime.getRuntime().availableProcessors())".
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_SHOW_SQL - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default show SQL property value (value is true).
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.spi.communication.tcp.TcpCommunicationSpi
Default socket send and receive buffer size.
DFLT_SOCK_WRITE_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default socket write timeout.
DFLT_SPACE_NAME - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Name for null space.
DFLT_START_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Initial default cache size.
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_SWAP_ENABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'swapEnabled' flag.
DFLT_SYSTEM_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of system thread pool.
DFLT_SYSTEM_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default keep alive time for system thread pool.
DFLT_SYSTEM_MAX_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default max size of system thread pool.
DFLT_SYSTEM_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default max queue capacity of system thread pool.
DFLT_TCP_DIRECT_BUF - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP direct buffer flag.
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_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_TIME_TO_LIVE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default time to live.
DFLT_TOKEN_DIR_PATH - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Default token directory.
DFLT_TRANSACTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default transaction timeout.
DFLT_TRASH_PURGE_TIMEOUT - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
Default trash directory purge await timeout in case data cache oversize is detected.
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_UPDATE_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default update entry query (value is select * from ENTRIES where key=?
DFLT_USE_OPTIMIZED_SERIALIZER - Static variable in class org.apache.ignite.configuration.QueryConfiguration
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_WRITE_BEHIND_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default batch size 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.
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.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.
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.TcpClientDiscoverySpi
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.
discoveryEvent() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunctionContext
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.
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.
dispose() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Disposes the index.
dispose() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Disposes the index.
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
dumpDebugInfo() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Dumps debug info using configured logger.
dumpDebugInfo(IgniteLogger) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
dumpDebugInfo() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Dumps debug info using configured logger.
duration() - Method in interface org.apache.ignite.lang.IgniteFuture
Gets duration in milliseconds between start of the future and current time if future is not finished, or between start and finish of this future.

E

EMPTY_COLUMN_VALUE - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Empty column value.
EMPTY_FILE_STATUS - Static variable in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Empty array of file statuses.
enabledEvents() - Method in interface org.apache.ignite.IgniteEvents
Gets types of enabled events.
enableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Enables provided events.
enableManagement(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
enableStatistics(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
end(Connection, Statement) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes allocated resources depending on transaction status.
endUpdate(StreamerIndexUpdateSync, E, boolean, boolean) - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Finalizes an update operation.
endUpdate(StreamerIndexUpdateSync, E, boolean, boolean) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Finalizes an update operation.
endUpdate0(StreamerIndexUpdateSync, E, K, boolean) - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
endUpdate0(StreamerIndexUpdateSync, E, K, boolean) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
endUpdate0(StreamerIndexUpdateSync, E, K, boolean) - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
enhance(T) - Static method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringEnhancer
Enhances the object on load.
enqueue(E) - Method in interface org.apache.ignite.streamer.StreamerWindow
Adds single event to window.
enqueue(E...) - Method in interface org.apache.ignite.streamer.StreamerWindow
Adds events to window.
enqueue(E) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Adds single event to window.
enqueue(E...) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Adds events to window.
enqueue0(E) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Adds event to window.
enqueue0(E) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Adds event to window.
enqueue0(E) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Adds event to window.
enqueue0(E) - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Adds event to window.
enqueue0(E) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Adds event to window.
enqueueAll(Collection<E>) - Method in interface org.apache.ignite.streamer.StreamerWindow
Adds all events to window.
enqueueAll(Collection<E>) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Adds all events to window.
entries(int) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only collection of entries in the index.
entry(K) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets index entry for given key.
entrySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
entrySet(V) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only set of index entries with given value.
entrySet(boolean, V, boolean, V, boolean) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only set of index entries within given value range.
entryToKey - Variable in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
entryToVal - Variable in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
equals(Object) - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
Equality check which delegates to the underlying key equality.
equals(Object) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
equals(Object) - Method in class org.apache.ignite.events.EventAdapter
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.GridSecurityCredentials
equals(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
equals(Object) - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
equals(Object) - Method in class org.apache.ignite.spi.swapspace.SwapKey
equals(Object) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.Entry
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.IgniteJclLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.jcl.IgniteJclLogger
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.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.GridSlf4jLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Logs error message with optional exception.
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 functionality over this grid projection.
events(ClusterGroup) - Method in interface org.apache.ignite.Ignite
 
events() - Method in class org.apache.ignite.IgniteSpringBean
Gets events functionality over this grid projection.
events(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
events(int) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only collection of index events.
events(V) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only collection of index events.
events(boolean, V, boolean, V, boolean) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only collection of index events.
events() - Method in interface org.apache.ignite.streamer.index.StreamerIndexEntry
Gets events associated with given index key and value.
events() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.DedupTrackingEntry
Gets events associated with given index key and value.
events() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.EventTrackingEntry
Gets events associated with given index key and value.
events() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.NonTrackingEntry
Gets events associated with given index key and value.
eventsCount() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
EventStorageSpi - Interface in org.apache.ignite.spi.eventstorage
This SPI provides local node events storage.
EventType - Interface in org.apache.ignite.events
Contains event type constants.
evict() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Evicts entry associated with given key from cache.
evict(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
evict(Object) - 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.HibernateGeneralDataRegion
EvictableEntry<K,V> - Interface in org.apache.ignite.cache.eviction
Evictable cache entry passed into CacheEvictionPolicy.
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove all data from cache without regard to transaction.
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
evictAllowed(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.eviction.CacheEvictionFilter
Checks if entry may be evicted from cache.
evictAllowed(Cache.Entry) - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsEvictionFilter
Checks if entry may be evicted from cache.
evictionQueueSize() - Method in interface org.apache.ignite.streamer.StreamerWindow
Gets number of entries available for eviction.
evictionQueueSize() - Method in interface org.apache.ignite.streamer.StreamerWindowMetrics
Gets eviction queue size.
evictionQueueSize() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Gets number of entries available for eviction.
evictionQueueSize() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Gets number of entries available for eviction.
evictionQueueSize() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Gets number of entries available for eviction.
evictionQueueSize() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Gets number of entries available for eviction.
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_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_FROM_OFFHEAP - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object moved from off-heap storage back into memory.
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_SWAPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object swapped from swap storage.
EVT_CACHE_OBJECT_TO_OFFHEAP - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object stored in off-heap storage.
EVT_CACHE_OBJECT_UNLOCKED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object unlocked.
EVT_CACHE_OBJECT_UNSWAPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object unswapped from swap storage.
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_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_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_SWAP_SPACE_CLEARED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: swap space cleared.
EVT_SWAP_SPACE_DATA_EVICTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: swap space data evicted.
EVT_SWAP_SPACE_DATA_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: swap space data read.
EVT_SWAP_SPACE_DATA_REMOVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: swap space data removed.
EVT_SWAP_SPACE_DATA_STORED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: swap space data stored.
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_VISOR_EVENTS_LOST - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Visor detects that some events were evicted from events buffer since last poll.
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_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_SWAPSPACE - Static variable in interface org.apache.ignite.events.EventType
All swap space events.
EVTS_TASK_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
All grid task execution events.
exceptionRegistry() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets exception registry.
exclude(IgfsPath) - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Check whether provided path must be excluded from evictions.
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 the grid projection.
execute(ComputeTask<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task on this grid projection.
execute(String, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task on this grid projection.
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(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.
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.
executing() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets flag indicating if stage is being currently executed by at least one thread on current node.
executionId() - Method in interface org.apache.ignite.services.ServiceContext
Gets service execution ID.
executions() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets total number execution of query.
executorService() - Method in interface org.apache.ignite.Ignite
Creates new ExecutorService which will execute all submitted Callable and Runnable jobs on nodes in this grid projection.
executorService(ClusterGroup) - Method in interface org.apache.ignite.Ignite
 
executorService() - Method in class org.apache.ignite.IgniteSpringBean
Creates new ExecutorService which will execute all submitted Callable and Runnable jobs on nodes in this grid projection.
executorService(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
executorServiceCapacity() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets maximum number of threads in executor service.
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 interface org.apache.ignite.IgniteFileSystem
Checks if the specified path exists in the file system.
Extension - Interface in org.apache.ignite.plugin
Marker interface for extensions.
ExtensionRegistry - Interface in org.apache.ignite.plugin
Context that allows to register extensions.
extractField(String, String, String, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get field value from object.
extractField(String, String, String, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Get field value from object.

F

factory - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
 
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.
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.
failuresCount() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets number of failures.
failuresCount() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage failure count.
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.
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.IgniteJclLogger
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.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.GridSlf4jLogger
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.
FileSwapSpaceSpi - Class in org.apache.ignite.spi.swapspace.file
File-based swap space SPI implementation which holds keys in memory.
FileSwapSpaceSpi() - Constructor for class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
 
FileSwapSpaceSpiMBean - Interface in org.apache.ignite.spi.swapspace.file
Management bean for FileSwapSpaceSpi.
fileSystem() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Gets the underlying FileSystem.
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.
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
 
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
findManager(IgniteCache<?, ?>) - Method in class org.apache.ignite.cache.CachingProvider
 
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.
finish(int) - Method in class org.apache.ignite.streamer.index.StreamerIndexUpdateSync
Notifies all waiting threads to finish waiting.
firstEntry() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets first entry in the index.
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
forAttribute(String, String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates projection for nodes containing given name and value specified in user attributes.
forCacheNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates projection for all nodes that have cache with specified name running.
forceRepartition() - Method in interface org.apache.ignite.cache.GridCache
Forces this cache node to re-balance its partitions.
forClientNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates projection for all nodes that have cache with specified name running and cache distribution mode is CacheDistributionMode.CLIENT_ONLY or CacheDistributionMode.NEAR_ONLY.
forDaemons() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets projection consisting from the daemon nodes in this projection.
forDataNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates projection for all nodes that have cache with specified name running and cache distribution mode is CacheDistributionMode.PARTITIONED_ONLY or CacheDistributionMode.NEAR_PARTITIONED.
forHost(ClusterNode) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets grid projection consisting from the nodes in this projection residing on the same host as given node.
forLocal() - Method in interface org.apache.ignite.IgniteCluster
Gets monadic projection consisting from the local node.
format() - Method in interface org.apache.ignite.IgniteFileSystem
Formats the file system removing all existing entries from it.
format(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFormatter
forNode(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection for the given node.
forNodeId(UUID, UUID...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection for a node with specified ID.
forNodeIds(Collection<UUID>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection over nodes with specified node IDs.
forNodes(Collection<? extends ClusterNode>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection over a given set of nodes.
forOldest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates grid projection with one oldest node in the current projection.
forOthers(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection for nodes other than given nodes.
forOthers(ClusterGroup) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection for nodes not included into given projection.
forPredicate(IgnitePredicate<ClusterNode>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a grid projection which includes all nodes that pass the given predicate filter.
forRandom() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates grid projection with one random node from current projection.
forRemotes() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets grid projection consisting from the nodes in this projection excluding the local node.
forSpace(String) - Method in interface org.apache.ignite.spi.indexing.IndexingQueryFilter
Creates optional predicate for space.
forStreamer(String, String...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates projection for all nodes that have streamer with specified name running.
forYoungest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates grid projection with one youngest node in the current projection.
FRAMEWORK_NAME - Static variable in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
Framework name used in configuration.
fromBytes(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Deserialize object from byte array using marshaller.
fromBytes(byte[]) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Deserialize object from byte array using marshaller.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.cache.CacheAtomicWriteOrderMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheDistributionMode
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.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.DeploymentMode
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.GridSecurityPermission
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.plugin.security.GridSecuritySubjectType
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
Gets and resets future for previous asynchronous operation.
future() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets future for this streaming process.
future() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Gets and resets future for previous asynchronous operation.

G

get(Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Gets value from cache.
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Gets value from cache.
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Gets value from cache.
get() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Synchronously waits for completion of the computation and returns computation result.
get(long, TimeUnit) - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long.
get() - Method in interface org.apache.ignite.IgniteAtomicReference
Gets current value of an atomic reference.
get() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets current value of atomic sequence.
get() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets both current value and current stamp of atomic stamped.
get(K) - Method in interface org.apache.ignite.IgniteCache
get(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
get() - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation and returns computation result.
get(long) - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get(long, TimeUnit) - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Waits for the completion of the next scheduled execution and returns its result.
get(long, TimeUnit) - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Waits for the completion of the next scheduled execution for specified amount of time and returns its result.
get(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets object from cache.
get1() - Method in class org.apache.ignite.lang.IgniteBiTuple
Gets first value.
get2() - Method in class org.apache.ignite.lang.IgniteBiTuple
Gets second value.
GET_ADDRS_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Query to get addresses.
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
 
getAckSendThreshold() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets number of received messages per connection to node after which acknowledgment message is sent.
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.TcpClientDiscoverySpi
Gets message acknowledgement timeout.
getAckTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets message acknowledgement timeout.
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.ThreadPoolMXBean
Returns the approximate number of threads that are actively executing tasks.
getActiveJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets number of jobs that can be executed in parallel.
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.CacheConfiguration
Gets key topology resolver to provide mapping from keys to nodes.
getAffinityKey() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets affinity key used for key-to-node affinity calculation.
getAffinityMapper() - Method in class org.apache.ignite.configuration.CacheConfiguration
Affinity key mapper used to provide custom affinity key for any given key.
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
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(K, V) - Method in interface org.apache.ignite.IgniteCache
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.
getAndRemove(K) - Method in interface org.apache.ignite.IgniteCache
getAndReplace(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndSet(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long and sets new value l of atomic long.
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.
getAscendingFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets ascending-indexed fields.
getAtomicConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache atomicity mode.
getAtomicSequenceReserveSize() - Method in class org.apache.ignite.configuration.AtomicConfiguration
Gets default number of sequence values reserved for IgniteAtomicSequence instances.
getAtomicWriteOrderMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache write ordering mode.
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.
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.
getAverageExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage average execution time.
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.
getAverageWaitingTime() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Stage average waiting time.
getAvgMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets avg message processing time.
getAvgMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets avg message processing time.
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.CacheRendezvousAffinityFunction
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.
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.
getBaseDirectory() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets base directory.
getBaseDirectory() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
Gets base directory.
getBatchFutureMapSize() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets size of batch futures map.
getBatchQueueSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns batch queue 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.streamer.window.StreamerBoundedSizeBatchWindow
Gets batch size.
getBatchSize() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Gets batch size.
getBatchTimeInterval() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Gets batch time interval.
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.
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.cache.query.ContinuousQuery
Gets buffer size.
getBufferSizeRatio() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets the buffer size ratio for this SPI.
getBufferSizeRatio() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets the buffer size ratio for this SPI.
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
getCache(String) - Method in class org.apache.ignite.cache.spring.SpringDynamicCacheManager
getCacheConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configuration (descriptors) for all caches.
getCacheDataDescription() - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
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.
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.
getCacheName() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getCacheName() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets cache name used for key-to-node affinity calculation.
getCacheName() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Gets cache name to be used by this SPI..
getCacheName() - Method in interface org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpiMBean
Gets cache name to be used by this SPI..
getCacheNames() - Method in class org.apache.ignite.cache.CacheManager
getCacheNames() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
getCacheNames() - Method in class org.apache.ignite.cache.spring.SpringDynamicCacheManager
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.
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
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.
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() - Method in interface org.apache.ignite.streamer.StreamerWindowMBean
Gets window class name.
getClassName() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets window class name.
getClockSyncFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets frequency at which clock is synchronized between nodes, in milliseconds.
getClockSyncSamples() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets number of samples used to synchronize clocks between different nodes.
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.
getColumnValue(ResultSet, int, Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
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.
getComparator() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Gets event comparator.
getCompletedTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the approximate total number of tasks that have completed execution.
getConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets configuration bean.
getConfiguration(Class<C>) - Method in interface org.apache.ignite.IgniteCache
getConfigurationPath() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets configuration file path.
getConnectionBufferFlushFrequency() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets connection buffer flush frequency.
getConnectionBufferFlushFrequency() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets connection buffer flush frequency.
getConnectionBufferSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets connection buffer size.
getConnectionBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets connection buffer size.
getConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getConnectTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets connect timeout used when establishing connection with remote nodes.
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.
getContentSummary(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
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.
getCurrentActiveSessions() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets number of current active sessions.
getCurrentBlocks() - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Gets current amount of blocks.
getCurrentBlocks() - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
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.
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
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
 
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
 
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
 
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Gets current queue size.
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicyMBean
Gets current queue size.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Gets current size of data in all blocks.
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
Gets current size of data in all blocks.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Gets current queue size.
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicyMBean
Gets current queue 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.
getDatabaseName() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
getDatabaseSchema() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets database schema name.
getDatabaseTable() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets table name in database.
getDatabaseType() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
getDataCacheName() - Method in class org.apache.ignite.cache.spring.SpringDynamicCacheManager
Sets data cache name.
getDataCacheName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Cache name to store IGFS data.
getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
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.
getDefaultAccessType() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
getDefaultBlockSize() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getDefaultClassLoader() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultLockTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets default lock acquisition timeout.
getDefaultMode() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets mode to specify how IGFS interacts with Hadoop file system, like HDFS.
getDefaultPriority() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets default priority to use if a job does not have priority attribute set.
getDefaultPriority() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets default priority to use if a job does not have priority attribute set.
getDefaultProperties() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultQueryTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets default query timeout.
getDefaultReplication() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
getDefaultTimeToLive() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets time to live for all objects in cache.
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
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.
getDescendingFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets descending-indexed fields.
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.
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.
getDisconnectCheckInterval() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets disconnect check interval.
getDisconnectCheckInterval() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets disconnect check interval.
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.
getDistributionMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache distribution mode.
getDouble(String, double) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getDualModeMaxPendingPutsSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get maximum amount of pending data read from the secondary file system and waiting to be written to data cache.
getDualModePutExecutorService() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get DUAL mode put operation executor service.
getDualModePutExecutorServiceShutdown() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get DUAL mode put operation executor service shutdown flag.
getElementCountInMemory() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getElementCountOnDisk() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getEndTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets end of computation time for the task.
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.
getEvictionQueueSize() - Method in interface org.apache.ignite.streamer.StreamerWindowMBean
Gets estimate for window eviction queue size.
getEvictionQueueSize() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets estimate for window eviction queue size.
getEvictMaxOverflowRatio() - Method in class org.apache.ignite.configuration.CacheConfiguration
This value denotes the maximum size of eviction queue in percents of cache size in case of distributed cache (replicated and partitioned) and using synchronized eviction (that is if CacheConfiguration.isEvictSynchronized() returns true).
getEvictSynchronizedConcurrencyLevel() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets concurrency level for synchronized evictions.
getEvictSynchronizedKeyBufferSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets size of the key buffer for synchronized evictions.
getEvictSynchronizedTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets timeout for synchronized evictions.
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.CacheIgfsPerBlockLruEvictionPolicy
Gets collection of regex for paths whose blocks must not be evicted.
getExcludePaths() - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
Gets collection of regex for paths whose blocks must not be evicted.
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
Gets event time-to-live value.
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
Gets maximum event queue size.
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.
getExternalAddresses(InetSocketAddress) - Method in interface org.apache.ignite.configuration.AddressResolver
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.
getFailuresCount() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets number of failures since last reset.
getFailuresCount() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage failure count.
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
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.
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.
getFilter() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets optional event filter.
getFinishedJobInfoTtl() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets finished job info time-to-live in milliseconds.
getFragmentizerConcurrentFiles() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets number of files that can be processed by fragmentizer concurrently.
getFragmentizerLocalWritesRatio() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets amount of local memory (in % of local IGFS max space size) available for local writes during file creation.
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.
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.
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
Gets grid name.
getGridName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets optional grid name.
getGridStartTime() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets start time of the very first node in the grid.
getGroups() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets group-indexed fields.
getHadoopConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets hadoop configuration.
getHashIdResolver() - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Gets hash ID resolver for nodes.
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.
getHeartbeatFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets delay between heartbeat messages sent by coordinator.
getHeartbeatFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets delay between heartbeat messages sent by coordinator.
getHeartbeatFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets delay between heartbeat messages sent by coordinator.
getHeartbeatFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets delay between heartbeat messages sent by coordinator.
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.igfs.IgfsIpcEndpointConfiguration
Gets the host endpoint is bound to.
getId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets session ID of the task being executed.
getIdleConnectionTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets maximum idle connection time upon which idle connections will be closed.
getIdleConnectionTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum idle connection time upon which idle connections will be closed.
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.
getIgfsThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing outgoing IGFS messages.
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 class org.apache.ignite.spi.IgniteSpiAdapter
Gets Ignite installation home folder (i.e.
getIgniteHome() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets Ignite installation home folder (i.e.
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.
getIndexCustomFunctionClasses() - Method in class org.apache.ignite.configuration.QueryConfiguration
Gets classes with methods annotated by QuerySqlFunction to be used as user-defined functions from SQL queries.
getIndexingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured indexing SPI implementations.
getIndexingSpiName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets name of the SPI to use for indexing.
getInitialQuery() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets initial query.
getInitialScriptPath() - Method in class org.apache.ignite.configuration.QueryConfiguration
Gets script path to be ran against H2 database after opening.
getInstanceName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets optional kernal instance name.
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.
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.TcpClientDiscoverySpi
Gets TcpDiscoveryIpFinder (string representation).
getIpFinderFormatted() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets TcpDiscoveryIpFinder (string representation).
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.
getJavaName() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
getJavaType() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
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.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.
getKey() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
getKey() - Method in class org.apache.ignite.lang.IgniteBiTuple
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.CacheTypeMetadata
Gets key fields.
getKeyFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets key field type for checkpoint table.
getKeyFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets key field type for checkpoint table.
getKeyRange() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets key range.
getKeySize() - Method in interface org.apache.ignite.cache.CacheMetrics
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.
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.CacheTypeMetadata
Gets key type.
getKeyType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Determines the required type of keys for this Cache, if any.
getLargestPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the largest number of threads that have ever simultaneously been in the pool.
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.
getLocalAddress() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets local host address for socket binding.
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.
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.
getLocalNode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets local node.
getLocalNodeId() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Unique identifier for this node within grid.
getLocalNodeId() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets ID of the local node.
getLocalNodeId() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets ID of the local node.
getLocalPort() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets local port for socket binding.
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
Gets maximum number of local ports tried if all previously tried ports are occupied.
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.
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.IgniteJclLogger
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.NullLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Creates new logger with given category based off the current instance.
getLogin() - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
Gets login.
getLong(String, long) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getLongQueryExecutionTimeout() - Method in class org.apache.ignite.configuration.QueryConfiguration
Get long query execution time timeout.
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
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.
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
Should return an instance of marshaller to use in grid.
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.CacheIgfsPerBlockLruEvictionPolicy
Gets maximum allowed amount of blocks.
getMaxBlocks() - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
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.
getMaximumActiveSessions() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets maximum number of active sessions since last reset.
getMaximumBatches() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Gets maximum number of batches can be stored in window.
getMaximumBatches() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Gets maximum number of batches can be stored in window.
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.
getMaximumConcurrentSessions() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets maximum number of concurrent events to be processed by streamer.
getMaximumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage maximum execution time.
getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Gets maximum number of attempts to execute a failed job on another node.
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
Gets maximum number of attempts to execute a failed job on another node.
getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Gets maximum number of attempts to execute a failed job on another node.
getMaximumFailoverAttempts() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets maximum number of failover attempts to try when pipeline execution has failed.
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 interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the maximum allowed number of threads.
getMaximumQueryIteratorCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum number of query iterators that can be stored.
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.
getMaximumSize() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Gets window maximum size.
getMaximumSparsity() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets maximum sparsity.
getMaximumSparsity() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
Gets maximum sparsity.
getMaximumStealingAttempts() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets maximum number of attempts to steal job by another node.
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.
getMaximumWaitingTime() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage maximum waiting time.
getMaxMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets max message processing time.
getMaxMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets max message processing time.
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.
getMaxMissedClientHeartbeats() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets max heartbeats count node can miss without failing client node.
getMaxMissedClientHeartbeats() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets max heartbeats count node can miss without failing client node.
getMaxMissedHeartbeats() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets max heartbeats count node can miss without initiating status check.
getMaxMissedHeartbeats() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets max heartbeats count node can miss without initiating status check.
getMaxOffHeapMemory() - Method in class org.apache.ignite.configuration.QueryConfiguration
Gets maximum amount of memory available to off-heap storage.
getMaxParallelTasks() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets max number of local tasks that may be executed in parallel.
getMaxParamsCnt() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Get max query parameters count.
getMaxParamsCnt() - 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.jdbc.CacheAbstractJdbcStore
Get Max workers thread count.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Gets maximum allowed size of all blocks in bytes.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
Gets maximum allowed size of all blocks in bytes.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSpaceSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get maximum space available for data cache to store file system entries.
getMaxTaskQueueSize() - Method in class org.apache.ignite.configuration.HadoopConfiguration
Gets max task queue size.
getMaxWriteQueueSize() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets max write queue size in bytes.
getMaxWriteQueueSize() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
Gets max write queue size in bytes.
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.
getMemoryMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets memory mode for cache.
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
Message expire time configuration parameter.
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.TcpClientDiscoverySpi
Gets message worker queue current size.
getMessageWorkerQueueSize() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets message worker queue current size.
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.
getMetaCacheName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Cache name 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 job metrics update frequency in milliseconds.
getMinimumBufferedMessageCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets the minimum number of messages for this SPI, that are buffered prior to sending.
getMinimumBufferedMessageCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets the minimum number of messages for this SPI, that are buffered prior to sending.
getMinimumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage minimum execution time.
getMinimumWaitingTime() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage minimum waiting time.
getMinorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
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.
getName() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Cache name.
getName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets IGFS instance name.
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 interface org.apache.ignite.streamer.index.StreamerIndexProvider
Gets index name.
getName() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets index name.
getName() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets streamer name.
getName() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets streamer name.
getName() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage name.
getName() - Method in interface org.apache.ignite.streamer.StreamerWindowMBean
Gets window name.
getName() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets window name.
getNearEvictionPolicy() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets eviction policy for near cache which is different from the one used for partitioned cache.
getNearStartSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
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.TcpClientDiscoverySpi
Gets network timeout.
getNetworkTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets network timeout.
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.TcpClientDiscoverySpi
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.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
Unique identifier for this node within grid.
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 interface org.apache.ignite.logger.LoggerNodeIdAware
Gets node ID.
getNodesFailed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets failed nodes count.
getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets failed nodes count.
getNodesFailed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets failed nodes count.
getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets failed nodes count.
getNodesJoined() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets joined nodes count.
getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets joined nodes count.
getNodesJoined() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets joined nodes count.
getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets joined nodes count.
getNodesLeft() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets left nodes count.
getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets left nodes count.
getNodesLeft() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets left nodes count.
getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets left nodes count.
getNodeStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the start time of grid node in milliseconds.
getNodeStartTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
Returns the start time of grid node in milliseconds.
getNodeWeight() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Gets weight of this node.
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.
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.
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.
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.
getOffHeapMaxMemory() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum amount of memory available to off-heap storage.
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.
getOverflowSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of entries that was swapped to disk.
getOverflowSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of entries that was swapped to disk.
getPageSize() - Method in class org.apache.ignite.cache.query.Query
Gets optional page size, if 0, then CacheQueryConfiguration#getPageSize() is used.
getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets number of jobs that can be executed in parallel.
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.
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcDriver
getPartitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Gets total number of key partitions.
getPassword() - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
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.
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.
getPipelineAverageExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets average number of unique nodes participated in pipeline execution.
getPipelineAverageExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets pipeline average execution time, i.e. time between execution start and time when last stage in pipeline returned empty map.
getPipelineMaximumExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets maximum number of unique nodes participated in pipeline execution.
getPipelineMaximumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets pipeline maximum execution time, i.e. time between execution start and time when last stage in pipeline returned empty map.
getPipelineMinimumExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets minimum number of unique nodes participated in pipeline execution.
getPipelineMinimumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets pipeline minimum execution time, i.e. time between execution start and time when last stage in pipeline returned empty map.
getPluginConfigurations() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getPolicy() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Gets event indexing policy, which defines how events are tracked within an index.
getPolicy() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets event indexing policy, which defines how events are tracked within an index.
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.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.
getPrefetchBlocks() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get number of pre-fetched blocks if specific file's chunk is requested.
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.TcpClientDiscoverySpi
Gets processed messages counts (grouped by type).
getProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets processed messages counts (grouped by type).
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.
getProperties() - Method in class org.apache.ignite.cache.CacheManager
getPropertyInfo(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
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.
getQueryConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets query configuration.
getQueryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getQueryFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets query-enabled fields.
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.
getReadStripesNumber() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets read pool size.
getReadStripesNumber() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
Gets read pool size.
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
Gets size of rebalancing thread pool.
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).
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.TcpClientDiscoverySpi
Gets received messages counts (grouped by type).
getReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets received messages counts (grouped by type).
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.jdbc.TcpDiscoveryJdbcIpFinder
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.
getRejectedExecutionHandlerClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Returns the class name of current rejection handler.
getRemoteFilter() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets remote filter.
getRemoteNodes() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
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.
getResourceClass() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource class.
getResourceClass() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource class.
getResponseWaitTime() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets time in milliseconds IP finder waits for reply to multicast address request.
getRouter() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets streamer event router.
getSearchPath() - Method in class org.apache.ignite.configuration.QueryConfiguration
Gets the optional search path consisting of space names to search SQL schema objects.
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
Gets count of selectors used in TCP server.
getSelectorsCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets count of selectors used in TCP 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.
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.
getSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of non-null values in the cache.
getSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets number of non-null values in the cache.
getSize() - Method in interface org.apache.ignite.streamer.StreamerWindowMBean
Gets current window size.
getSize() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets current window size.
getSizeInMemory() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getSocketReceiveBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets receive buffer size for sockets created or accepted by this SPI.
getSocketReceiveBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets receive buffer size for sockets created or accepted by this SPI.
getSocketSendBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets send buffer size for sockets created or accepted by this SPI.
getSocketSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets send buffer size for sockets created or accepted by this SPI.
getSocketTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets socket timeout.
getSocketTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets socket timeout.
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
Gets socket write timeout for TCP connections.
getSocketWriteTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets socket write timeout for TCP connections.
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.
getSslContextFactory() - 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.
getStageActiveExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets number of stages currently being executed in streamer pool.
getStageClassName() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets stage class name.
getStageFutureMapSize() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets size of stage futures map.
getStages() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets collection of streamer stages.
getStageTotalExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets total number of stages executed since last reset.
getStageWaitingExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets number of event batches currently waiting to be executed.
getStartSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets initial cache size which will be used to pre-create internal hash table after start.
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 class org.apache.ignite.spi.IgniteSpiAdapter
Get start timestamp of this SPI.
getStartTimestamp() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
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 class org.apache.ignite.spi.IgniteSpiAdapter
Gets string presentation of the start timestamp.
getStartTimestampFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets string presentation of the start timestamp.
getStarvationIncrement() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets value to increment job priority by every time a lower priority job gets behind a higher priority job.
getStarvationIncrement() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets value to increment job priority by every time a lower priority job gets behind a higher priority job.
getState() - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Gets state of default grid instance.
getState(String) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Gets state for a given grid instance.
getStatisticsPrintFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets statistics print frequency.
getStatisticsPrintFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets statistics print frequency.
getStealingAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Configuration parameter to enable stealing to/from only nodes that have these attributes set (see ClusterNode.attribute(String) and IgniteConfiguration.getUserAttributes() methods).
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).
getStreamBufferSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Get read/write buffer size for IGFS stream operations in bytes.
getStreamerConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets streamers configurations.
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.
getSwapSpaceSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured swap space SPI implementation.
getSwapSpaceSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets a formatted instance of configured swapspace SPI implementations.
getSystemThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal system messages.
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.
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.
getTextFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
Gets text-indexed fields.
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.streamer.StreamerConfiguration
Gets streamer pool size.
getThreadPriority() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets thread priority.
getThreadPriority() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets thread priority.
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.
getTimeInterval() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Gets window time interval.
getTimeout() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
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.
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.
getTopology() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets a collection of grid nodes IDs.
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.
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.
getTotalExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets total stage execution count since last reset.
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.
getTotalProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets total processed messages count.
getTotalProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets total processed messages count.
getTotalProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets total processed messages count.
getTotalProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets total processed messages count.
getTotalReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Gets total received messages count.
getTotalReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpiMBean
Gets total received messages count.
getTotalReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets total received messages count.
getTotalReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets total received messages count.
getTotalRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of jobs this node rejects during collision resolution operations since node startup.
getTotalRejectedJobs() - Method in interface org.apache.ignite.mxbean.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.
getTransactionConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets transactions configuration.
getTransactionManagerLookupClassName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets class name of transaction manager finder for integration for JEE app servers.
getTrashPurgeTimeout() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Gets maximum timeout awaiting for trash purging in case data cache oversize is detected.
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.
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.
getTypeMetadata() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets collection of type metadata objects.
getTypeResolver() - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
Gets query type resolver.
getUnacknowledgedMessagesBufferSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets maximum number of stored unacknowledged messages per connection to node.
getUnacknowledgedMessagesBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of stored unacknowledged messages per connection to node.
getUpdater() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets index updater.
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 class org.apache.ignite.spi.IgniteSpiAdapter
Gets up-time of this SPI in ms.
getUpTime() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
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 class org.apache.ignite.spi.IgniteSpiAdapter
Gets string presentation of up-time for this SPI.
getUpTimeFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
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.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 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 collection of formatted user-defined attributes added to this node.
getUserObject() - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
Gets user-specific object.
getValue() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
getValue() - Method in class org.apache.ignite.lang.IgniteBiTuple
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.CacheTypeMetadata
Gets value fields.
getValueFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets value field type for checkpoint table.
getValueFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets value field type for checkpoint table.
getValueType() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines the required type of values for this Cache, if any.
getValueType() - Method in class org.apache.ignite.cache.CacheTypeMetadata
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
Maximum number of jobs that are allowed to wait in waiting queue.
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
Gets job count threshold at which this node will start stealing jobs from other nodes.
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.
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.
getWindows() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets collection of streamer event windows.
getWorkDirectory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Ignite work folder.
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.
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.
getWriteBufferSize() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets write buffer size in bytes.
getWriteBufferSize() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
Gets write buffer size in bytes.
getWriteSynchronizationMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets write synchronization mode.
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 - Variable in class org.apache.ignite.cache.spring.SpringCacheManager
Ignite instance.
grid() - Method in interface org.apache.ignite.plugin.PluginContext
 
GRID_CONFIG_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
 
GRID_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
Hibernate L2 cache grid name property name.
GridCache<K,V> - Interface in org.apache.ignite.cache
Main entry point for all Data Grid APIs.
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
 
GridSecurityCredentials - Class in org.apache.ignite.plugin.security
Security credentials used for client or node authentication.
GridSecurityCredentials() - Constructor for class org.apache.ignite.plugin.security.GridSecurityCredentials
Empty constructor required by Externalizable.
GridSecurityCredentials(String, String) - Constructor for class org.apache.ignite.plugin.security.GridSecurityCredentials
Constructs security credentials based on login and password.
GridSecurityCredentials(String, String, Object) - Constructor for class org.apache.ignite.plugin.security.GridSecurityCredentials
Constructs security credentials based on login, password, and custom user object.
GridSecurityCredentialsBasicProvider - Class in org.apache.ignite.plugin.security
Basic implementation for GridSecurityCredentialsProvider.
GridSecurityCredentialsBasicProvider(GridSecurityCredentials) - Constructor for class org.apache.ignite.plugin.security.GridSecurityCredentialsBasicProvider
Constructs security credentials provider based on security credentials passed in.
GridSecurityCredentialsProvider - Interface in org.apache.ignite.plugin.security
Security credentials provider for specifying security credentials.
GridSecurityException - Exception in org.apache.ignite.plugin.security
Common security exception for the grid.
GridSecurityException(String, Throwable) - Constructor for exception org.apache.ignite.plugin.security.GridSecurityException
Constructs security grid exception with given message and cause.
GridSecurityException(Throwable) - Constructor for exception org.apache.ignite.plugin.security.GridSecurityException
Creates new security grid exception given throwable as a cause and source of error message.
GridSecurityException(String) - Constructor for exception org.apache.ignite.plugin.security.GridSecurityException
Constructs security grid exception with given message.
GridSecurityPermission - Enum in org.apache.ignite.plugin.security
Supported security permissions within grid.
GridSecurityPermissionSet - Interface in org.apache.ignite.plugin.security
Security permission set for authorized security subjects.
GridSecuritySubject - Interface in org.apache.ignite.plugin.security
Security subject representing authenticated node or client with a set of permissions.
GridSecuritySubjectType - Enum in org.apache.ignite.plugin.security
Supported security subject types.
GridSegmentationPolicy - Enum in org.apache.ignite.plugin.segmentation
Policy that defines how node will react on topology segmentation.
GridSegmentationResolver - Interface in org.apache.ignite.plugin.segmentation
This is interface for segmentation (a.k.a "split-brain" problem) resolvers.
GridSlf4jLogger - Class in org.apache.ignite.logger.slf4j
SLF4J-based implementation for logging.
GridSlf4jLogger() - Constructor for class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Creates new logger.
GridSlf4jLogger(Logger) - Constructor for class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Creates new logger with given implementation.
groupBlockSize() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file group block size (i.e. block size * group size).
groupSize() - Method in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
 

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
 
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.
HANDSHAKE_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
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.
hashCode() - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
Hash code implementation which delegates to the underlying CacheAffinityKey.key().
hashCode() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
hashCode() - Method in class org.apache.ignite.events.EventAdapter
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.GridSecurityCredentials
hashCode() - Method in class org.apache.ignite.services.ServiceConfiguration
hashCode() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
hashCode() - Method in class org.apache.ignite.spi.swapspace.SwapKey
hashCode() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.Entry
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.
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.
HibernateAbstractRegionAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of L2 cache access strategy delegating to HibernateAccessStrategyAdapter.
HibernateAbstractRegionAccessStrategy(HibernateAccessStrategyAdapter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
 
HibernateAccessStrategyAdapter - Class in org.apache.ignite.cache.hibernate
Common interface used to implement Hibernate L2 cache access strategies (RegionAccessStrategy, EntityRegionAccessStrategy and CollectionRegionAccessStrategy).
HibernateAccessStrategyAdapter(Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
HibernateCollectionRegion - Class in org.apache.ignite.cache.hibernate
Implementation of CollectionRegion.
HibernateCollectionRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>, CacheDataDescription) - Constructor for class org.apache.ignite.cache.hibernate.HibernateCollectionRegion
 
HibernateEntityRegion - Class in org.apache.ignite.cache.hibernate
Implementation of EntityRegion.
HibernateEntityRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>, CacheDataDescription) - Constructor for class org.apache.ignite.cache.hibernate.HibernateEntityRegion
 
HibernateGeneralDataRegion - Class in org.apache.ignite.cache.hibernate
Implementation of GeneralDataRegion.
HibernateGeneralDataRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
 
HibernateNaturalIdRegion - Class in org.apache.ignite.cache.hibernate
Implementation of NaturalIdRegion.
HibernateNaturalIdRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>, CacheDataDescription) - Constructor for class org.apache.ignite.cache.hibernate.HibernateNaturalIdRegion
 
HibernateNonStrictAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of AccessType.NONSTRICT_READ_WRITE cache access strategy.
HibernateNonStrictAccessStrategy(Ignite, GridCache<Object, Object>, ThreadLocal) - Constructor for class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
 
HibernateQueryResultsRegion - Class in org.apache.ignite.cache.hibernate
Implementation of QueryResultsRegion.
HibernateQueryResultsRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateQueryResultsRegion
 
HibernateReadOnlyAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of AccessType.READ_ONLY cache access strategy.
HibernateReadOnlyAccessStrategy(Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
 
HibernateReadWriteAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of AccessType.READ_WRITE cache access strategy.
HibernateReadWriteAccessStrategy(Ignite, GridCache<Object, Object>, ThreadLocal) - Constructor for class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
 
HibernateRegion - Class in org.apache.ignite.cache.hibernate
Implementation of Region.
HibernateRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateRegion
 
HibernateRegionFactory - Class in org.apache.ignite.cache.hibernate
Hibernate L2 cache region factory.
HibernateRegionFactory() - Constructor for class org.apache.ignite.cache.hibernate.HibernateRegionFactory
 
HibernateTimestampsRegion - Class in org.apache.ignite.cache.hibernate
Implementation of TimestampsRegion.
HibernateTimestampsRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateTimestampsRegion
 
HibernateTransactionalAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of AccessType.TRANSACTIONAL cache access strategy.
HibernateTransactionalAccessStrategy(Ignite, GridCache<Object, Object>) - Constructor for class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
 
HibernateTransactionalDataRegion - Class in org.apache.ignite.cache.hibernate
Implementation of TransactionalDataRegion (transactional means that data in the region is updated in connection with database transaction).
HibernateTransactionalDataRegion(HibernateRegionFactory, String, Ignite, GridCache<Object, Object>, CacheDataDescription) - Constructor for class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
 
holdcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Holds (suspends) a given job indefinitely until ComputeJobContinuation.callcc() is called.
holdcc(long) - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Holds (suspends) a given job for specified timeout or until ComputeJobContinuation.callcc() is called.
holdcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Holds (suspends) a given job indefinitely until ComputeJobContinuation.callcc() is called.
holdcc(long) - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Holds (suspends) a given job for specified timeout or until ComputeJobContinuation.callcc() is called.
hostNames() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets collection of host names this node is known by.
hosts() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
Compliant with Hadoop interface.

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.security.GridSecuritySubject
Gets subject ID.
id() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets scheduled task ID.
IGFS_MANAGEMENT - Static variable in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Internal property to indicate management connection.
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.
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).
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(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
Constructs default root path.
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.
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
 
ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Grid.
ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
Grid instance.
ignite() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
ignite() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets instance of grid.
Ignite - Interface in org.apache.ignite
Main entry-point for all Ignite APIs.
ignite() - Static method in class org.apache.ignite.Ignition
Gets an instance of default no-name grid.
ignite(UUID) - Static method in class org.apache.ignite.Ignition
Gets a grid instance for given local node ID.
ignite(String) - Static method in class org.apache.ignite.Ignition
Gets an named grid instance.
ignite() - Method in class org.apache.ignite.messaging.MessagingListenActor
Gets grid instance associated with this actor.
ignite - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
Ignite instance
IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for atomic cache queue delete history.
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_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_CFG_FILE_PATH_PARAM - Static variable in class org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup
Configuration file path parameter name.
IGNITE_COMMUNICATION_BUF_RESIZE_RATIO - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to manage ratio for communication buffer resize.
IGNITE_CONFIG_URL - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold optional configuration URL.
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_DEP_MODE_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override deployment mode configuration parameter.
IGNITE_DISABLE_HOSTNAME_VERIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to disable HostnameVerifier for SSL connections.
IGNITE_EXCEPTION_REGISTRY_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling size of buffer holding last exception.
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_HOME - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines Ignite installation folder.
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_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_LOCAL_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of system property to set system-wide local IP address or host.
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
If this system property is present the Ignite will include grid name into verbose log.
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_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_MIN_BUFFERED_COMMUNICATION_MSG_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to disable buffered communication if node sends less messages count than specified by this property.
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_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_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_OVERRIDE_MCAST_GRP - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override multicast group taken from configuration.
IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag indicating whether performance suggestions output on start should be disabled.
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_REFLECTION_CACHE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override default reflection cache size.
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_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_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_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_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_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_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_WORK_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
Environment variable to set work directory.
IgniteAsyncSupport - Interface in org.apache.ignite.lang
Allows to enable asynchronous mode on Ignite APIs.
IgniteAsyncSupported - Annotation Type in org.apache.ignite.lang
Annotation to indicate that method can be executed asynchronously if async mode is enabled.
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.
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.
IgniteCallable<V> - Interface in org.apache.ignite.lang
Grid-aware adapter for Callable implementations.
IgniteCheckedException - Exception in org.apache.ignite
General grid exception.
IgniteCheckedException() - Constructor for exception org.apache.ignite.IgniteCheckedException
Create empty exception.
IgniteCheckedException(String) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message.
IgniteCheckedException(Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteCheckedException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message and optional nested exception.
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.
IgniteConfiguration - Class in org.apache.ignite.configuration
This class defines grid runtime configuration.
IgniteConfiguration() - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
Creates valid grid configuration with all default values.
IgniteConfiguration(IgniteConfiguration) - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
Creates grid configuration by coping all configuration properties from given configuration.
igniteConfiguration() - Method in interface org.apache.ignite.plugin.PluginContext
 
IgniteCountDownLatch - Interface in org.apache.ignite
This interface provides a rich API for working with distributed count down latch.
IgniteDataStreamer<K,V> - Interface in org.apache.ignite
Data streamer is responsible for streaming external data into cache.
IgniteDataStreamer.Updater<K,V> - Interface in org.apache.ignite
Updates cache with batch of entries.
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.
IgniteEntryProcessor<K,V,T> - Interface in org.apache.ignite.cache
This processor adds Serializable interface to EntryProcessor object.
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.
IgniteFuture<V> - Interface in org.apache.ignite.lang
Extension for standard Future interface.
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
Adapter to use any Hadoop file system FileSystem as IgfsSecondaryFileSystem.
IgniteHadoopIgfsSecondaryFileSystem(String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Simple constructor that is to be used by default.
IgniteHadoopIgfsSecondaryFileSystem(String, String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Constructor.
IgniteHadoopMapReducePlanner - Class in org.apache.ignite.hadoop.mapreduce
Default map-reduce planner implementation.
IgniteHadoopMapReducePlanner() - Constructor for class org.apache.ignite.hadoop.mapreduce.IgniteHadoopMapReducePlanner
 
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.
IgniteImmutable - Annotation Type in org.apache.ignite.cache
If cache configuration flag CacheConfiguration.isCopyOnRead() is set then for each operation implying return value copy of the value stored in cache is created.
IgniteInClosure<E> - Interface in org.apache.ignite.lang
Closure with one in-parameter and void return type.
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.
IgniteJclLogger - Class in org.apache.ignite.logger.jcl
This logger wraps any JCL (Jakarta Commons Logging) loggers.
IgniteJclLogger() - Constructor for class org.apache.ignite.logger.jcl.IgniteJclLogger
Creates new logger.
IgniteJclLogger(Log) - Constructor for class org.apache.ignite.logger.jcl.IgniteJclLogger
Creates new logger with given implementation.
IgniteJdbcDriver - Class in org.apache.ignite
JDBC driver implementation for In-Memory Data Grid.
IgniteJdbcDriver() - Constructor for class org.apache.ignite.IgniteJdbcDriver
 
IgniteLogger - Interface in org.apache.ignite
This interface defines basic logging functionality used throughout the system.
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.
IgniteNotPeerDeployable - Annotation Type in org.apache.ignite.lang
This annotations should be used to mark any type that should not be peer deployable.
IgniteOutClosure<T> - Interface in org.apache.ignite.lang
Closure that does not take any parameters and returns a value.
IgnitePlugin - Interface in org.apache.ignite.plugin
Marker interface for all Ignite plugins.
IgnitePortProtocol - Enum in org.apache.ignite.spi
Protocols supported by port processor.
IgnitePredicate<E> - Interface in org.apache.ignite.lang
Defines a predicate which accepts a parameter and returns true or false.
IgniteProductVersion - Class in org.apache.ignite.lang
Represents node version.
IgniteProductVersion() - Constructor for class org.apache.ignite.lang.IgniteProductVersion
Empty constructor required by Externalizable.
IgniteProductVersion(byte, byte, byte, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
 
IgniteProductVersion(byte, byte, byte, String, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
 
IgniteQueue<T> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed queues based on In-Memory Data Grid.
IgniteReducer<E,R> - Interface in org.apache.ignite.lang
Defines generic reducer that collects multiple values and reduces them into one.
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.
IgniteServices - Interface in org.apache.ignite
Defines functionality necessary to deploy distributed services on the grid.
IgniteServletContextListenerStartup - Class in org.apache.ignite.startup.servlet
This class defines Ignite startup based on servlet context listener.
IgniteServletContextListenerStartup() - Constructor for class org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup
 
IgniteServletStartup - Class in org.apache.ignite.startup.servlet
This class defines servlet-based Ignite startup.
IgniteServletStartup() - Constructor for class org.apache.ignite.startup.servlet.IgniteServletStartup
 
IgniteSet<T> - Interface in org.apache.ignite
Set implementation based on on In-Memory Data Grid.
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.
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.
IgniteSpiNodeValidationResult - Class in org.apache.ignite.spi
Result of joining node validation.
IgniteSpiNodeValidationResult(UUID, String, String) - Constructor for class org.apache.ignite.spi.IgniteSpiNodeValidationResult
 
IgniteSpiNoop - Annotation Type in org.apache.ignite.spi
Annotates NO-OP SPI implementations.
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
 
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 @IgniteSpringApplicationContextResource annotation.
IgniteSpring() - Constructor for class org.apache.ignite.IgniteSpring
 
IgniteSpringBean - Class in org.apache.ignite
Grid 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.
IgniteStreamer - Interface in org.apache.ignite
Streamer interface.
IgniteStripedThreadPoolExecutor - Class in org.apache.ignite.thread
An ExecutorService that executes submitted tasks using pooled grid threads.
IgniteStripedThreadPoolExecutor() - Constructor for class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
 
IgniteSystemProperties - Class in org.apache.ignite
Contains constants for all system properties and environmental variables in Ignite.
IgniteThread - Class in org.apache.ignite.thread
This class adds some necessary plumbing on top of the Thread class.
IgniteThread(GridWorker) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates thread with given worker.
IgniteThread(String, String, Runnable) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given grid.
IgniteThread(ThreadGroup, String, String, Runnable) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given grid with specified thread group.
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, int, int, long, BlockingQueue<Runnable>) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(String, int, int, long, BlockingQueue<Runnable>, RejectedExecutionHandler) - 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.
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.
IgniteWebSessionFilter - Class in org.apache.ignite.cache.websession
Filter for web sessions caching.
IgniteWebSessionFilter() - Constructor for class org.apache.ignite.cache.websession.IgniteWebSessionFilter
 
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.
implicit() - Method in interface org.apache.ignite.transactions.Transaction
Flag indicating whether transaction was started automatically by the system or not.
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.
index() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Gets user view for this index.
index() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets user view for this index.
index() - Method in interface org.apache.ignite.streamer.StreamerWindow
Gets default index, if default index is not configured then IllegalArgumentException will be thrown.
index(String) - Method in interface org.apache.ignite.streamer.StreamerWindow
Gets index by name, if not index with such name was configured then IllegalArgumentException will be thrown.
index() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets default index, if default index is not configured then IllegalArgumentException will be thrown.
index(String) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets index by name, if not index with such name was configured then IllegalArgumentException will be thrown.
index0() - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
index0() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
index0() - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
indexes() - Method in interface org.apache.ignite.streamer.StreamerWindow
Gets all indexes configured for this window.
indexes() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets all indexes configured for this window.
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.
indexKey(E) - Method in interface org.apache.ignite.streamer.index.StreamerIndexUpdater
Given an event, extract index key.
indexProviders() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Get array of index providers.
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 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.IgniteJclLogger
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.NullLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Logs out information message.
init(FilterConfig) - Method in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
init(ServiceContext) - Method in interface org.apache.ignite.services.Service
Pre-initializes service before execution.
init() - Method in class org.apache.ignite.startup.servlet.IgniteServletStartup
initExtensions(PluginContext, ExtensionRegistry) - Method in interface org.apache.ignite.plugin.PluginProvider
Register extensions.
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
initialize() - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
Initializes the index.
initialize() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Initializes the index.
initialize() - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
Initializes the index.
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.
initialValue(E, K) - Method in interface org.apache.ignite.streamer.index.StreamerIndexUpdater
Gets initial value for the index or null if event should be ignored.
injectables() - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
This method returns SPI internal instances that need to be injected as well.
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
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.
internal() - Method in class org.apache.ignite.events.TaskEvent
Returns true if task is created by Ignite and is used for system needs.
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, IgniteEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Invokes an IgniteEntryProcessor against the Entry specified by the provided key.
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>, IgniteEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Invokes an IgniteEntryProcessor against the set of 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
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
isAllSegmentationResolversPassRequired() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets all segmentation resolvers pass required flag.
isAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
 
isAtLeastOnce() - Method in class org.apache.ignite.streamer.StreamerConfiguration
Gets flag indicating whether streamer should track event execution sessions and failover event execution if any failure detected or any node on which execution happened has left the grid before successful response is received.
isAtLeastOnce() - Method in interface org.apache.ignite.streamer.StreamerMBean
Gets atLeastOnce configuration flag.
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.CacheAffinity
Returns true if local node is one of the backup nodes for given key.
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.services.ServiceContext
Get flag indicating whether service has been cancelled or not.
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 a client node.
isClosed() - Method in class org.apache.ignite.cache.CacheManager
isCollocated() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
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.
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.IgniteJclLogger
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.NullLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Tests whether debug level is enabled.
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.
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 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.
isEscapeAll() - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
If true, then table name and all column names in 'create table' SQL generated for SQL engine are escaped with double quotes.
isEventRecordable(int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Checks whether all provided event types are recordable.
isEvictNearSynchronized() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether eviction on primary node is synchronized with near nodes where entry is kept.
isEvictSynchronized() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether eviction is synchronized between primary and backup nodes on partitioned cache.
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.CacheRendezvousAffinityFunction
Checks flag to exclude same-host-neighbors from being backups of each other (default is false).
isExecuting() - Method in interface org.apache.ignite.streamer.StreamerStageMBean
Gets flag indicating if stage is being currently executed by at least one thread on current node.
isFile() - Method in interface org.apache.ignite.igfs.IgfsFile
Check this file is a data file.
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
 
isIndexFixedTyping() - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
This flag essentially controls whether all values of the same type have identical key type.
isIndexPrimitiveKey() - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
Gets flag indicating whether SQL engine should index by key in cases where key is primitive type
isIndexPrimitiveValue() - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
Gets flag indicating whether SQL engine should index by value in cases where value is primitive type
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.IgniteJclLogger
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.NullLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
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.
isLastRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Tells whether last invocation of any of readXXX(...)
isLoadPreviousValue() - Method in class org.apache.ignite.configuration.CacheConfiguration
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.
isLoggable(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
isLongQueryExplain() - Method in class org.apache.ignite.configuration.QueryConfiguration
Gets flag marking SPI should print SQL execution plan for long queries (explain SQL query).
isManagedIgnite(Ignite) - Method in class org.apache.ignite.cache.CacheManager
 
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.
isMinimalPutsEnabledByDefault() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
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.
isolation() - Method in interface org.apache.ignite.transactions.Transaction
Cache transaction isolation level.
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.
isPerTask() - 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.
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.
isPrimary(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Returns true if given node is the primary node for given key.
isPrimaryOrBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Returns true if local node is primary or one of the backup nodes This method is essentially equivalent to calling "CacheAffinity.isPrimary(org.apache.ignite.cluster.ClusterNode, Object) || CacheAffinity.isBackup(org.apache.ignite.cluster.ClusterNode, Object))", however it is more efficient as it makes both checks at once.
isQueryIndexEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating whether Ignite should attempt to index value and/or key instances stored in cache.
isQuiet() - Method in interface org.apache.ignite.IgniteLogger
Tests whether info and debug levels are turned off.
isQuiet() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether info and debug levels are turned off.
isQuiet() - Method in class org.apache.ignite.logger.jcl.IgniteJclLogger
Tests whether info and debug levels are turned off.
isQuiet() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Tests whether info and debug levels are turned off.
isQuiet() - Method in class org.apache.ignite.logger.NullLogger
Tests whether info and debug levels are turned off.
isQuiet() - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Tests whether info and debug levels are turned off.
isReadFromBackup() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether data can be read from backup.
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.
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.
isSame(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
Checks if paths are identical.
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.ThreadPoolMXBean
Returns true if this executor has been shut down.
isShutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
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
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
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.
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.
isSubDirectoryOf(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
Checks whether this path is a sub-directory of argument.
isSupported(OptionalFeature) - Method in class org.apache.ignite.cache.CachingProvider
isSwapEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating whether Ignite should use swap storage by default.
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.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.IgniteJclLogger
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.NullLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Tests whether trace level is enabled.
isTransactionAware() - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
isTxSerializableEnabled() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets flag to enable/disable TransactionIsolation.SERIALIZABLE isolation level for cache transactions.
isUnique() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Checks whether this index is unique or not.
isUnique() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Checks whether this index is unique or not.
isUnique() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Gets window unique flag.
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.
isUseOptimizedSerializer() - Method in class org.apache.ignite.configuration.QueryConfiguration
The flag indicating that serializer for H2 database will be set to Ignite's marshaller.
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
Checks whether node weights are considered when doing random load balancing.
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.GridSegmentationResolver
Checks whether segment is valid.
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 interface org.apache.ignite.IgniteQueue
iterator() - Method in interface org.apache.ignite.IgniteSet
iterator() - Method in class org.apache.ignite.lang.IgniteBiTuple
iterator() - Method in class org.apache.ignite.lang.IgniteUuid
iterator() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
iterator0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Returns an iterator over a set of elements of type T without check for iteration limit.
iterator0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Returns an iterator over a set of elements of type T without check for iteration limit.
iterator0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Returns an iterator over a set of elements of type T without check for iteration limit.
iterator0() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Returns an iterator over a set of elements of type T without check for iteration limit.
iterator0() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Returns an iterator over a set of elements of type T without check for iteration limit.
iteratorInternal(Collection<StreamerBoundedSizeSortedWindow.Holder<E>>, Set<E>, AtomicInteger) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Creates iterator based on implementation collection type.
iteratorInternal(Collection<E>, Set<E>, AtomicInteger) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
Creates iterator based on implementation collection type.

J

JavaLogger - Class in org.apache.ignite.logger.java
Logger to use with Java logging.
JavaLogger() - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger.
JavaLogger(boolean) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger.
JavaLogger(Logger) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger with given implementation.
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
 
jcache(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCache API.
jcache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCache API.
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
JdbcDialect - Interface in org.apache.ignite.cache.store.jdbc.dialect
Represents a dialect of SQL implemented by a particular RDBMS.
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
 
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.
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.

K

key() - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
Gets wrapped key.
key(K) - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
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.
key() - Method in class org.apache.ignite.spi.swapspace.SwapKey
 
key() - Method in interface org.apache.ignite.streamer.index.StreamerIndexEntry
Gets index entry key.
key() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.Entry
Gets index entry key.
keyBytes() - Method in class org.apache.ignite.spi.swapspace.SwapKey
 
keyBytes(byte[]) - Method in class org.apache.ignite.spi.swapspace.SwapKey
 
keyColumns() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Gets key columns.
keyIndex() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.Entry
 
keyIterator(String, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets iterator over space keys.
keyIterator(String, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets iterator over space keys.
keyIterator(String, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets iterator over space keys.
keySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
keySet(int) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only set of index keys.
keySet(V) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only set of index keys with given value.
keySet(boolean, V, boolean, V, boolean) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only set of index keys within given value range.
keyType() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Key type.
keyTypeId(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Extract key type id from key object.
keyTypeId(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Extract key type id from key class name.
keyTypeId(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Extract key type id from key object.
keyTypeId(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Extract key type id from key class name.
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.

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.
lastEntry() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets last entry in the index.
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.scheduler.SchedulerFuture
Gets start time of last execution (0 if never started).
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.
LifecycleAware - Interface in org.apache.ignite.lifecycle
All components provided in Ignite configuration can implement this interface.
LifecycleBean - Interface in org.apache.ignite.lifecycle
A bean that reacts to node lifecycle events defined in LifecycleEventType.
LifecycleEventType - Enum in org.apache.ignite.lifecycle
Node lifecycle event types.
listen(IgniteInClosure<? super IgniteFuture<V>>) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers 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 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 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.hibernate.CacheHibernateBlobStore
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.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.jdbc.CacheAbstractJdbcStore
Loads all values from underlying persistent storage.
loadCache(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
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 select count query.
loadCacheRangeQuery(String, Collection<String>, Iterable<String>, boolean, boolean) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct select count query.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct select count query.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct select count query.
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.
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.
localClear(K) - Method in interface org.apache.ignite.IgniteCache
Clear entry from the cache and swap storage, without notifying listeners or CacheWriters.
localClearAll(Set<K>) - Method in interface org.apache.ignite.IgniteCache
Clear entries from the cache and swap storage, without notifying listeners or CacheWriters.
LocalDeploymentSpi - Class in org.apache.ignite.spi.deployment.local
Local deployment SPI that implements only within VM deployment on local node via LocalDeploymentSpi.register(ClassLoader, Class) method.
LocalDeploymentSpi() - Constructor for class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
 
LocalDeploymentSpiMBean - Interface in org.apache.ignite.spi.deployment.local
Management MBean for LocalDeploymentSpi SPI.
localDeployTask(Class<? extends ComputeTask>, ClassLoader) - Method in interface org.apache.ignite.IgniteCompute
Explicitly deploys a task with given class loader on the local node.
localEntries(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
 
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.
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.
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<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.
localNode() - Method in interface org.apache.ignite.IgniteCluster
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.
localOrder() - Method in interface org.apache.ignite.events.Event
Gets locally unique ID that is atomically incremented for each event.
localOrder() - Method in class org.apache.ignite.events.EventAdapter
Gets locally unique ID that is atomically incremented for each event.
localPeek(K, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Peeks at in-memory cached value using default GridCachePeekMode.SMART peek mode.
localPromote(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
This method unswaps cache entries by given keys, if any, from swap storage into memory.
localQuery(Query) - Method in interface org.apache.ignite.IgniteCache
Queries cache locally.
localQuery(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Queries local node for events using passed-in predicate filter for event selection.
localQueryFields(SqlFieldsQuery) - Method in interface org.apache.ignite.IgniteCache
Queries separate entry fields locally.
localSize(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this nodes.
localSpace() - Method in interface org.apache.ignite.streamer.StreamerContext
Gets streamer local space.
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 .
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) - 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.
lockAll(Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Creates a Lock instance associated with passed keys.
lockId() - Method in class org.apache.ignite.events.CacheEvent
ID of the lock if held or null if no lock held.
lockIndexKey(StreamerIndexProviderAdapter.IndexKey<V>, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Lock updates on particular key.
lockItem(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
lockRegion() - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
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.
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() - 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.PluginContext
Gets logger for given class.
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.GridSecuritySubject
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.

M

main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
Main method.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineStartup
Main entry point.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
Main method being triggered in step 3 of the Workaround.
maintenance() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets maintenance version number.
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(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.CacheAffinity
This method provides ability to detect which keys are mapped to which nodes.
mapKeysToNodes(String, Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCluster
This method provides ability to detect which cache keys are mapped to which nodes on cache instance with given name.
mapKeyToNode(K) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
This method provides ability to detect to which primary node the given key is mapped.
mapKeyToNode(String, K) - Method in interface org.apache.ignite.IgniteCluster
This method provides ability to detect which cache keys are mapped to which nodes on cache instance with given name.
mapKeyToPrimaryAndBackups(K) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets primary and backup nodes for the key.
mapPartitionsToNodes(Collection<Integer>) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets primary nodes for the given partitions.
mapPartitionToNode(int) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets primary node for the given partition.
mapPartitionToPrimaryAndBackups(int) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets primary and backup nodes for partition.
marshal(Object) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
Marshals object to byte array.
marshal(Object, OutputStream) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
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.
marshal(Object, OutputStream) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Marshals object to the output stream.
marshal(Object) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Marshals object to byte array.
Marshaller - Interface in org.apache.ignite.marshaller
GridMarshaller allows to marshal or unmarshal objects in grid.
MarshallerContext - Interface in org.apache.ignite.marshaller
Marshaller context.
MarshallerExclusions - Class in org.apache.ignite.marshaller
Controls what classes should be excluded from marshalling by default.
MAX_ATTEMPT_WRITE_COUNT - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Max attempt write count.
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_STEALING_ATTEMPT_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Maximum stealing attempts attribute name.
maximumActiveSessions() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets maximum number of active sessions since last reset.
maximumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage maximum execution time.
maximumTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets maximum execution time of query.
maximumWaitingTime() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage maximum waiting time.
maxParamsCnt - Variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Max query parameters 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.
MBeanServerResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of MBeanServer resource.
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.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
Construct merge query.
message() - Method in 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 functionality over this grid projection.
message(ClusterGroup) - Method in interface org.apache.ignite.Ignite
 
message() - Method in class org.apache.ignite.IgniteSpringBean
Gets messaging functionality over this grid projection.
message(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Message - Interface in org.apache.ignite.plugin.extensions.communication
Base class for all communication messages.
message() - Method in class org.apache.ignite.spi.IgniteSpiNodeValidationResult
 
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.
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.
meta(UUID) - Method in interface org.apache.ignite.transactions.Transaction
Gets metadata by name.
metrics() - Method in interface org.apache.ignite.cache.GridCache
Gets metrics (statistics) for this cache.
metrics() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a metrics snapshot for this projection.
metrics() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets metrics snapshot for this node.
metrics() - Method in interface org.apache.ignite.IgniteCache
Gets snapshot metrics (statistics) for this cache.
metrics() - Method in interface org.apache.ignite.IgniteFileSystem
Gets metrics snapshot for this file system.
metrics() - Method in interface org.apache.ignite.IgniteStreamer
Gets current streamer metrics.
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.
minimumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage minimum execution time.
minimumTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets minimum execution time of query.
minimumWaitingTime() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage minimum waiting time.
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 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(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Resolve path mode.
mode(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Resolve path mode.
mode(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
Resolve path mode.
model() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
 
modificationTime() - Method in interface org.apache.ignite.igfs.IgfsFile
Gets file last modification time.
MSG_EXPIRE_TIME_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Stealing request expiration time attribute name.
mtdsCache - Variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Methods cache.
mxBean() - Method in interface org.apache.ignite.cache.GridCache
Gets metrics (statistics) for this cache.
mxBean() - Method in interface org.apache.ignite.IgniteCache
Gets 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.cache.CacheMetrics
Gets name of this 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 grid this grid instance (and correspondingly its local node) belongs to.
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.IgniteCountDownLatch
Gets name of the latch.
name() - Method in interface org.apache.ignite.IgniteFileSystem
Gets IGFS name.
name() - Method in interface org.apache.ignite.IgniteQueue
Gets queue name.
name() - Method in interface org.apache.ignite.IgniteSet
Gets set name.
name() - Method in class org.apache.ignite.IgniteSpringBean
Gets the name of the grid this grid instance (and correspondingly its local node) belongs to.
name() - Method in interface org.apache.ignite.IgniteStreamer
Gets streamer name.
name() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Gets name of this cache.
name() - Method in interface org.apache.ignite.plugin.PluginProvider
 
name() - Method in interface org.apache.ignite.services.ServiceContext
Gets service name.
name() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service name.
name() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Index name.
name() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Index name.
name() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderMBean
Index name.
name() - Method in interface org.apache.ignite.streamer.StreamerStage
Gets streamer stage name.
name() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets stage name.
name() - Method in interface org.apache.ignite.streamer.StreamerWindow
Gets window name.
name() - Method in interface org.apache.ignite.streamer.StreamerWindowMetrics
Gets window name.
name() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Gets window 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.
nestedCauses() - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
Gets nested causes for this multi-exception.
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.
newCollection() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Creates new collection specific for window implementation.
newCollection() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
Creates new collection specific for window implementation.
newEntry(K, V, StreamerIndexProviderAdapter.IndexKey<V>, E) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
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.
nextKey(V) - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
 
nextStageName() - Method in interface org.apache.ignite.streamer.StreamerContext
For context passed to StreamerStage.run(StreamerContext, Collection) this method will return next stage name in execution pipeline.
nextTimestamp() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
nextTimestamp() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
node(UUID) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a node for given ID from this grid projection.
node() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets first node from the list of nodes in this projection.
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").
nodeId(UUID) - 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.IgniteSpiNodeValidationResult
 
nodeId() - Method in interface org.apache.ignite.transactions.Transaction
ID of the node on which this transaction started.
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.
nodes() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets read-only collections of nodes in this projection.
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.
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
 
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
 
NoopSwapSpaceSpi - Class in org.apache.ignite.spi.swapspace.noop
No-op implementation of SwapSpaceSpi.
NoopSwapSpaceSpi() - Constructor for class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
 
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
 

O

offer(T) - Method in interface org.apache.ignite.IgniteQueue
offer(T, long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
offHeapAllocatedSize() - Method in interface org.apache.ignite.cache.GridCache
Gets memory size allocated in off-heap.
offHeapEntriesCount() - Method in interface org.apache.ignite.cache.GridCache
Gets number of cache entries stored in off-heap memory.
offHeapIterator() - Method in interface org.apache.ignite.cache.GridCache
Gets iterator over keys and values belonging to this cache off-heap memory on local node.
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).
onAdded(StreamerIndexEntry<E, K, V>, E) - Method in interface org.apache.ignite.streamer.index.StreamerIndexUpdater
Callback invoked whenever an event is being added to the window.
onAfterPut(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called after new value has been stored.
onAfterPut(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called after new value has been stored.
onAfterRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called after value has been removed.
onAfterRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called after value has been removed.
onAttributeSet(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSessionAttributeListener
Called on attribute change (set or update).
onBeforePut(Cache.Entry<K, V>, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.put(Object, Object) and similar operations before new value is stored in cache.
onBeforePut(Cache.Entry<K, V>, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.put(Object, Object) and similar operations before new value is stored in cache.
onBeforeRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.remove(Object) and similar operations to provide control over returned value.
onBeforeRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.remove(Object) and similar operations to provide control over returned value.
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.
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 when either new grid job arrived or executing job finished its execution.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
This is a callback called when either new grid job arrived or executing job finished its execution.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This is a callback called when either new grid job arrived or executing job finished its execution.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
This is a callback called when either new grid job arrived or executing job finished its execution.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This is a callback called when either new grid job arrived or executing job finished its execution.
onConnected() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
Will be executed on Visor connect to grid.
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>>, Serializable) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
Notification for grid node discovery events.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in interface org.apache.ignite.cache.eviction.CacheEvictionPolicy
Callback for whenever entry is accessed.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Callback for whenever entry is accessed.
onEntryAccessed(boolean, EvictableEntry<IgfsBlockKey, byte[]>) - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Callback for whenever entry is accessed.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Callback for whenever entry is accessed.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy
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.
onEventsChanged() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
Will be executed on Visor events changed.
onExchange(UUID, Map<Integer, Object>) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
Notifies discovery manager about data received from remote node.
onExternalCollision() - Method in interface org.apache.ignite.spi.collision.CollisionExternalListener
Callback invoked by Collision SPI whenever an external collision event occurs.
onFailure(String, Collection<Object>, Throwable) - Method in interface org.apache.ignite.streamer.StreamerFailureListener
Callback invoked when unrecoverable failure is detected by streamer.
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.PluginProvider
Callback that notifies that Ignite has successfully started, including all internal components.
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.
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.
onReceive(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
onRemoved(StreamerIndexEntry<E, K, V>, E) - Method in interface org.apache.ignite.streamer.index.StreamerIndexUpdater
Callback invoked whenever an event is being removed from the window and has index entry for given key.
onSend(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
onSpiContextDestroyed() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onSpiContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onStateChange(String, IgniteState) - Method in interface org.apache.ignite.IgnitionListener
Listener for grid factory state change notifications.
onStateChanged(TransactionState, TransactionState, Transaction) - Method in interface org.apache.ignite.transactions.TransactionSynchronization
State change callback for transaction.
onSwap(String, Object) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
Will be called when entry with given key is swapped.
onSwap(String, Object) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Will be called when entry with given key is swapped.
onSwapEvent(int, String, byte[]) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpiListener
Notification for swap space events.
onUndeploy(ClassLoader) - Static method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
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..
onUnswap(String, Object, Object) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
Will be called when entry with given key is unswapped.
onUnswap(String, Object, Object) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Will be called when entry with given key is unswapped.
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) - 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.
OptimizedMarshaller - Class in org.apache.ignite.marshaller.optimized
Optimized implementation of Marshaller.
OptimizedMarshaller() - Constructor for class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Creates new marshaller will all defaults.
OptimizedMarshaller(boolean) - Constructor for class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Creates new marshaller providing whether it should require Serializable interface or not.
OptimizedMarshallerIdMapper - Interface in org.apache.ignite.marshaller.optimized
ID mapper.
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
 
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.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.fair - package org.apache.ignite.cache.affinity.fair
Contains fair cache affinity for partitioned cache.
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.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.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
 
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.hibernate - package org.apache.ignite.cache.store.hibernate
Contains reference Hibernate-based cache store implementation.
org.apache.ignite.cache.store.jdbc - package org.apache.ignite.cache.store.jdbc
Contains reference JDBC-based cache store implementation.
org.apache.ignite.cache.store.jdbc.dialect - package org.apache.ignite.cache.store.jdbc.dialect
Contains SQL dialects for different RDBMS.
org.apache.ignite.cache.websession - package org.apache.ignite.cache.websession
Contains classes for Web Sessions Caching.
org.apache.ignite.cluster - package org.apache.ignite.cluster
 
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
 
org.apache.ignite.events - package org.apache.ignite.events
Contains Event Subscription functionality together with various events emitted by Ignite.
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.mapreduce - package org.apache.ignite.hadoop.mapreduce
Ignite Hadoop Accelerator map-reduce 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.
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
 
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.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.marshaller.optimized - package org.apache.ignite.marshaller.optimized
Contains default Optimized marshaller.
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.plugin - package org.apache.ignite.plugin
 
org.apache.ignite.plugin.extensions.communication - package org.apache.ignite.plugin.extensions.communication
Contains extendable components for communication.
org.apache.ignite.plugin.security - package org.apache.ignite.plugin.security
Contains APIs for security, authentication, and authorization.
org.apache.ignite.plugin.segmentation - package org.apache.ignite.plugin.segmentation
Contains segmentation "split-brain" related classes.
org.apache.ignite.resources - package org.apache.ignite.resources
Contains resource injection annotations.
org.apache.ignite.scheduler - package org.apache.ignite.scheduler
Contains Job Scheduling functionality.
org.apache.ignite.services - package org.apache.ignite.services
Contains main Managed Services APIs.
org.apache.ignite.spi - package org.apache.ignite.spi
Contains common classes and interfaces for SPI implementations.
org.apache.ignite.spi.checkpoint - package org.apache.ignite.spi.checkpoint
Contains APIs for checkpoint SPI.
org.apache.ignite.spi.checkpoint.cache - package org.apache.ignite.spi.checkpoint.cache
Contains cache-based implementation for checkpoint SPI.
org.apache.ignite.spi.checkpoint.jdbc - package org.apache.ignite.spi.checkpoint.jdbc
Contains JDBC implementation for checkpoint SPI.
org.apache.ignite.spi.checkpoint.noop - package org.apache.ignite.spi.checkpoint.noop
Contains default no-op checkpoint SPI implementation.
org.apache.ignite.spi.checkpoint.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.jdbc - package org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Contains JDBC 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.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
 
org.apache.ignite.spi.loadbalancing - package org.apache.ignite.spi.loadbalancing
Contains APIs for load balancing SPI.
org.apache.ignite.spi.loadbalancing.adaptive - package org.apache.ignite.spi.loadbalancing.adaptive
Contains adaptive load balancing SPI.
org.apache.ignite.spi.loadbalancing.roundrobin - package org.apache.ignite.spi.loadbalancing.roundrobin
Contains default round-robin implementation for load balancing SPI.
org.apache.ignite.spi.loadbalancing.weightedrandom - package org.apache.ignite.spi.loadbalancing.weightedrandom
Contains weighted random-base implementation for load balancing SPI.
org.apache.ignite.spi.swapspace - package org.apache.ignite.spi.swapspace
Contains APIs for swap space SPI.
org.apache.ignite.spi.swapspace.file - package org.apache.ignite.spi.swapspace.file
Contains file-based swap space SPI.
org.apache.ignite.spi.swapspace.noop - package org.apache.ignite.spi.swapspace.noop
Contains default no-op swap space SPI implementation.
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.streamer - package org.apache.ignite.streamer
Contains main Streaming APIs.
org.apache.ignite.streamer.index - package org.apache.ignite.streamer.index
Contains APIs for indexing of streamer windows.
org.apache.ignite.streamer.index.hash - package org.apache.ignite.streamer.index.hash
Contains hash-based streamer index implementation.
org.apache.ignite.streamer.index.tree - package org.apache.ignite.streamer.index.tree
Contains tree-based streamer index implementation.
org.apache.ignite.streamer.router - package org.apache.ignite.streamer.router
Contains streamer event router implementations.
org.apache.ignite.streamer.window - package org.apache.ignite.streamer.window
Contains streamer window implementations.
org.apache.ignite.thread - package org.apache.ignite.thread
Contains threads-related utility classes.
org.apache.ignite.transactions - package org.apache.ignite.transactions
 
org.apache.ignite.visor.plugin - package org.apache.ignite.visor.plugin
Contains Visor Plugin extension functionality.
originNodeId() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets ID of grid node that initiated the service deployment.
overflowSize() - Method in interface org.apache.ignite.cache.GridCache
Gets size (in bytes) of all entries swapped to disk.

P

PARAM_NODE_ID - Static variable in class org.apache.ignite.IgniteJdbcDriver
Node ID URL parameter name.
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.
partition(K) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets partition id for the given key.
partition(Object) - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunction
Gets partition number for a given key starting from 0.
partition(Object) - Method in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Gets partition number for a given key starting from 0.
partition(Object) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
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(String, Object) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Calculates partition number for given key.
partition() - Method in class org.apache.ignite.spi.swapspace.SwapKey
 
partitions() - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets number of partitions in cache according to configured affinity function.
partitions() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunction
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Gets total number of partitions available.
partitions(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets partitions IDs that are stored in the passed in space.
partitions(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets partitions IDs that are stored in the passed in space.
partitions(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets partitions IDs that are stored in the passed in space.
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.GridSecuritySubject
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 update operations for a single node.
perNodeParallelOperations(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets maximum number of parallel update operations for a single node.
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.TcpClientDiscoverySpi
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.
pipelineAverageExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets average number of unique nodes participated in pipeline execution.
pipelineAverageExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets pipeline average execution time, i.e. time between execution start and time when last stage in pipeline returned empty map.
pipelineMaximumExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets maximum number of unique nodes participated in pipeline execution.
pipelineMaximumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets pipeline maximum execution time, i.e. time between execution start and time when last stage in pipeline returned empty map.
pipelineMinimumExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets minimum number of unique nodes participated in pipeline execution.
pipelineMinimumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets pipeline minimum execution time, i.e. time between execution start and time when last stage in pipeline returned empty map.
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
TODO: Add class description.
PluginContext - Interface in org.apache.ignite.plugin
TODO: Add class description.
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.
policy() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets index policy.
policy() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets index policy.
policy() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderMBean
Gets index policy.
poll() - Method in interface org.apache.ignite.IgniteQueue
poll(long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
pollEvicted() - Method in interface org.apache.ignite.streamer.StreamerWindow
If window supports eviction, this method will return next evicted element.
pollEvicted(int) - Method in interface org.apache.ignite.streamer.StreamerWindow
If window supports eviction, this method will return up to cnt evicted elements.
pollEvicted() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
If window supports eviction, this method will return next evicted element.
pollEvicted(int) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
If window supports eviction, this method will return up to cnt evicted elements.
pollEvicted0(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
If window supports eviction, this method will return up to cnt evicted elements.
pollEvicted0(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
If window supports eviction, this method will return up to cnt evicted elements.
pollEvicted0(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
If window supports eviction, this method will return up to cnt evicted elements.
pollEvicted0(int) - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
If window supports eviction, this method will return up to cnt evicted elements.
pollEvicted0(int) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
If window supports eviction, this method will return up to cnt evicted elements.
pollEvictedAll() - Method in interface org.apache.ignite.streamer.StreamerWindow
If window supports eviction, this method will return all available evicted elements.
pollEvictedAll() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
If window supports eviction, this method will return all available evicted elements.
pollEvictedBatch() - Method in interface org.apache.ignite.streamer.StreamerWindow
If window supports batch eviction, this method will poll next evicted batch from window.
pollEvictedBatch() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
If window supports batch eviction, this method will poll next evicted batch from window.
pollEvictedBatch0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
If window supports batch eviction, this method will poll next evicted batch from window.
pollEvictedBatch0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
If window supports batch eviction, this method will poll next evicted batch from window.
pollEvictedBatch0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
If window supports batch eviction, this method will poll next evicted batch from window.
pollEvictedBatch0() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
If window supports batch eviction, this method will poll next evicted batch from window.
pollEvictedBatch0() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
If window supports batch eviction, this method will poll next evicted batch from window.
pollInternal(Collection<StreamerBoundedSizeSortedWindow.Holder<E>>, Set<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
pollInternal(Collection<E>, Set<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
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 projection.
prepareBuilders(String, Collection<CacheTypeMetadata>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Prepare internal store specific builders for provided types metadata.
prepareBuilders(String, Collection<CacheTypeMetadata>) - 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 class org.apache.ignite.hadoop.mapreduce.IgniteHadoopMapReducePlanner
Prepares map-reduce execution plan for the given job and topology.
previousAssignment(int) - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunctionContext
Gets affinity assignment for given partition on previous topology version.
primaryPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.CacheAffinity
Gets partition ids for which nodes of the given projection has primary ownership.
printLastErrors() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Prints errors.
printStackTrace(PrintStream) - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
PriorityQueueCollisionSpi - Class in org.apache.ignite.spi.collision.priorityqueue
This class provides implementation for Collision SPI based on priority queue.
PriorityQueueCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
 
PriorityQueueCollisionSpiMBean - Interface in org.apache.ignite.spi.collision.priorityqueue
Management bean that provides access to the priority queue collision SPI configuration.
processingMessage(boolean) - Method in class org.apache.ignite.thread.IgniteThread
 
processingMessage() - Method in class org.apache.ignite.thread.IgniteThread
 
projection() - Method in interface org.apache.ignite.streamer.StreamerContext
Gets instance of dynamic grid projection including all nodes on which this streamer is running.
PROP_CACHE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Cache name property name.
PROP_HOST - Static variable in class org.apache.ignite.IgniteJdbcDriver
Hostname 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.
properties() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Gets current session properties.
properties() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
Gets the implementation specific properties of file system.
properties() - Method in interface org.apache.ignite.igfs.IgfsFile
Get properties of the file.
properties() - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
Gets the implementation specific properties of file system.
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.
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.
providerClass() - Method in interface org.apache.ignite.plugin.PluginConfiguration
 
publish(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
put(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
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.
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
putFromLoad(Object, Object, long, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
putFromLoad(Object, Object, long, Object, boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
putFromLoad(Object, Object, boolean) - 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.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(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.
putMetaIfAbsent(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Adds given metadata value only if it was absent.

Q

Query<T extends Query> - Class in org.apache.ignite.cache.query
Base class for all Ignite cache queries.
query(Query) - Method in interface org.apache.ignite.IgniteCache
Queries cache.
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(IgniteClosure<StreamerContext, R>) - Method in interface org.apache.ignite.streamer.StreamerContext
Queries all streamer nodes deployed within grid.
query(IgniteClosure<StreamerContext, R>, Collection<ClusterNode>) - Method in interface org.apache.ignite.streamer.StreamerContext
Queries streamer nodes deployed within grid.
queryAverageExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets average number of unique nodes participated in query execution.
queryAverageExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets query average execution time.
QueryConfiguration - Class in org.apache.ignite.configuration
Configuration for embedded indexing facilities.
QueryConfiguration() - Constructor for class org.apache.ignite.configuration.QueryConfiguration
 
QueryCursor<T> - Interface in org.apache.ignite.cache.query
Query result cursor.
queryFields(SqlFieldsQuery) - Method in interface org.apache.ignite.IgniteCache
Queries separate entry fields.
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.
queryMaximumExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets maximum number of unique nodes participated in query execution.
queryMaximumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets query maximum execution time.
QueryMetrics - Interface in org.apache.ignite.cache.query
Cache query metrics used to obtain statistics on query.
queryMinimumExecutionNodes() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets minimum number of unique nodes participated in query execution.
queryMinimumExecutionTime() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets query minimum execution time.
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 or getters to be indexed for full text search using Lucene.
queryType() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query type.
queryType() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query type.
QueryTypeResolver - Interface in org.apache.ignite.cache.query
Interface allowing to override table name for portable objects stored in cache.
queue() - Method in class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Gets read-only view on internal FIFO queue in proper order.
queue() - Method in class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Gets read-only view on internal FIFO 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

randomEntry() - Method in interface org.apache.ignite.cache.GridCache
Gets a random entry out of cache.
randomEntry() - Method in interface org.apache.ignite.IgniteCache
Gets a random entry out of cache.
randomUuid() - Static method in class org.apache.ignite.lang.IgniteUuid
Creates new pseudo-random ID.
rawEvents() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.DedupTrackingEntry
 
rawIterator(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets raw iterator over space entries.
rawIterator(String, int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets raw iterator over space entries.
rawIterator(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets raw iterator over space entries.
rawIterator(String, int) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets raw iterator over space entries.
rawIterator(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets raw iterator over space entries.
rawIterator(String, int) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets raw iterator over space entries.
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.
read(String, SwapKey, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Reads stored value as array of bytes by key from data space with given name.
read(String, SwapKey, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Reads stored value as array of bytes by key from data space with given name.
read(String, SwapKey, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Reads stored value as array of bytes by key from data space with given name.
readAll(String, Iterable<SwapKey>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Reads stored values as array of bytes by all passed keys from data space with given name.
readAll(String, Iterable<SwapKey>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Reads stored values as array of bytes by all passed keys from data space with given name.
readAll(String, Iterable<SwapKey>, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Reads stored values as array of bytes by all passed keys from data space with given name.
readBitSet(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads BitSet.
readBoolean(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads boolean value.
readBooleanArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads boolean array.
readByte(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads byte value.
readByteArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads byte array.
readChar(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads char value.
readCharArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads char array.
readCollection(String, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads collection.
readDouble(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads double value.
readDoubleArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads double array.
reader(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.CacheAffinityKey
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
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.plugin.security.GridSecurityCredentials
readFloat(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads float value.
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.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.
readFromSwap(String, SwapKey, ClassLoader) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Reads object from swap.
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(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int value.
readIntArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int array.
readLock() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
readLong(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads long value.
readLongArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads long array.
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.
readObjectArray(String, MessageCollectionItemType, Class<T>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads array of objects.
readShort(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads short value.
readShortArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads short array.
readString(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads String.
readUnlock() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
readUuid(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads UUID.
readValueFromOffheapAndSwap(String, Object, ClassLoader) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Reads swapped cache value from off-heap and swap.
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.
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, Object) - Method in interface org.apache.ignite.plugin.PluginProvider
Receives plugin discovery data object from remote nodes (called on new node during discovery process).
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.
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
 
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.
reduce(IgniteClosure<StreamerContext, R1>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.streamer.StreamerContext
Queries all streamer nodes deployed within grid.
reduce(IgniteClosure<StreamerContext, R1>, IgniteReducer<R1, R2>, Collection<ClusterNode>) - Method in interface org.apache.ignite.streamer.StreamerContext
Queries streamer nodes deployed within grid.
reducerNodeWeight(ClusterNode, int) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopMapReducePlanner
Calculate node weight based on node metrics and data co-location.
refreshJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Refreshes collection of job siblings.
REG_ADDR_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Query to register address.
REGION_CACHE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
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.jdbc.TcpDiscoveryJdbcIpFinder
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.
registerCacheObject(MBeanServer, Object, String, String) - Method in class org.apache.ignite.cache.CacheManager
 
registerClass(int, Class) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Registers class with provided type ID.
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.
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 projection (possibly including local node if it belongs to the projection 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 projection (possibly including local node if it belongs to the projection 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 projection (possibly including this node if it belongs to the projection 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 projection for events using passed in predicate filter for event selection.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
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.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.
remove(String, SwapKey, IgniteInClosure<byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Removes value stored in data space with given name corresponding to specified key.
remove(String, SwapKey, IgniteInClosure<byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Removes value stored in data space with given name corresponding to specified key.
remove(String, SwapKey, IgniteInClosure<byte[]>, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Removes value stored in data space with given name corresponding to specified key.
remove(E, K, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
Remove event from the index.
remove(StreamerIndexUpdateSync, E) - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Removes an event from index.
remove(StreamerIndexUpdateSync, E) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Remove event from the index.
remove(E, K, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Remove event from the index.
remove(E, K, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
Remove event from the index.
removeAll() - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
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(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
removeAll() - Method in interface org.apache.ignite.IgniteCache
removeAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
removeAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
removeAll(String, Collection<SwapKey>, IgniteBiInClosure<SwapKey, byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Removes values stored in data space with given name corresponding to specified keys.
removeAll(String, Collection<SwapKey>, IgniteBiInClosure<SwapKey, byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Removes values stored in data space with given name corresponding to specified keys.
removeAll(String, Collection<SwapKey>, IgniteBiInClosure<SwapKey, byte[]>, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Removes values stored in data space with given name corresponding to specified keys.
removeAppender(FileAppender) - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
Removes file appender.
removeAttributeListener(ComputeTaskSessionAttributeListener) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Removes given listener.
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.
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.IgniteQueue
Gets status of queue.
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.
removeEvent(StreamerIndexEntry<E, K, V>, K, V, StreamerIndexProviderAdapter.IndexKey<V>, E) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
removeFromCollection(Collection<E>, E) - Static method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
removeFromMap(Map<E, Integer>, E) - Static method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
removeFromSwap(String, Object, ClassLoader) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes object from swap.
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.
removeMessageListener(GridMessageListener, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes a previously registered message listener.
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(UUID) - Method in interface org.apache.ignite.transactions.Transaction
Removes metadata by name.
removeNode(UUID) - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunction
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
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.
removeStreamerFailureListener(StreamerFailureListener) - Method in interface org.apache.ignite.IgniteStreamer
Removes streamer failure listener.
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 interface org.apache.ignite.IgniteFileSystem
Renames/moves a file.
renameInternal(Path, Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
repeat(String, int, String, String, String) - Static method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Concatenates elements using provided delimiter.
replace(K, V, V) - Method in interface org.apache.ignite.IgniteCache
replace(K, V) - Method in interface org.apache.ignite.IgniteCache
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.
REPLICA_CNT - Static variable in class org.apache.ignite.streamer.router.StreamerAffinityEventRouter
 
reset() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityFunction
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.cache.affinity.CacheAffinityKeyMapper
Resets cache affinity mapper to its initial state.
reset() - Method in class org.apache.ignite.cache.affinity.fair.CachePartitionFairAffinity
Resets cache affinity to its initial state.
reset() - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.IgniteStreamer
Resets all configured streamer windows by calling StreamerWindow.reset() on each and clears local space.
reset() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Resets this writer.
reset() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProvider
Resets the index to an initial empty state.
reset() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Resets the index to an initial empty state.
reset() - Method in interface org.apache.ignite.streamer.StreamerWindow
Resets window.
reset() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Resets window.
reset0() - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
Called on reset.
reset0() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Called on reset.
reset0() - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
Called on reset.
reset0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Reset routine.
reset0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Reset routine.
reset0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Reset routine.
reset0() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Reset routine.
reset0() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Reset routine.
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.IgniteStreamer
Resets all streamer metrics.
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.
resolve(ClusterNode) - Method in class org.apache.ignite.cache.affinity.CacheAffinityNodeAddressHashResolver
Resolve alternate hash value for the given Grid node.
resolve(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.CacheAffinityNodeHashResolver
Resolve alternate hash value for the given Grid node.
resolve(ClusterNode) - Method in class org.apache.ignite.cache.affinity.CacheAffinityNodeIdHashResolver
Resolve alternate hash value for the given Grid node.
resolveDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Perform dialect resolution.
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.
resolveTypeName(Object, Object) - Method in interface org.apache.ignite.cache.query.QueryTypeResolver
Allows to override type name for portable objects being stored in cache.
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.
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
revisionHash() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision hash.
revisionTimestamp() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision timestamp.
rollback() - Method in interface org.apache.ignite.transactions.Transaction
Rolls back this transaction.
rollbackTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets last time transaction was rollback.
root() - Method in class org.apache.ignite.igfs.IgfsPath
Returns a root for this 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.
route(StreamerContext, String, T) - Method in class org.apache.ignite.streamer.router.StreamerAffinityEventRouter
Selects a node for given event that should be processed by a stage with given name.
route(StreamerContext, String, T) - Method in class org.apache.ignite.streamer.router.StreamerCacheAffinityEventRouter
Selects a node for given event that should be processed by a stage with given name.
route(StreamerContext, String, T) - Method in class org.apache.ignite.streamer.router.StreamerLocalEventRouter
Selects a node for given event that should be processed by a stage with given name.
route(StreamerContext, String, Collection<T>) - Method in class org.apache.ignite.streamer.router.StreamerLocalEventRouter
Selects a node for given events that should be processed by a stage with given name.
route(StreamerContext, String, Object) - Method in class org.apache.ignite.streamer.router.StreamerRandomEventRouter
Selects a node for given event that should be processed by a stage with given name.
route(StreamerContext, String, Object) - Method in class org.apache.ignite.streamer.router.StreamerRoundRobinEventRouter
Selects a node for given event that should be processed by a stage with given name.
route(StreamerContext, String, T) - Method in interface org.apache.ignite.streamer.StreamerEventRouter
Selects a node for given event that should be processed by a stage with given name.
route(StreamerContext, String, Collection<T>) - Method in interface org.apache.ignite.streamer.StreamerEventRouter
Selects a node for given events that should be processed by a stage with given name.
route(StreamerContext, String, Collection<T>) - Method in class org.apache.ignite.streamer.StreamerEventRouterAdapter
Selects a node for given events that should be processed by a stage with given name.
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 in this grid projection.
run(Collection<? extends IgniteRunnable>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on grid nodes within this grid projection.
run() - Method in class org.apache.ignite.spi.IgniteSpiThread
run(StreamerContext, Collection<IN>) - Method in interface org.apache.ignite.streamer.StreamerStage
Stage execution routine.
runLocal(Runnable) - Method in interface org.apache.ignite.IgniteScheduler
Executes given closure on internal system thread pool asynchronously.

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.
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.
scan(IgniteBiPredicate<K, V>) - Static method in class org.apache.ignite.cache.query.Query
Factory method for SPI queries.
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(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.
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.
selected() - Method in interface org.apache.ignite.visor.plugin.VisorPluginNodesPanel
Get selected elements.
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 this projection.
send(Object, Collection<?>) - Method in interface org.apache.ignite.IgniteMessaging
Sends given messages with specified topic to the nodes in this projection.
send(ClusterNode, Serializable, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Sends a message to a remote node.
sendCustomEvent(Serializable) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sends custom message across the ring.
sendCustomEvent(Serializable) - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Sends custom message across the ring.
sendCustomEvent(Serializable) - 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() - Method in class org.apache.ignite.spi.IgniteSpiNodeValidationResult
 
sendOrdered(Object, Object, long) - Method in interface org.apache.ignite.IgniteMessaging
Sends given message with specified topic to the nodes in this projection.
service(String) - Method in interface org.apache.ignite.IgniteServices
Gets 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.
serviceProxy(String, Class<? super T>, boolean) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service.
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 functionality over this grid projection.
services(ClusterGroup) - Method in interface org.apache.ignite.Ignite
 
services(String) - Method in interface org.apache.ignite.IgniteServices
Gets all deployed services with specified name.
services() - Method in class org.apache.ignite.IgniteSpringBean
Gets services functionality over this grid projection.
services(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
session() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
session() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
 
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.
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.
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.
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
 
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.
setAffinity(CacheAffinityFunction) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets affinity for cache keys.
setAffinityKey(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets affinity key used for key-to-node affinity calculation.
setAffinityMapper(CacheAffinityKeyMapper) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets custom affinity mapper.
setAllSegmentationResolversPassRequired(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets all segmentation resolvers pass required flag.
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.IgniteSpringBean
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets SQL arguments.
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets SQL arguments.
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlQuery
Sets SQL arguments.
setArguments(Object...) - Method in class org.apache.ignite.compute.ComputeJobAdapter
Sets given arguments.
setAscendingFields(Map<String, Class<?>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets ascending-indexed fields.
setAtLeastOnce(boolean) - Method in class org.apache.ignite.streamer.StreamerConfiguration
 
setAtomicConfiguration(AtomicConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache atomicity mode.
setAtomicSequenceReserveSize(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
Sets default number of sequence values reserved for IgniteAtomicSequence instances.
setAtomicWriteOrderMode(CacheAtomicWriteOrderMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache write ordering mode.
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.TcpClientDiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets discovery SPI node authenticator.
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.
setBackupFilter(IgniteBiPredicate<ClusterNode, ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Sets optional backup filter.
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.
setBaseDirectory(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Sets base directory.
setBatchQueueSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets batch queue 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.streamer.window.StreamerBoundedSizeBatchWindow
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Sets batch size.
setBatchTimeInterval(long) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Sets batch time interval.
setBlockSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets file's data block size.
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.
setBufferSize(int) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets buffer size.
setBufferSizeRatio(double) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets the buffer size ratio for this SPI.
setCacheConfiguration(CacheConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache configurations.
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets caching mode.
setCacheName(String) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
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.
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 fpr persistent storage for cache data.
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.
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.
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.
setClockSyncFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets clock synchronization frequency in milliseconds.
setClockSyncSamples(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets number of samples used for clock synchronization.
setCollisionSpi(CollisionSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CollisionSpi.
setCollocated(boolean) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setCommunicationSpi(CommunicationSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CommunicationSpi.
setComparator(Comparator<V>) - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
Sets comparator.
setComparator(Comparator<E>) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
Sets event comparator.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets configuration bean.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Sets grid configuration.
setConfigurationPath(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets configuration file path.
setConnectionBufferFlushFrequency(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets connection buffer flush frequency.
setConnectionBufferFlushFrequency(long) - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Sets connection buffer flush frequency.
setConnectionBufferSize(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets connection buffer size.
setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets connection URL.
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.
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.
setCopyOnRead(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Set copy on get flag.
setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets create table query.
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.
setDatabaseName(String) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
setDatabaseSchema(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets database schema name.
setDatabaseTable(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Table name in database.
setDatabaseType(int) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
setDataCacheName(String) - Method in class org.apache.ignite.cache.spring.SpringDynamicCacheManager
Gets data cache name.
setDataCacheName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets cache name 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.
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.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.
setDebugMessageHistory(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method is intended for troubleshooting purposes only.
setDebugMode(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method is intended for troubleshooting purposes only.
setDefaultLockTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets default lock timeout in milliseconds.
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.
setDefaultPriority(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets default priority to use if a job does not have priority attribute set.
setDefaultPriority(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets default priority to use if a job does not have priority attribute set.
setDefaultQueryTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets default query timeout, 0 for never.
setDefaultTimeToLive(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets time to live for all objects in cache.
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.
setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets delete entry query.
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.
setDescendingFields(Map<String, Class<?>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets descending-indexed fields.
setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
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.
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.
setDisconnectCheckInterval(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
Sets disconnect check interval.
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.
setDistributionMode(CacheDistributionMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache distribution mode.
setDualModeMaxPendingPutsSize(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set maximum amount of data in pending put operations.
setDualModePutExecutorService(ExecutorService) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set DUAL mode put operations executor service.
setDualModePutExecutorServiceShutdown(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set DUAL mode put operations executor service shutdown flag.
setEagerTtl(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eager ttl flag.
setEncodeUri(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Indicates that URI must be encoded before usage.
setEscapeAll(boolean) - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
If true, then table name and all column names in 'create table' SQL generated for SQL engine are escaped with double quotes.
setEventStorageSpi(EventStorageSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of EventStorageSpi.
setEvictionFilter(CacheEvictionFilter<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eviction filter.
setEvictionPolicy(CacheEvictionPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache eviction policy.
setEvictMaxOverflowRatio(float) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum eviction overflow ratio.
setEvictNearSynchronized(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets flag indicating whether eviction is synchronized with near nodes.
setEvictSynchronized(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets flag indicating whether eviction is synchronized with backup nodes (or the rest of the nodes for replicated cache).
setEvictSynchronizedConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets concurrency level for synchronized evictions.
setEvictSynchronizedKeyBufferSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eviction key buffer size.
setEvictSynchronizedTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets timeout for synchronized evictions.
setExcludeNeighbors(boolean) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
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.CacheIgfsPerBlockLruEvictionPolicy
Sets collection of regex for paths whose blocks must not be evicted.
setExcludePaths(Collection<String>) - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
Sets collection of regex for paths whose blocks must not be evicted.
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.
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.
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
setFileSystemConfiguration(FileSystemConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets IGFS (Ignite In-Memory File System) configurations.
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.
setFilter(IgnitePredicate<Object>) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Sets event filter.
setFinishedJobInfoTtl(long) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets finished job info time-to-live.
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.
setFragmentizerLocalWritesRatio(float) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets ratio for space available for local file writes.
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.
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
Sets grid name.
setGridName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets grid name.
setGroups(Map<String, LinkedHashMap<String, IgniteBiTuple<Class<?>, Boolean>>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets group-indexed fields.
setHadoopConfiguration(HadoopConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets hadoop configuration.
setHashIdResolver(CacheAffinityNodeHashResolver) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Sets hash ID resolver for nodes.
setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Sets hibernate configuration path.
setHibernateProperties(Properties) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Sets Hibernate properties.
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.igfs.IgfsIpcEndpointConfiguration
Sets the host endpoint is bound to.
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.
setIdleTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle timeout for REST server.
setIdMapper(OptimizedMarshallerIdMapper) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Sets ID mapper.
setIgfsThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set thread pool size that will be used to process outgoing IGFS messages.
setIgniteHome(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite installation folder.
setIncludeEventTypes(int...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets array of event types, which will be recorded by GridEventStorageManager.record(org.apache.ignite.events.Event).
setIncludeProperties(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets array of system or environment property names to include into node attributes.
setIndexCustomFunctionClasses(Class<?>...) - Method in class org.apache.ignite.configuration.QueryConfiguration
Sets classes with methods annotated by QuerySqlFunction to be used as user-defined functions from SQL queries.
setIndexes(StreamerIndexProvider<E, ?, ?>...) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Set indexes.
setIndexFixedTyping(boolean) - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
This flag essentially controls whether key type is going to be identical for all values of the same type.
setIndexingSpi(IndexingSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of IndexingSpi.
setIndexingSpiName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets name of the SPI to use for indexing.
setIndexPrimitiveKey(boolean) - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
Sets flag indicating whether SQL engine should index by key in cases where key is primitive type.
setIndexPrimitiveValue(boolean) - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
Sets flag indexing whether SQL engine should index by value in cases where value is primitive type.
setInitialQuery(Query) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets initial query.
setInitialScriptPath(String) - Method in class org.apache.ignite.configuration.QueryConfiguration
Sets script path to be ran against H2 database after opening.
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.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets insert entry query.
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.
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.
setJavaName(String) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
setJavaType(Class<?>) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
 
setJettyPath(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets path, either absolute or relative to IGNITE_HOME, to JETTY XML configuration file.
setJndiNames(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.
setKey(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
setKeyFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint key field name.
setKeyFields(Collection<CacheTypeFieldMetadata>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets key fields.
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.
setKeyType(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets key type.
setKeyType(Class<?>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets key type.
setLevel(Level) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
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(SwapSpaceSpiListener) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Sets eviction listener to receive notifications on evicted swap entries.
setListener(SwapSpaceSpiListener) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Sets eviction listener to receive notifications on evicted swap entries.
setListener(SwapSpaceSpiListener) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Sets eviction listener to receive notifications on evicted swap entries.
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.
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.
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.
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.
setLogin(Object) - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
Sets login.
setLongQueryExecutionTimeout(long) - Method in class org.apache.ignite.configuration.QueryConfiguration
Set query execution time threshold.
setLongQueryExplain(boolean) - Method in class org.apache.ignite.configuration.QueryConfiguration
If true, SPI will print SQL execution plan for long queries (explain SQL query).
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.
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
Sets marshaller to use within grid.
setMarshalLocalJobs(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets marshal local jobs flag.
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.CacheIgfsPerBlockLruEvictionPolicy
Sets maximum allowed amount of blocks.
setMaxBlocks(int) - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
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.
setMaximumBatches(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Sets maximum number of batches can be stored in window.
setMaximumBatches(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Sets maximum number of batches can be stored in window.
setMaximumConcurrentSessions(int) - Method in class org.apache.ignite.streamer.StreamerConfiguration
Sets maximum number of concurrent sessions.
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.
setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.streamer.StreamerConfiguration
Sets maximum number of failover attempts.
setMaximumQueryIteratorCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of query iterators that can be stored.
setMaximumSize(int) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Sets window maximum size.
setMaximumSparsity(float) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Sets maximum sparsity.
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.
setMaxMissedClientHeartbeats(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets max heartbeats count node can miss without failing client node.
setMaxMissedHeartbeats(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets max heartbeats count node can miss without initiating status check.
setMaxOffHeapMemory(long) - Method in class org.apache.ignite.configuration.QueryConfiguration
Sets maximum amount of memory available to off-heap storage.
setMaxOffheapRowsCacheSize(int) - Method in class org.apache.ignite.configuration.QueryConfiguration
Specifies max allowed size of cache for deserialized offheap rows to avoid deserialization costs for most frequently used ones.
setMaxParallelTasks(int) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets max number of local tasks that may be executed in parallel.
setMaxParamsCnt(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.jdbc.CacheAbstractJdbcStore
Set Max workers thread count.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(long) - Method in class org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicy
Sets maximum allowed size of data in all blocks in bytes.
setMaxSize(long) - Method in interface org.apache.ignite.cache.eviction.igfs.CacheIgfsPerBlockLruEvictionPolicyMXBean
Sets maximum allowed size of data in all blocks in bytes.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSpaceSize(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Set maximum space in bytes available in data cache.
setMaxTaskQueueSize(int) - Method in class org.apache.ignite.configuration.HadoopConfiguration
Sets max task queue size.
setMaxWriteQueueSize(int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Sets max write queue size in bytes.
setMBeanServer(MBeanServer) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets initialized and started MBean server.
setMemoryMode(CacheMemoryMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets memory mode for 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.
setMetaCacheName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets cache name 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.
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.
setMetricsUpdateFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets job metrics update frequency in milliseconds.
setMinimumBufferedMessageCount(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets the minimum number of messages for this SPI, that are buffered prior to sending.
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.
setName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache name.
setName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets IGFS instance name.
setName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service name.
setName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Sets SPI name.
setName(String) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Sets index name.
setName(String) - Method in class org.apache.ignite.streamer.StreamerConfiguration
Sets the name of the streamer.
setName(String) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Sets window name.
setNearEvictionPolicy(CacheEvictionPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eviction policy for near cache.
setNearStartSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Start size for near cache.
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.
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.
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
Sets unique identifier for local node.
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 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.
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.
setOffHeapMaxMemory(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum amount of memory available to off-heap storage.
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
setPageSize(int) - Method in class org.apache.ignite.cache.query.Query
Sets optional page size, if 0, then CacheQueryConfiguration#getPageSize() is used.
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.
setPartitions(int) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
Sets total number of partitions.
setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets password for database access.
setPassword(Object) - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
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.
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.
setPluginConfigurations(PluginConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setPolicy(StreamerIndexPolicy) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Sets index policy.
setPoolSize(int) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Specifies size of cached object streams used by marshaller.
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.igfs.IgfsIpcEndpointConfiguration
Sets the port endpoint is bound to.
setPortRange(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets number of ports to try if configured one is in use.
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.
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.
setQueryConfiguration(CacheQueryConfiguration) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets query configuration.
setQueryConfiguration(QueryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setQueryFields(Map<String, Class<?>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets query fields map.
setQueryIndexEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating whether query indexing is enabled or not.
setReadFromBackup(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets read from backup flag.
setReadStripesNumber(int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Sets read stripe size.
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
Sets size of rebalancing thread pool.
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.
setRemoteFilter(CacheEntryEventFilter<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets optional key-value filter.
setReplication(Path, short) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
setRequireSerializable(boolean) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Sets whether marshaller should require Serializable interface or not.
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.
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.
setRouter(StreamerEventRouter) - Method in class org.apache.ignite.streamer.StreamerConfiguration
Sets router for streamer.
setSearchPath(String...) - Method in class org.apache.ignite.configuration.QueryConfiguration
Sets the optional search path consisting of space names to search SQL schema objects.
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(GridSegmentationPolicy) - 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(GridSegmentationResolver...) - 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.
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.
setService(Service) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service instance.
setServiceConfiguration(ServiceConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets configurations for services to be deployed on the grid.
setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Sets session factory.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Sets shared flag.
setSocketReceiveBuffer(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets receive buffer size for sockets created or accepted by this SPI.
setSocketSendBuffer(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets send buffer size for sockets created or accepted by this SPI.
setSocketWriteTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets socket write timeout for TCP connection.
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.
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
Sets instance of GridSslContextFactory that will be used to create an instance of SSLContext for Secure Socket Layer on TCP binary protocol.
setSslEnabled(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets whether Secure Socket Layer should be enabled for REST TCP binary protocol.
setStages(Collection<StreamerStage>) - Method in class org.apache.ignite.streamer.StreamerConfiguration
Sets stages.
setStartSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Initial size for internal hash map.
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.
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.
setStreamBufferSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets read/write buffers size for IGFS stream operations (bytes).
setStreamerConfiguration(StreamerConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets streamer configuration.
setSwapEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating whether swap storage is enabled or not.
setSwapSpaceSpi(SwapSpaceSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of SwapSpaceSpi.
setSystemThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets system thread pool size to use within grid.
setTarget(Object) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets target object for method execution.
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.
setTextFields(Collection<String>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets text-indexed fields.
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.streamer.StreamerConfiguration
Sets streamer pool size.
setThreadsCount(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets number of worker threads.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets time interval.
setTimeInterval(long) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Sets window time interval.
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.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.
setTokenDirectoryPath(String) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
Sets directory where shared memory tokens are stored.
setTotalCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets total number of deployed service instances in the cluster, 0 for unlimited.
setTransactionConfiguration(TransactionConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets transactions configuration.
setTransactionManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets look up mechanism for available TransactionManager implementation, if any.
setTrashPurgeTimeout(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
Sets maximum timeout awaiting for trash purging in case data cache oversize is detected.
setTxSerializableEnabled(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Enables/disables serializable cache transactions.
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.
setTypeMetadata(Collection<CacheTypeMetadata>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets collection of type metadata objects.
setTypeResolver(QueryTypeResolver) - Method in class org.apache.ignite.configuration.CacheQueryConfiguration
Sets query type resolver.
setUnacknowledgedMessagesBufferSize(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sets maximum number of stored unacknowledged messages per connection to node.
setUnique(boolean) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Sets unique flag.
setUnique(boolean) - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Sets window unique flag.
setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets update entry query.
setUpdater(StreamerIndexUpdater<E, K, V>) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Sets index updater.
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.
setUseOptimizedSerializer(boolean) - Method in class org.apache.ignite.configuration.QueryConfiguration
The flag indicating that serializer for H2 database will be set to Ignite's marshaller.
setUseProcessors(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets flag indicating whether to use average CPU load vs. current (default is true).
setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets user name for database access.
setUser(String) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
Set user name and default working directory for current thread.
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.
setUserObject(Object) - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
Sets user-specific object.
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.
setValue(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
setValue(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
setValueFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint value field name.
setValueFields(Collection<CacheTypeFieldMetadata>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets value fields.
setValueFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint value field type.
setValueType(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
Sets value type.
setValueType(Class<?>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
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.
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.
setWindows(Collection<StreamerWindow>) - Method in class org.apache.ignite.streamer.StreamerConfiguration
Sets collection of streamer windows.
setWorkDirectory(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite work folder.
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.
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.
setWriteBufferSize(int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Sets write buffer size in bytes.
setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write synchronization mode.
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.SwapSpaceEvent
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.
shutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
shutdownNow() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
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
size(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Gets size in bytes for data space with given name.
size(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Gets size in bytes for data space with given name.
size(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Gets size in bytes for data space with given name.
size() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
 
size() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets current index size.
size() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderMBean
Gets current index size.
size() - Method in interface org.apache.ignite.streamer.StreamerWindow
Gets number of events currently stored in window.
size() - Method in interface org.apache.ignite.streamer.StreamerWindowMetrics
Gets window size.
size() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Gets number of events currently stored in window.
size() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Gets number of events currently stored in window.
size() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Gets number of events currently stored in window.
size() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Gets number of events currently stored in window.
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 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.
snapshot() - Static method in class org.apache.ignite.IgniteSystemProperties
Gets snapshot of system properties.
snapshot(boolean) - Method in interface org.apache.ignite.streamer.StreamerWindow
Create window snapshot.
snapshot(boolean) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Create window snapshot.
sorted() - Method in class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
Returns true if index supports sorting and therefore can perform range operations.
sorted() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Returns true if index supports sorting and therefore can perform range operations.
sorted() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderMBean
Returns true if index supports sorting and therefore can perform range operations.
sorted() - Method in class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
Returns true if index supports sorting and therefore can perform range operations.
space() - Method in class org.apache.ignite.events.SwapSpaceEvent
Gets swap space name.
spi() - Static method in class org.apache.ignite.cache.query.Query
Factory method for SPI queries.
spiContext() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
 
SpiQuery - 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.TcpClientDiscoverySpi
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.failover.always.AlwaysFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
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.TcpClientDiscoverySpi
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.failover.always.AlwaysFailoverSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called to stop SPI.
spiStop() - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
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
 
SpringDynamicCacheManager - Class in org.apache.ignite.cache.spring
Extension of SpringCacheManager that adds an option to emulate dynamic cache creation for you Spring-based applications.
SpringDynamicCacheManager() - Constructor for class org.apache.ignite.cache.spring.SpringDynamicCacheManager
 
SpringResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of resource from Spring ApplicationContext.
sql(String) - Static method in class org.apache.ignite.cache.query.Query
Factory method for SQL fields queries.
sql(Class<?>, String) - Static method in class org.apache.ignite.cache.query.Query
Factory method for SQL queries.
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.
SqlQuery - Class in org.apache.ignite.cache.query
SQL Query.
SqlQuery(String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Constructs query for the given 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 MsSQL database.
SQLServerDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
 
stage() - Method in class org.apache.ignite.lang.IgniteProductVersion
 
stageActiveExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets number of stages currently being executed in streamer pool.
stageMetrics(String) - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets current stage metrics, if stage with given name is not configured then IllegalArgumentException will be thrown.
stageMetrics() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets metrics for all stages.
stageTotalExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets total number of stages executed since last reset.
stageWaitingExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets number of event batches currently waiting to be executed.
stamp() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current stamp.
start(Settings, Properties) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
start() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
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(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() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
Starts grid component, called on grid start.
start(PluginContext) - Method in interface org.apache.ignite.plugin.PluginProvider
Starts grid component.
start() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
startInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformly formatted message for SPI start.
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).
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.lang.IgniteFuture
Gets start time for this future.
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 grid.
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.
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.
stgy - Variable in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
 
stop() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
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 grid.
stop() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.messaging.MessagingListenActor
This method instructs underlying implementation to stop receiving new messages and unregister the message listener.
stop(Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method sends the response message to the original sender node and instructs underlying implementation to stop receiving new messages and unregister the message listener.
stop(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops default grid instance.
stop(String, boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops named grid.
stop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
Stops grid component.
stop() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
stop0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
Dispose window.
stop0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
Dispose window.
stop0() - Method in class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
Dispose window.
stop0() - Method in class org.apache.ignite.streamer.window.StreamerUnboundedWindow
Dispose window.
stop0() - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Dispose window.
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 this projection.
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.
store(String, SwapKey, byte[], SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Stores value as array of bytes with given key into data space with given name.
store(String, SwapKey, byte[], SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Stores value as array of bytes with given key into data space with given name.
store(String, SwapKey, byte[], SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Stores value as array of bytes with given key into data space with given name.
storeAll(String, Map<SwapKey, byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
Stores key-value pairs (both keys and values are arrays of bytes) into data space with given name.
storeAll(String, Map<SwapKey, byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
Stores key-value pairs (both keys and values are arrays of bytes) into data space with given name.
storeAll(String, Map<SwapKey, byte[]>, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
Stores key-value pairs (both keys and values are arrays of bytes) into data space with given name.
streamer(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of streamer by name, if one does not exist then IllegalArgumentException will be thrown.
streamer(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of streamer by name, if one does not exist then IllegalArgumentException will be thrown.
StreamerAffinityEventRouter - Class in org.apache.ignite.streamer.router
Router used to colocate identical streamer events or events with identical affinity key on the same node.
StreamerAffinityEventRouter() - Constructor for class org.apache.ignite.streamer.router.StreamerAffinityEventRouter
 
StreamerAffinityEventRouter.AffinityEvent - Interface in org.apache.ignite.streamer.router
All events that implement this interface will be routed based on key affinity.
StreamerBoundedSizeBatchWindow<E> - Class in org.apache.ignite.streamer.window
Window that is bounded by size and accumulates events to batches.
StreamerBoundedSizeBatchWindow() - Constructor for class org.apache.ignite.streamer.window.StreamerBoundedSizeBatchWindow
 
StreamerBoundedSizeSortedWindow<E> - Class in org.apache.ignite.streamer.window
Size-bounded sorted window.
StreamerBoundedSizeSortedWindow() - Constructor for class org.apache.ignite.streamer.window.StreamerBoundedSizeSortedWindow
 
StreamerBoundedSizeWindow<E> - Class in org.apache.ignite.streamer.window
Queue window bounded by number of elements in queue.
StreamerBoundedSizeWindow() - Constructor for class org.apache.ignite.streamer.window.StreamerBoundedSizeWindow
 
StreamerBoundedTimeBatchWindow<E> - Class in org.apache.ignite.streamer.window
Window that accumulates events in batches, and is bounded by time and maximum number of batches.
StreamerBoundedTimeBatchWindow() - Constructor for class org.apache.ignite.streamer.window.StreamerBoundedTimeBatchWindow
 
StreamerBoundedTimeWindow<E> - Class in org.apache.ignite.streamer.window
Window which is bounded by size and time interval.
StreamerBoundedTimeWindow() - Constructor for class org.apache.ignite.streamer.window.StreamerBoundedTimeWindow
 
StreamerCacheAffinityEventRouter - Class in org.apache.ignite.streamer.router
Router used to colocate streamer events with data stored in a partitioned cache.
StreamerCacheAffinityEventRouter() - Constructor for class org.apache.ignite.streamer.router.StreamerCacheAffinityEventRouter
 
StreamerCacheAffinityEventRouter.CacheAffinityEvent - Interface in org.apache.ignite.streamer.router
All events that implement this interface will be routed based on key affinity.
StreamerConfiguration - Class in org.apache.ignite.streamer
Streamer configuration.
StreamerConfiguration() - Constructor for class org.apache.ignite.streamer.StreamerConfiguration
 
StreamerConfiguration(StreamerConfiguration) - Constructor for class org.apache.ignite.streamer.StreamerConfiguration
 
StreamerContext - Interface in org.apache.ignite.streamer
Streamer context.
StreamerEventRouter - Interface in org.apache.ignite.streamer
Streamer event router.
StreamerEventRouterAdapter - Class in org.apache.ignite.streamer
Streamer adapter for event routers.
StreamerEventRouterAdapter() - Constructor for class org.apache.ignite.streamer.StreamerEventRouterAdapter
 
StreamerFailureListener - Interface in org.apache.ignite.streamer
Streamer failure listener.
StreamerHashIndexProvider<E,K,V> - Class in org.apache.ignite.streamer.index.hash
Hash index implementation of a StreamerIndexProvider.
StreamerHashIndexProvider() - Constructor for class org.apache.ignite.streamer.index.hash.StreamerHashIndexProvider
 
StreamerIndex<E,K,V> - Interface in org.apache.ignite.streamer.index
User view on streamer index.
StreamerIndexEntry<E,K,V> - Interface in org.apache.ignite.streamer.index
Streamer index entry.
StreamerIndexPolicy - Enum in org.apache.ignite.streamer.index
Streamer index policy, which defines how events are tracked within an index.
StreamerIndexProvider<E,K,V> - Interface in org.apache.ignite.streamer.index
Represents an actual instance of an index.
StreamerIndexProviderAdapter<E,K,V> - Class in org.apache.ignite.streamer.index
Convenient StreamerIndexProvider adapter implementing base configuration methods.
StreamerIndexProviderAdapter() - Constructor for class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
StreamerIndexProviderAdapter.DedupTrackingEntry<E,K,V> - Class in org.apache.ignite.streamer.index
StreamerIndexProviderAdapter.DedupTrackingEntry(Map<E, Integer>, K, V, StreamerIndexProviderAdapter.IndexKey<V>) - Constructor for class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.DedupTrackingEntry
 
StreamerIndexProviderAdapter.Entry<E,K,V> - Class in org.apache.ignite.streamer.index
Streamer window index entry.
StreamerIndexProviderAdapter.EventTrackingEntry<E,K,V> - Class in org.apache.ignite.streamer.index
Entry with index policy StreamerIndexPolicy.EVENT_TRACKING_ON.
StreamerIndexProviderAdapter.EventTrackingEntry(Collection<E>, K, V, StreamerIndexProviderAdapter.IndexKey<V>) - Constructor for class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.EventTrackingEntry
 
StreamerIndexProviderAdapter.IndexKey<V> - Interface in org.apache.ignite.streamer.index
Streamer window index key.
StreamerIndexProviderAdapter.NonTrackingEntry<E,K,V> - Class in org.apache.ignite.streamer.index
StreamerIndexProviderAdapter.NonTrackingEntry(K, V, StreamerIndexProviderAdapter.IndexKey<V>) - Constructor for class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.NonTrackingEntry
 
StreamerIndexProviderMBean - Interface in org.apache.ignite.streamer.index
Streamer window index provider MBean.
StreamerIndexUpdater<E,K,V> - Interface in org.apache.ignite.streamer.index
Index updater.
StreamerIndexUpdateSync - Class in org.apache.ignite.streamer.index
Streamer index update synchronizer.
StreamerIndexUpdateSync() - Constructor for class org.apache.ignite.streamer.index.StreamerIndexUpdateSync
 
StreamerLocalEventRouter - Class in org.apache.ignite.streamer.router
Local router.
StreamerLocalEventRouter() - Constructor for class org.apache.ignite.streamer.router.StreamerLocalEventRouter
 
StreamerMBean - Interface in org.apache.ignite.streamer
Streamer MBean interface.
StreamerMetrics - Interface in org.apache.ignite.streamer
Streamer metrics.
StreamerRandomEventRouter - Class in org.apache.ignite.streamer.router
Random router.
StreamerRandomEventRouter() - Constructor for class org.apache.ignite.streamer.router.StreamerRandomEventRouter
Empty constructor for spring.
StreamerRandomEventRouter(IgnitePredicate<ClusterNode>...) - Constructor for class org.apache.ignite.streamer.router.StreamerRandomEventRouter
Constructs random event router with optional set of filters to apply to streamer projection.
StreamerRandomEventRouter(Collection<IgnitePredicate<ClusterNode>>) - Constructor for class org.apache.ignite.streamer.router.StreamerRandomEventRouter
Constructs random event router with optional set of filters to apply to streamer projection.
StreamerRoundRobinEventRouter - Class in org.apache.ignite.streamer.router
Round robin router.
StreamerRoundRobinEventRouter() - Constructor for class org.apache.ignite.streamer.router.StreamerRoundRobinEventRouter
 
streamers() - Method in interface org.apache.ignite.Ignite
Gets all instances of streamers.
streamers() - Method in class org.apache.ignite.IgniteSpringBean
Gets all instances of streamers.
StreamerStage<IN> - Interface in org.apache.ignite.streamer
Streamer stage is a component that determines event processing flow.
StreamerStageMBean - Interface in org.apache.ignite.streamer
Streamer stage MBean.
StreamerStageMetrics - Interface in org.apache.ignite.streamer
Streamer stage metrics.
StreamerTreeIndexProvider<E,K,V> - Class in org.apache.ignite.streamer.index.tree
Tree index implementation of a StreamerIndexProvider.
StreamerTreeIndexProvider() - Constructor for class org.apache.ignite.streamer.index.tree.StreamerTreeIndexProvider
 
StreamerUnboundedWindow<E> - Class in org.apache.ignite.streamer.window
Unbounded window which holds all events.
StreamerUnboundedWindow() - Constructor for class org.apache.ignite.streamer.window.StreamerUnboundedWindow
 
StreamerWindow<E> - Interface in org.apache.ignite.streamer
Streamer rolling window.
StreamerWindowAdapter<E> - Class in org.apache.ignite.streamer.window
Streamer window adapter.
StreamerWindowAdapter() - Constructor for class org.apache.ignite.streamer.window.StreamerWindowAdapter
 
StreamerWindowMBean - Interface in org.apache.ignite.streamer
Streamer window MBean.
StreamerWindowMetrics - Interface in org.apache.ignite.streamer
Streamer window 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(GridSecuritySubjectType) - 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.
SwapContext - Class in org.apache.ignite.spi.swapspace
Context for swap operations.
SwapContext() - Constructor for class org.apache.ignite.spi.swapspace.SwapContext
 
swapIterator() - Method in interface org.apache.ignite.cache.GridCache
Gets iterator over keys and values belonging to this cache swap space on local node.
SwapKey - Class in org.apache.ignite.spi.swapspace
Utility wrapper class that represents swap key.
SwapKey(Object) - Constructor for class org.apache.ignite.spi.swapspace.SwapKey
 
SwapKey(Object, int) - Constructor for class org.apache.ignite.spi.swapspace.SwapKey
 
SwapKey(Object, int, byte[]) - Constructor for class org.apache.ignite.spi.swapspace.SwapKey
 
swapKeys() - Method in interface org.apache.ignite.cache.GridCache
Gets number of swap entries (keys).
swapSize() - Method in interface org.apache.ignite.cache.GridCache
Gets size in bytes for swap space.
SwapSpaceEvent - Class in org.apache.ignite.events
Grid swap space event.
SwapSpaceEvent(ClusterNode, String, int, String) - Constructor for class org.apache.ignite.events.SwapSpaceEvent
Creates swap space event.
SwapSpaceSpi - Interface in org.apache.ignite.spi.swapspace
Provides a mechanism in grid for storing data on disk.
SwapSpaceSpiListener - Interface in org.apache.ignite.spi.swapspace
Swap space SPI eviction listener.
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.
systemPermissions() - Method in interface org.apache.ignite.plugin.security.GridSecurityPermissionSet
Collection of system-wide permissions (events enable/disable, Visor task execution).

T

take() - Method in interface org.apache.ignite.IgniteQueue
taskClassName() - Method in class org.apache.ignite.events.JobEvent
Gets name of task class that triggered this event.
taskClassName(String) - Method in class org.apache.ignite.events.JobEvent
Sets name of the task class that triggered this event.
taskClassName() - Method in class org.apache.ignite.events.TaskEvent
Gets name of task class that triggered this event.
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 interface org.apache.ignite.plugin.security.GridSecurityPermissionSet
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.
TcpClientDiscoverySpi - Class in org.apache.ignite.spi.discovery.tcp
Client discovery SPI implementation that uses TCP/IP for node discovery.
TcpClientDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.tcp.TcpClientDiscoverySpi
 
TcpClientDiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery.tcp
Management bean for TcpClientDiscoverySpi.
TcpCommunicationSpi - Class in org.apache.ignite.spi.communication.tcp
GridTcpCommunicationSpi 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.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.
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.
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.
text(Class<?>, String) - Static method in class org.apache.ignite.cache.query.Query
Factory method for Lucene fulltext queries.
TextQuery - Class in org.apache.ignite.cache.query
Query for Lucene based fulltext search.
TextQuery(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() - 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.
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
toBytes(Object) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Serialize object to byte array using marshaller.
toBytes(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Serialize object to byte array using marshaller.
toMap() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
tooltip() - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
Tab tooltip.
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.
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.cache.affinity.CacheAffinityKey
toString() - Method in class org.apache.ignite.cache.affinity.CacheAffinityNodeAddressHashResolver
toString() - Method in class org.apache.ignite.cache.affinity.CacheAffinityNodeIdHashResolver
toString() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
toString() - Method in class org.apache.ignite.cache.eviction.fifo.CacheFifoEvictionPolicy
toString() - Method in class org.apache.ignite.cache.eviction.lru.CacheLruEvictionPolicy
toString() - Method in class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy
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.store.hibernate.CacheHibernateBlobStore
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
toString() - Method in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
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.CacheConfiguration
toString() - Method in class org.apache.ignite.configuration.CollectionConfiguration
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.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.SwapSpaceEvent
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.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.IgniteJclLogger
toString() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
toString() - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
toString() - Method in class org.apache.ignite.messaging.MessagingListenActor
toString() - Method in class org.apache.ignite.plugin.security.GridSecurityCredentials
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.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.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.IgniteSpiThread
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
toString() - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
toString() - Method in class org.apache.ignite.spi.swapspace.SwapContext
toString() - Method in class org.apache.ignite.spi.swapspace.SwapKey
toString() - Method in class org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup
toString() - Method in class org.apache.ignite.startup.servlet.IgniteServletStartup
toString() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.DedupTrackingEntry
toString() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.Entry
toString() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.EventTrackingEntry
toString() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.NonTrackingEntry
toString() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
toString() - Method in class org.apache.ignite.streamer.index.StreamerIndexUpdateSync
toString() - Method in class org.apache.ignite.streamer.StreamerConfiguration
toString() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
toString() - Method in class org.apache.ignite.thread.IgniteThread
totalCount() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets maximum allowed total number of deployed services in the grid, 0 for unlimited.
totalExecutionCount() - Method in interface org.apache.ignite.streamer.StreamerStageMetrics
Gets total stage execution count since last reset.
totalLength() - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
totalLength(long) - Method in class org.apache.ignite.igfs.IgfsPathSummary
 
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.IgniteJclLogger
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.NullLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
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
Grid 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
 
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.
TransactionSynchronization - Interface in org.apache.ignite.transactions
Synchronization callback for transaction.
TransactionTimeoutException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid 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(String...) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
 
trieGet(K, TrieMap<K, V>) - Static method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Utility method to safely get values from TrieMap.
tryFlush() - Method in interface org.apache.ignite.IgniteDataStreamer
Makes an attempt to stream remaining data.
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.
txEnd(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.
txEnd(boolean) - Method in interface org.apache.ignite.cache.store.CacheStore
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
txEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
Default empty implementation for ending transactions.
txEnd(boolean) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default empty implementation for ending transactions.
txEnd(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.
txEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default empty implementation for ending transactions.
txRollbacks() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction rollbacks.
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.
txSynchronizations() - Method in interface org.apache.ignite.cache.GridCache
Gets registered transaction synchronizations.
txSynchronize(TransactionSynchronization) - Method in interface org.apache.ignite.cache.GridCache
Registers transactions synchronizations for all transactions started by this cache.
txUnsynchronize(TransactionSynchronization) - Method in interface org.apache.ignite.cache.GridCache
Removes transaction synchronizations.
type() - Method in interface org.apache.ignite.events.Event
Gets type of this event.
type(int) - Method in class org.apache.ignite.events.EventAdapter
Sets event type.
type() - Method in class org.apache.ignite.events.EventAdapter
Gets type of this event.
type() - Method in interface org.apache.ignite.plugin.security.GridSecuritySubject
Gets subject type, either node or client.
typeId(String) - Method in interface org.apache.ignite.marshaller.optimized.OptimizedMarshallerIdMapper
Gets type ID for provided class name.

U

undeployTask(String) - Method in interface org.apache.ignite.IgniteCompute
Makes the best attempt to undeploy a task with given name from this grid projection.
undeployTaskFromGrid(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Makes the best attempt to undeploy a task from the whole grid.
unique() - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets index unique flag.
unique() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets index unique flag.
unique() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderMBean
Gets index unique flag.
unlock(Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate failed to update or successfully removed given key.
unlock(Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlockIndexKey(StreamerIndexProviderAdapter.IndexKey<V>, StreamerIndexUpdateSync) - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Unlock updates on particular key.
unlockItem(Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
unlockRegion(SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
unlockRegion(SoftLock) - 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.AbstractMarshaller
Unmarshals object from byte array using given class loader.
unmarshal(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Unmarshals object from the output stream using given class loader.
unmarshal(InputStream, ClassLoader) - Method in interface org.apache.ignite.marshaller.Marshaller
Unmarshals object from the output 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.
unmarshal(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Unmarshals object from the output stream using given class loader.
unmarshal(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
Unmarshals object from byte array using given class loader.
UNREG_ADDR_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Query to unregister address.
unregister(String) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregister(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregister(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.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.
unregisterCacheObject(MBeanServer, String, String) - Method in class org.apache.ignite.cache.CacheManager
UnRegisters the mxbean if registered already.
unregisterMBean() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Unregisters MBean.
unwrap(Class<T>) - Method in class org.apache.ignite.cache.CacheManager
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(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in interface org.apache.ignite.IgniteDataStreamer.Updater
Updates cache with batch of entries.
update(IgfsPath, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
Updates file information for the specified path.
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.
updateIndexes(E, boolean) - Method in class org.apache.ignite.streamer.window.StreamerWindowAdapter
Update indexes.
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.
updater(IgniteDataStreamer.Updater<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets custom cache updater to this data streamer.
updaterClass() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
Gets index updater class name.
updaterClass() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderMBean
Gets index updater class name.
UriDeploymentSpi - Class in org.apache.ignite.spi.deployment.uri
Implementation of DeploymentSpi which can deploy tasks from different sources like file system folders, FTP, 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 interface org.apache.ignite.IgniteFileSystem
Gets used space in bytes.
userArgument() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
User argument provided for task execution.

V

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.
value() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry value.
value() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current value.
value() - Method in interface org.apache.ignite.streamer.index.StreamerIndexEntry
Gets index entry value.
value() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.Entry
Gets index entry value.
value() - Method in interface org.apache.ignite.streamer.index.StreamerIndexProviderAdapter.IndexKey
 
valueColumns() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Gets value columns.
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.CacheAtomicWriteOrderMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheDistributionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheMemoryMode
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.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.DeploymentMode
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.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.GridSecurityPermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.security.GridSecuritySubjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.segmentation.GridSegmentationPolicy
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.streamer.index.StreamerIndexPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.transactions.TransactionConcurrency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.transactions.TransactionIsolation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.transactions.TransactionState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheAtomicWriteOrderMode
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.CacheDistributionMode
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.CacheMemoryMode
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.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.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.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.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.GridSecurityPermission
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.GridSecuritySubjectType
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.GridSegmentationPolicy
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(int) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only collection of index values.
values(boolean, V, boolean, V, boolean) - Method in interface org.apache.ignite.streamer.index.StreamerIndex
Gets read-only collection of index values within given value range.
values() - Static method in enum org.apache.ignite.streamer.index.StreamerIndexPolicy
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
Value type.
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
 
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.
waitForLocal(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Waits 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.
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.IgniteJclLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.jcl.IgniteJclLogger
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.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.GridSlf4jLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.GridSlf4jLogger
Logs out warning message with optional exception.
WEB_SES_CACHE_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
Web sessions caching cache name parameter name.
WEB_SES_MAX_RETRIES_ON_FAIL_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
Web sessions caching retry on fail parameter name (valid for ATOMIC
WEB_SES_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.IgniteWebSessionFilter
Web sessions caching grid name parameter name.
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.
window() - Method in interface org.apache.ignite.streamer.StreamerContext
Gets default event window, i.e. window that is on the first place in streamer configuration.
window(String) - Method in interface org.apache.ignite.streamer.StreamerContext
Gets streamer event window by window name, if no window with such name was configured IllegalArgumentException will be thrown.
windowMetrics(String) - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets current window metrics, if window with given name is not configured then IllegalArgumentException will be thrown.
windowMetrics() - Method in interface org.apache.ignite.streamer.StreamerMetrics
Gets metrics for all windows.
withAsync() - Method in interface org.apache.ignite.IgniteCache
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.IgniteCluster
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.IgniteCompute
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.IgniteEvents
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.IgniteFileSystem
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.IgniteMessaging
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.IgniteServices
Gets component with asynchronous mode enabled.
withAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Gets component with asynchronous mode enabled.
withExpiryPolicy(ExpiryPolicy) - Method in interface org.apache.ignite.IgniteCache
 
withName(String) - Method in interface org.apache.ignite.IgniteCompute
Sets task name for the next executed task on this projection in the current thread.
withNoFailover() - Method in interface org.apache.ignite.IgniteCompute
Sets no-failover flag for the next executed task on this projection in the current thread.
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 on this projection 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.hibernate.CacheHibernateBlobStore
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(HadoopJobInfo, HadoopJobId, 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.jdbc.CacheAbstractJdbcStore
writeBitSet(String, BitSet) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes BitSet.
writeBoolean(String, boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes boolean value.
writeBooleanArray(String, boolean[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes boolean array.
writeByte(String, byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte value.
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(String, char) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes char value.
writeCharArray(String, char[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes char array.
writeCollection(String, Collection<T>, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes collection.
writeDouble(String, double) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes double value.
writeDoubleArray(String, double[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes double array.
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.affinity.CacheAffinityKey
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.affinity.rendezvous.CacheRendezvousAffinityFunction
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.plugin.security.GridSecurityCredentials
writeFloat(String, float) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes float value.
writeFloatArray(String, float[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes float array.
writeHeader(byte, 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(String, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes int value.
writeIntArray(String, int[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes int array.
writeLock() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
writeLong(String, long) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long value.
writeLongArray(String, long[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long array.
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.
writeObjectArray(String, T[], MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes array of objects.
writer() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFormatter
Creates new message writer instance.
writeShort(String, short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes short value.
writeShortArray(String, short[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes short array.
writeString(String, String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes String.
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.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.
writeToSwap(String, Object, Object, ClassLoader) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Writes object to swap.
writeUnlock() - Method in class org.apache.ignite.streamer.index.StreamerIndexProviderAdapter
 
writeUuid(String, UUID) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes UUID.

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).
A B C D E F G H I J K L M N O P Q R S T U V W X 
Apache Ignite - In-Memory Data Fabric

2015 Copyright © Apache Software Foundation
Apache Ignite Fabric :   ver. 1.0.0-RC3
Release Date :   March 24 2015