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

A

AboutDialog - Class in org.apache.ignite.startup.cmdline
About dialog.
ABS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns Math.abs(a).
AbstractCommand - Class in org.apache.ignite.tensorflow.submitter.command
Abstract command that contains options common for all commands.
AbstractCommand() - Constructor for class org.apache.ignite.tensorflow.submitter.command.AbstractCommand
 
AbstractContinuousQuery<K,V> - Class in org.apache.ignite.cache.query
Base class for continuous query.
AbstractContinuousQuery() - Constructor for class org.apache.ignite.cache.query.AbstractContinuousQuery
 
AbstractCrossValidation<M extends IgniteModel<Vector,L>,L,K,V> - Class in org.apache.ignite.ml.selection.cv
Cross validation score calculator.
AbstractCrossValidation() - Constructor for class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
AbstractCrossValidation.TaskResult - Class in org.apache.ignite.ml.selection.cv
Represents the scores and map of parameters.
AbstractEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction
Common functionality implementation for eviction policies with max size/max memory and batch eviction support.
AbstractEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
AbstractEvictionPolicyFactory<T> - Class in org.apache.ignite.cache.eviction
Common functionality implementation for eviction policies factories.
AbstractEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
 
AbstractFailureHandler - Class in org.apache.ignite.failure
Abstract superclass for FailureHandler implementations.
AbstractFailureHandler() - Constructor for class org.apache.ignite.failure.AbstractFailureHandler
 
AbstractLSQR - Class in org.apache.ignite.ml.math.isolve.lsqr
Basic implementation of the LSQR algorithm without assumptions about dataset storage format or data processing device.
AbstractLSQR() - Constructor for class org.apache.ignite.ml.math.isolve.lsqr.AbstractLSQR
 
AbstractMarshaller - Class in org.apache.ignite.marshaller
Base class for marshallers.
AbstractMarshaller() - Constructor for class org.apache.ignite.marshaller.AbstractMarshaller
 
AbstractMatrix - Class in org.apache.ignite.ml.math.primitives.matrix
This class provides a helper implementation of the Matrix interface to minimize the effort required to implement it.
AbstractMatrix(MatrixStorage) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
 
AbstractMatrix() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
 
AbstractMetrics<M extends MetricValues> - Class in org.apache.ignite.ml.selection.scoring.metric
Abstract metrics calculator.
AbstractMetrics() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.AbstractMetrics
 
AbstractNodeNameAwareMarshaller - Class in org.apache.ignite.marshaller
Marshaller allowing for Ignition.localIgnite() calls.
AbstractNodeNameAwareMarshaller() - Constructor for class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
 
AbstractVector - Class in org.apache.ignite.ml.math.primitives.vector
This class provides a helper implementation of the Vector interface to minimize the effort required to implement it.
AbstractVector(VectorStorage) - Constructor for class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
AbstractVector(boolean, VectorStorage) - Constructor for class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
AbstractVector() - Constructor for class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
accept(A, B, C) - Method in interface org.apache.ignite.ml.math.functions.IgniteTriConsumer
Analogous to 'accept' in Consumer version, but with three parameters.
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
accept(int, String, Class<T>) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeVisitor
Visit some object property.
accept(int, String, Class<T>, T) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
accept(CacheDrEntry<K, V>) - Method in interface org.gridgain.grid.cache.dr.CacheDrEntryFilter
Whether to perform data center replication for particular cache entry or not.
acceptance() - Method in interface org.gridgain.grid.cache.compress.CompressionMetrics
Gets current acceptance, a fraction of records which were actually compressed.
acceptBoolean(int, String, boolean) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptByte(int, String, byte) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptChar(int, String, char) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptDouble(int, String, double) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptFloat(int, String, float) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptInt(int, String, int) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptLong(int, String, long) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptShort(int, String, short) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcDriver
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcThinDriver
accessMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
Get access mode.
accessMode() - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
 
accessMode() - Method in interface org.apache.ignite.ml.math.primitives.matrix.OrderedMatrix
Get access mode.
accessMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
accessMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
accessMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
Accuracy<L> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Accuracy score calculator.
Accuracy() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.Accuracy
 
accuracy() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Accuracy.
ackMessage() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
Called when custom message has been handled by all nodes.
acknowledge(byte) - Method in interface org.gridgain.grid.dr.store.DrSenderStoreEntry
Acknowledge.
acl() - Method in class org.gridgain.grid.security.passcode.AuthenticationAclBasicProvider
Gets per-user access control map.
acl() - Method in interface org.gridgain.grid.security.passcode.AuthenticationAclProvider
Gets per-user access control map.
acquire() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
acquire(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, blocking until all are available, or the thread is interrupted.
acquirePort(UUID) - Method in class org.apache.ignite.tensorflow.cluster.util.ClusterPortManager
Acquires free port on the specified node.
acquireUninterruptibly() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, blocking until one is available.
acquireUninterruptibly(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, blocking until all are available.
actionsForMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
All MaintenanceActions provided by a component for MaintenanceTask with a given name.
activate() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Activates the job.
activationFunction() - Method in class org.apache.ignite.ml.nn.architecture.TransformationLayerArchitecture
Get activation function for this layer.
Activators - Class in org.apache.ignite.ml.nn
Class containing some common activation functions.
Activators() - Constructor for class org.apache.ignite.ml.nn.Activators
 
activatorsOutput - Variable in class org.apache.ignite.ml.nn.MLPState
Output of activators.
activatorsOutput(int) - Method in class org.apache.ignite.ml.nn.MLPState
Output of activators of given layer.
active(ClusterState) - Static method in enum org.apache.ignite.cluster.ClusterState
 
active() - Method in interface org.apache.ignite.Ignite
Deprecated.
active(boolean) - Method in interface org.apache.ignite.Ignite
Deprecated.
active() - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
active(boolean) - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
active() - Method in class org.apache.ignite.IgniteSpringBean
Checks Ignite grid is active or not active.
active(boolean) - Method in class org.apache.ignite.IgniteSpringBean
Changes Ignite grid state to active or inactive.
active(boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
 
active() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
ACTIVE - Static variable in class org.gridgain.grid.cache.dr.CacheDrStatus
Status: not stopped.
ACTIVE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ACTIVE_JOBS_THRESHOLD_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Threshold of maximum jobs executing concurrently.
activeDictionaries() - Method in interface org.gridgain.grid.cache.compress.DictionaryMetrics
Gets number of active dictionaries.
activeJobs() - Method in interface org.apache.ignite.spi.collision.CollisionContext
Gets ordered collection of collision contexts for jobs that are currently executing.
activeMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Returns active MaintenanceTask by its name.
activeTaskFutures() - Method in interface org.apache.ignite.IgniteCompute
Gets tasks future for active tasks started on local node.
AdaptableDatasetModel<I,O,IW,OW,M extends IgniteModel<IW,OW>> - Class in org.apache.ignite.ml.trainers
Model which is composition of form before `andThen` inner Mdl `andThen` after.
AdaptableDatasetModel(IgniteFunction<I, IW>, M, IgniteFunction<OW, O>) - Constructor for class org.apache.ignite.ml.trainers.AdaptableDatasetModel
Construct instance of this class.
AdaptableDatasetTrainer<I,O,IW,OW,M extends IgniteModel<IW,OW>,L> - Class in org.apache.ignite.ml.trainers
Type used to adapt input and output types of wrapped DatasetTrainer.
AdaptiveCpuLoadProbe - Class in org.apache.ignite.spi.loadbalancing.adaptive
Implementation of node load probing based on CPU load.
AdaptiveCpuLoadProbe() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Initializes CPU load probe to use CPU load average by default.
AdaptiveCpuLoadProbe(boolean, boolean) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Specifies whether to use average CPU load vs. current and whether or not to take number of processors into account.
AdaptiveCpuLoadProbe(boolean, boolean, double) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Specifies whether to use average CPU load vs. current and whether or not to take number of processors into account.
AdaptiveJobCountLoadProbe - Class in org.apache.ignite.spi.loadbalancing.adaptive
Implementation of node load probing based on active and waiting job count.
AdaptiveJobCountLoadProbe() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Initializes active job probe.
AdaptiveJobCountLoadProbe(boolean) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Creates new active job prove specifying whether to use average job counts vs. current.
AdaptiveLoadBalancingSpi - Class in org.apache.ignite.spi.loadbalancing.adaptive
Load balancing SPI that adapts to overall node performance.
AdaptiveLoadBalancingSpi() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
 
AdaptiveLoadBalancingSpiMBean - Interface in org.apache.ignite.spi.loadbalancing.adaptive
Management MBean for AdaptiveLoadBalancingSpi SPI.
AdaptiveLoadProbe - Interface in org.apache.ignite.spi.loadbalancing.adaptive
Pluggable implementation of node load probing.
AdaptiveProcessingTimeLoadProbe - Class in org.apache.ignite.spi.loadbalancing.adaptive
Implementation of node load probing based on total job processing time.
AdaptiveProcessingTimeLoadProbe() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Initializes execution time load probe to use execution time average by default.
AdaptiveProcessingTimeLoadProbe(boolean) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Specifies whether to use average execution time vs. current.
add(T) - Method in interface org.apache.ignite.client.ClientIgniteSet
add(T) - Method in interface org.apache.ignite.IgniteQueue
add(T) - Method in interface org.apache.ignite.IgniteSet
add(double, M) - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
Adds a specific binary classifier to the bunch of same classifiers.
add(MLPArchitecture) - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Creates config describing network where first goes this config and after goes this method's argument.
add(MultilayerPerceptron) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Create MLP where this MLP output is fed as input to added MLP.
add(GiniImpurityMeasure) - Method in class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasure
Adds the given impurity to this.
add(T) - Method in interface org.apache.ignite.ml.tree.impurity.ImpurityMeasure
Adds the given impurity to this.
add(MSEImpurityMeasure) - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
Adds the given impurity to this.
add(StepFunction<T>) - Method in class org.apache.ignite.ml.tree.impurity.util.StepFunction
Adds the given step function to this.
add(VectorGenerator, double) - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.Builder
Add generator to family with weight proportional to it selection probability.
add(VectorGenerator) - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.Builder
Adds generator to family with weight = 1.
add(Vector, Vector) - Method in class org.apache.ignite.ml.util.generators.standard.GaussianMixtureDataStream.Builder
Adds multidimentional gaussian component.
add(Throwable) - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
Adds a new cause for multi-exception.
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.client.ClientIgniteSet
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteQueue
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteSet
addAndGet(long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Adds l and gets current value of atomic long.
addAndGet(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Adds l and gets current value of atomic long.
addAndGet(long) - Method in interface org.apache.ignite.IgniteAtomicSequence
Adds l elements to atomic sequence and gets value of atomic sequence.
addAppender(FileAppender) - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
Adds file appender.
addAttributeListener(ComputeTaskSessionAttributeListener, boolean) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Add listener for the session attributes.
addCacheConfiguration(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Adds cache configuration template.
addCacheConfiguration(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Adds cache configuration template.
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
addData(K, V) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Map.Entry<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Collection<? extends Map.Entry<K, V>>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Map<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addElement(T) - Method in interface org.apache.ignite.ml.dataset.feature.Histogram
Add object to histogram.
addElement(T) - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
Add object to histogram.
addElement(BootstrappedVector) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
Add object to histogram.
addElement(BootstrappedVector) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
Add object to histogram.
addElementToLeafStatistic(ObjectHistogram<BootstrappedVector>, BootstrappedVector, int) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.ClassifierLeafValuesComputer
Save vector to leaf statistic.
addElementToLeafStatistic(T, BootstrappedVector, int) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.LeafValuesComputer
Save vector to leaf statistic.
addElementToLeafStatistic(MeanValueStatistic, BootstrappedVector, int) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.RegressionLeafValuesComputer
Save vector to leaf statistic.
addField(String, String) - Method in class org.apache.ignite.ml.util.ModelTrace
Add field.
addField(String, List) - Method in class org.apache.ignite.ml.util.ModelTrace
Add field.
addGridCommonData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addHyperParam(String, DoubleConsumer, Double[]) - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
Adds a grid for the specific hyper parameter.
addIncomeConnectionListener(IgniteInClosure<Socket>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
addJoiningNodeData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addListener(IgnitionListener) - Static method in class org.apache.ignite.Ignition
Adds a lsnr for grid life cycle events.
addLocalEventListener(GridLocalEventListener, int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Adds an event listener for local events.
addLocalMessageListener(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Register an local message listener to receive messages sent by remote nodes.
addLog(String) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Logs work to span.
addLog(String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Logs work to span.
addLog(String) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Logs work to span.
addMatrix2MatrixTrainer(DatasetTrainer<M1, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Shortcut for adding trainer Matrix -> Matrix where this trainer is treated as Vector -> Vector, where input Vector is turned into 1 x cols Matrix and output is a first row of output Matrix.
addMessage(T) - Method in class org.apache.ignite.stream.StreamAdapter
Converts given message to 1 or many tuples (depending on the type of extractor) and adds it/them to the underlying streamer.
addMessageListener(GridMessageListener, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
addMeta(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Adds a new metadata.
addMetricRegistryCreationListener(Consumer<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Register listener which will be notified on metric registry creation.
addMetricRegistryCreationListener(Consumer<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricManager
Adds listener of metrics registry creation events.
addMetricRegistryRemoveListener(Consumer<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricManager
Adds listener of metrics registry remove events.
addNodeSpecificData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addPaging(StringBuilder, Pageable) - Static method in class org.apache.ignite.springdata22.repository.query.IgniteQueryGenerator
Add a dynamic part of a query for the pagination support.
addPreprocessingTrainer(PreprocessingTrainer) - Method in class org.apache.ignite.ml.pipeline.Pipeline
Adds a preprocessor.
addQueryField(String, String, String) - Method in class org.apache.ignite.cache.QueryEntity
Utility method for building query entities programmatically.
address() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets subject network address.
address(InetSocketAddress) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets subject network address.
address() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject connection address.
address() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
Gets subject connection address.
addresses() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets collection of addresses this node is known by.
addresses() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
addresses() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collection of addresses this node is known by.
addresses() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
AddressResolver - Interface in org.apache.ignite.configuration
Provides resolution between external and internal addresses.
addSendMessageListener(IgniteInClosure<TcpDiscoveryAbstractMessage>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
addSorting(StringBuilder, Sort) - Static method in class org.apache.ignite.springdata22.repository.query.IgniteQueryGenerator
Add a dynamic part of query for the sorting support.
addSystemViewCreationListener(Consumer<SystemView<?>>) - Method in interface org.apache.ignite.spi.systemview.ReadOnlySystemViewRegistry
Adds listener of view creation events.
addTag(String, String) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Adds tag to span with String value.
addTag(String, String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Adds tag to span with String value.
addTag(String, String) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Adds tag to span with String value.
addTask(String, UUID, int) - Method in class org.apache.ignite.tensorflow.cluster.spec.TensorFlowClusterSpec
Adds new task to the cluster specification.
addTimeoutObject(IgniteSpiTimeoutObject) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
addTimeoutObject(IgniteSpiTimeoutObject) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
addTrainer(DatasetTrainer<M1, L>) - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Adds submodel trainer along with converters needed on training and inference stages.
addTrainer(DatasetTrainer<M1, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Adds submodel trainer along with converters needed on training and inference stages.
addTrainer(DatasetTrainer<M1, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Adds submodel trainer along with converters needed on training and inference stages.
addTrainer(DatasetTrainer) - Method in class org.apache.ignite.ml.pipeline.Pipeline
Adds a trainer.
addTrainerWithDoubleOutput(DatasetTrainer<M1, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Shortcut for adding trainer Vector -> Double where this trainer is treated as Vector -> Vector, where output Vector is constructed by wrapping double value.
addVectorizer(Vectorizer<K, V, C, L>) - Method in class org.apache.ignite.ml.pipeline.Pipeline
 
Affinity<K> - Interface in org.apache.ignite.cache.affinity
Provides affinity information to detect which node is primary and which nodes are backups for a partitioned or replicated cache.
affinity() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
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(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets affinity service to provide information about data partitioning and distribution.
affinity() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
affinity() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
AFFINITY_CALL_ATTEMPT - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Name of job context attribute containing number of affinity call attempts.
affinityCacheIds() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
affinityCacheName() - Method in interface org.apache.ignite.spi.failover.FailoverContext
affinityCacheName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
affinityCall(String, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCall(Collection<String>, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCall(Collection<String>, int, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where partition is located (the partition is primary on the node) It's guaranteed that the data of all the partitions of all participating caches, the affinity key belongs to, will present on the destination node throughout the job execution.
affinityCall(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteQueue
Executes given job on collocated queue on the node where the queue is located (a.k.a. affinity co-location).
affinityCall(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteSet
Executes given job on collocated set on the node where the set is located (a.k.a. affinity co-location).
affinityCallAsync(String, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCallAsync(Collection<String>, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCallAsync(Collection<String>, int, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where partition is located (the partition is primary on the node) The data of the partition will not be migrated from the target node while the job is executed.
affinityCallWithRetries(Ignite, Collection<String>, IgniteFunction<Integer, R>, int, int, DeployingContext) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Calls the specified fun function on all partitions so that is't guaranteed that partitions with the same index of all specified caches will be placed on the same node and will not be moved before computation is finished.
affinityCallWithRetries(Ignite, Collection<String>, IgniteFunction<Integer, R>, int, DeployingContext) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Calls the specified fun function on all partitions so that is't guaranteed that partitions with the same index of all specified caches will be placed on the same node and will not be moved before computation is finished.
AffinityCentralizedFunction - Annotation Type in org.apache.ignite.cache.affinity
Annotation marker which identifies affinity function that must be calculated on one centralized node instead of independently on each node.
affinityColumn() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
AffinityFunction - Interface in org.apache.ignite.cache.affinity
Cache key affinity which maps keys to nodes.
AffinityFunctionContext - Interface in org.apache.ignite.cache.affinity
Affinity function context.
affinityKey(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Maps passed in key to a key which will be used for node affinity.
AffinityKey<K> - Class in org.apache.ignite.cache.affinity
Optional wrapper for cache keys to provide support for custom affinity mapping.
AffinityKey() - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Empty constructor.
AffinityKey(K) - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Initializes key wrapper for a given key.
AffinityKey(K, Object) - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Initializes key together with its affinity key counter-part.
affinityKey() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Gets affinity key to use for affinity mapping.
affinityKey(Object) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Sets affinity key to use for affinity mapping.
affinityKey(Object) - Method in interface org.apache.ignite.cache.affinity.AffinityKeyMapper
Deprecated.
Maps passed in key to an alternate key which will be used for node affinity.
affinityKey() - Method in interface org.apache.ignite.services.ServiceContext
Gets affinity key used for key-to-node affinity calculation.
affinityKey() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets affinity key used for key-to-node affinity calculation.
affinityKey() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
affinityKeyColumn() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns name of affinity key column.
affinityKeyFieldName() - Method in interface org.apache.ignite.binary.BinaryType
Binary objects can optionally specify custom key-affinity mapping in the configuration.
AffinityKeyMapped - Annotation Type in org.apache.ignite.cache.affinity
Optional annotation to specify custom key-to-node affinity.
AffinityKeyMapper - Interface in org.apache.ignite.cache.affinity
affinityMapper() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
affinityPartitionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
affinityPartitionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
affinityRun(String, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRun(Collection<String>, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRun(Collection<String>, int, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where partition is located (the partition is primary on the node) It's guaranteed that the data of all the partitions of all participating caches, the affinity key belongs to, will present on the destination node throughout the job execution.
affinityRun(IgniteRunnable) - Method in interface org.apache.ignite.IgniteQueue
Executes given job on collocated queue on the node where the queue is located (a.k.a. affinity co-location).
affinityRun(IgniteRunnable) - Method in interface org.apache.ignite.IgniteSet
Executes given job on collocated set on the node where the set is located (a.k.a. affinity co-location).
affinityRunAsync(String, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRunAsync(Collection<String>, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRunAsync(Collection<String>, int, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where partition is located (the partition is primary on the node) The data of the partition will not be migrated from the target node while the job is executed.
AffinityUuid - Class in org.apache.ignite.cache.affinity
Guaranteed unique affinity-based key.
AffinityUuid() - Constructor for class org.apache.ignite.cache.affinity.AffinityUuid
Empty constructor.
AffinityUuid(Object) - Constructor for class org.apache.ignite.cache.affinity.AffinityUuid
Constructs unique affinity UUID based on affinity key.
affKey - Variable in class org.apache.ignite.services.ServiceConfiguration
Affinity key.
afterFeatureExtractor(IgniteFunction<Vector, Vector>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Specify function which will be applied after feature extractor.
afterInnerMessageRead(boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback called after inner message is read.
afterInnerMessageWrite(boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called after inner message is written.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate inserted object in the database and transaction successfully completed.
afterInsert(SharedSessionContractImplementor, Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
afterInsert(SharedSessionContractImplementor, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
afterLabelExtractor(IgniteFunction<L, L>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Specify function which will be applied after label extractor.
afterMessageRead(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback that must be invoked by a message implementation after message body finished decoding.
afterSingletonsInstantiated() - Method in class org.apache.ignite.IgniteSpringBean
afterTrainedModel(IgniteFunction<O, O1>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Let this trainer produce model mdl.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate updated object in the database and transaction successfully completed.
afterUpdate(SharedSessionContractImplementor, Object, Object, Object, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
afterUpdate(SharedSessionContractImplementor, Object, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
aggregateImpurityStatistics(ArrayList<TreeRoot>, Map<Integer, BucketMeta>, Map<NodeId, TreeNode>, Dataset<EmptyContext, BootstrappedDatasetPartition>) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer
Computes histograms for each feature.
alias() - Method in class org.apache.ignite.events.DeploymentEvent
Gets deployment alias for this event.
alias(String) - Method in class org.apache.ignite.events.DeploymentEvent
Sets deployment alias for this event.
all() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets iterator over all elements in this vector.
all() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets iterator over all elements in this vector.
all() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets iterator over all elements in this vector.
ALL - Static variable in class org.apache.ignite.ml.tree.randomforest.data.FeaturesCountSelectionStrategies
 
ALL_NODES - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Filter that accepts all nodes.
allActions() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Supplies list of MaintenanceActions that user can call to fix maintenance situation for the component or get information about ongoing actions.
allAddresses() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets All subject network addresses.
allAddresses(List<InetSocketAddress>) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets All subject network addresses.
allCoords(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.ArrayLikeVectorizer
Returns list of all coordinate with feature values.
allCoords(K, BinaryObject) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Returns list of all coordinate with feature values.
allCoords(K, LabeledVector<L>) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.LabeledDummyVectorizer
Returns list of all coordinate with feature values.
allCoords(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Returns list of all coordinate with feature values.
allCoords(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.VectorizerAdapter
Returns list of all coordinate with feature values.
allGrids() - Static method in class org.apache.ignite.Ignition
Gets a list of all grids started so far.
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
allNodesSupport(IgniteFeatures, IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
allNodesSupport(IgniteFeatures, IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
allNodesSupport(IgniteFeatures, IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
allocateMemory(long) - Method in interface org.apache.ignite.mem.MemoryAllocator
 
ALLOW_ALL - Static variable in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
allowOverwrite() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag enabling overwriting existing values in cache.
allowOverwrite(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag enabling overwriting existing values in cache.
allPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which given cluster node has any ownership (either primary or backup).
allSpliterator() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets spliterator for all values in this matrix.
allSpliterator() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets spliterator for all values in this matrix.
allSpliterator() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets spliterator for all values in this vector.
allSpliterator() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets spliterator for all values in this vector.
allSpliterator() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets spliterator for all values in this vector.
allUpdatesReducer() - Method in class org.apache.ignite.ml.nn.UpdatesStrategy
Get function used to reduce updates from different trainings (for example, averaging of gradients of all parallel trainings).
ALREADY_CONNECTED - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
alreadyProcessed(int) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Checks if row/object with specified sequential number is already processed.
alreadyProcessed(int) - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Checks if row/object with specified sequential number is already processed.
AlwaysFailoverSpi - Class in org.apache.ignite.spi.failover.always
Failover SPI that always reroutes a failed job to another node.
AlwaysFailoverSpi() - Constructor for class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
 
AlwaysFailoverSpiMBean - Interface in org.apache.ignite.spi.failover.always
Management bean for AlwaysFailoverSpi.
amountOfFolds - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Amount of folds.
and(IgniteBiPredicate<E1, E2>) - Method in interface org.apache.ignite.lang.IgniteBiPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(TreeFilter) - Method in interface org.apache.ignite.ml.tree.TreeFilter
Returns a composed predicate.
andBefore(IgniteFunction<V1, T>) - Method in interface org.apache.ignite.ml.IgniteModel
Get a composition model of the form x -> mdl(before(x)).
andBefore(IgniteFunction<I1, I>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetModel
Create new AdaptableDatasetModel which is a composition of the form thisMdl . before.
andThen(IgniteFunction<C, C2>) - Method in interface org.apache.ignite.ml.dataset.PartitionContextBuilder
Makes a composed partition context builder that first builds a context and then applies the specified function on the result.
andThen(IgniteBiFunction<D, C, D2>) - Method in interface org.apache.ignite.ml.dataset.PartitionDataBuilder
Makes a composed partition data builder that first builds a data and then applies the specified function on the result.
andThen(UpstreamTransformerBuilder) - Method in interface org.apache.ignite.ml.dataset.UpstreamTransformerBuilder
Combunes two builders (this and other respectfully) env -> transformer1 env -> transformer2 into env -> transformer2 . transformer1
andThen(IgniteModel<V, V1>) - Method in interface org.apache.ignite.ml.IgniteModel
Get a composition model of the form x -> after(mdl(x)).
andThen(IgniteFunction<V, V1>) - Method in interface org.apache.ignite.ml.IgniteModel
Get a composition model of the form x -> after(mdl(x)).
andThen(IgniteFunction<? super R, ? extends V>) - Method in interface org.apache.ignite.ml.math.functions.IgniteBiFunction
 
andThen(IgniteFunction<? super R, ? extends V>) - Method in interface org.apache.ignite.ml.math.functions.IgniteFunction
Compose this function and given function.
andThen(Function<? super R, ? extends V>) - Method in interface org.apache.ignite.ml.math.functions.IgniteTriFunction
 
andThen(IgniteModel<O, O1>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetModel
Get a composition model of the form x -> after(mdl(x)).
andThen(DatasetTrainer<M1, L>, IgniteFunction<AdaptableDatasetModel<I, O, IW, OW, M>, IgniteFunction<LabeledVector<L>, LabeledVector<L>>>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Create a TrainersSequentialComposition of whis trainer and specified trainer.
ANNClassificationModel - Class in org.apache.ignite.ml.knn.ann
ANN model to predict labels in multi-class classification task.
ANNClassificationModel(LabeledVectorSet<LabeledVector>, ANNClassificationTrainer.CentroidStat) - Constructor for class org.apache.ignite.ml.knn.ann.ANNClassificationModel
Build the model based on a candidates set.
ANNClassificationTrainer - Class in org.apache.ignite.ml.knn.ann
ANN algorithm trainer to solve multi-class classification task.
ANNClassificationTrainer() - Constructor for class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
 
ANNClassificationTrainer.CentroidStat - Class in org.apache.ignite.ml.knn.ann
Service class used for statistics.
ANNModelFormat - Class in org.apache.ignite.ml.knn.ann
ANN model representation.
ANNModelFormat(int, DistanceMeasure, boolean, LabeledVectorSet<LabeledVector>, ANNClassificationTrainer.CentroidStat) - Constructor for class org.apache.ignite.ml.knn.ann.ANNModelFormat
Creates an instance.
appendCachePermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form cache with name.
appendPermissionSet(SecurityPermissionSet) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set.
appendServicePermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form service with name.
appendSystemPermissions(SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append system permission set.
appendTaskPermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form task with name.
appendTracingPermissions(SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append tracing permission set.
ApplicationMaster - Class in org.apache.ignite.yarn
Application master request containers from Yarn and decides how many resources will be occupied.
ApplicationMaster(String, ClusterProperties) - Constructor for class org.apache.ignite.yarn.ApplicationMaster
 
apply(ClusterNode, List<ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
Defines a predicate which returns true if a node is acceptable for a backup or false otherwise.
apply(ClusterNode) - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
Predicate body.
apply(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on a node within the underlying cluster group.
apply(IgniteClosure<T, R>, Collection<? extends T>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within the underlying cluster group.
apply(IgniteClosure<T, R1>, Collection<? extends T>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within the underlying cluster group.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiClosure
Closure body.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiInClosure
Closure body.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiPredicate
Predicate body.
apply(E) - Method in interface org.apache.ignite.lang.IgniteClosure
Closure body.
apply(E) - Method in interface org.apache.ignite.lang.IgniteInClosure
Closure body.
apply() - Method in interface org.apache.ignite.lang.IgniteOutClosure
Closure body.
apply(E) - Method in interface org.apache.ignite.lang.IgnitePredicate
Predicate body.
apply(UUID, T) - Method in class org.apache.ignite.messaging.MessagingListenActor
Predicate body.
apply(double[]) - Method in class org.apache.ignite.ml.composition.predictionsaggregator.MeanValuePredictionsAggregator
apply(double[]) - Method in class org.apache.ignite.ml.composition.predictionsaggregator.OnMajorityPredictionsAggregator
apply(double[]) - Method in class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
apply(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Extracts labeled vector from upstream object.
apply(int, double) - Method in interface org.apache.ignite.ml.math.functions.IgniteIntDoubleToDoubleBiFunction
 
apply(int, int) - Method in interface org.apache.ignite.ml.math.functions.IgniteIntIntToIntBiFunction
 
apply(A, B, C) - Method in interface org.apache.ignite.ml.math.functions.IgniteTriFunction
 
apply(int, int, double) - Method in interface org.apache.ignite.ml.math.functions.IntIntDoubleToVoidFunction
 
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.binarization.BinarizationPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.developer.MappedPreprocessor
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.developer.PatchedPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.encoding.onehotencoder.OneHotEncoderPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.encoding.stringencoder.StringEncoderPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.normalization.NormalizationPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerPreprocessor
Applies this preprocessor.
apply(Object) - Method in class org.apache.ignite.spi.indexing.IndexingQueryCacheFilter
Apply filter.
apply(IgniteConfiguration) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Closure body.
apply(UUID, Optional<TensorFlowCluster>) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGateway
Predicate body.
apply(Certificate[]) - Method in class org.gridgain.grid.security.certificate.IssuerRegexPredicate
Checks whether passed certificate is X.509 certificate with Issuer DN matches the pattern.
apply(Certificate[]) - Method in class org.gridgain.grid.security.certificate.SubjectRegexPredicate
Checks whether passed certificate is X.509 certificate with Subject DN matches the pattern.
applyAsync(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job asynchronously on a node within the underlying cluster group.
applyAsync(IgniteClosure<T, R>, Collection<? extends T>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job asynchronously on nodes within the underlying cluster group.
applyAsync(IgniteClosure<T, R1>, Collection<? extends T>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job asynchronously on nodes within the underlying cluster group.
applyGradient(Map<O, Vector>, Map<S, Vector>) - Method in class org.apache.ignite.ml.recommendation.util.MatrixFactorizationGradient
Applies given gradient to recommendation model (object matrix and subject matrix) and updates this model correspondingly.
applyPartition(int) - Method in class org.apache.ignite.spi.indexing.IndexingQueryCacheFilter
Apply filter.
architecture - Variable in class org.apache.ignite.ml.nn.MultilayerPerceptron
This MLP architecture.
architecture() - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get architecture of this MLP.
argmin(List<A>, IgniteFunction<A, B>) - Static method in class org.apache.ignite.ml.math.functions.Functions
 
argument(int) - Method in class org.apache.ignite.compute.ComputeJobAdapter
Gets job argument.
arguments() - Method in class org.apache.ignite.compute.ComputeJobAdapter
Gets array of job arguments.
arguments() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query arguments.
arguments() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query arguments.
ArrayLikeVectorizer(Integer...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.ArrayLikeVectorizer
Creates an instance of Vectorizer.
ArraySpatialIndex<L> - Class in org.apache.ignite.ml.knn.utils.indices
Array based implementation of SpatialIndex.
ArraySpatialIndex(List<LabeledVector<L>>, DistanceMeasure) - Constructor for class org.apache.ignite.ml.knn.utils.indices.ArraySpatialIndex
Construct a new array spatial index.
asArray() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Returns array of doubles corresponds to vector components.
asAscii(Vector, String, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
 
asAscii(Matrix, String) - Static method in class org.apache.ignite.ml.math.Tracer
 
asDatasetBuilder(int, int) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Convert first N values from stream to DatasetBuilder.
asDatasetBuilder(int, IgniteBiPredicate<Vector, Double>, int) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Convert first N values from stream to DatasetBuilder.
asDatasetBuilder(int, IgniteBiPredicate<Vector, Double>, int, UpstreamTransformerBuilder) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Convert first N values from stream to DatasetBuilder.
asDataStream() - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Conterts vectors generator to unlabeled data stream generator.
asDataStream() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily
Creates data stream where label of vector == id of distribution from family.
asDense(SparseMatrix, int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
 
asFeatureExtractor(FeatureLabelExtractor<K, V, L>) - Static method in class org.apache.ignite.ml.composition.CompositionUtils
Create feature extractor from given mapping (key, value) -> LabeledVector.
asLabelExtractor(FeatureLabelExtractor<K, V, L>) - Static method in class org.apache.ignite.ml.composition.CompositionUtils
Label extractor feature extractor from given mapping (key, value) -> LabeledVector.
asLIBSVM(String, String, String, Random, int) - Static method in class org.apache.ignite.ml.util.MnistUtils
Convert random count samples from MNIST dataset from two files (images and labels) into libsvm format.
asMap(int) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Convert first N values from stream to map.
assertAccessMode(int) - Method in interface org.apache.ignite.ml.math.StorageConstants
 
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.
assertStorageMode(int) - Method in interface org.apache.ignite.ml.math.StorageConstants
 
assign(double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Assigns given value to all elements of this matrix.
assign(IntIntToDoubleFunction) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Assigns each matrix element to the value generated by given function.
assign(double[][]) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Assigns given values to this matrix.
assign(Matrix) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Assigns values from given matrix to this matrix.
assign(double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Assigns given value to all elements of this matrix.
assign(double[][]) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Assigns given values to this matrix.
assign(Matrix) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Assigns values from given matrix to this matrix.
assign(IntIntToDoubleFunction) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Assigns each matrix element to the value generated by given function.
assign(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Assigns given value to all elements of this vector.
assign(double[]) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Assigns values from given array to this vector.
assign(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Copies values from the argument vector to this one.
assign(IntToDoubleFunction) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Assigns each vector element to the value generated by given function.
assign(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Assigns given value to all elements of this vector.
assign(double[]) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Assigns values from given array to this vector.
assign(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Copies values from the argument vector to this one.
assign(IntToDoubleFunction) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Assigns each vector element to the value generated by given function.
assign(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Assigns given value to all elements of this vector.
assign(double[]) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Assigns values from given array to this vector.
assign(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Copies values from the argument vector to this one.
assign(IntToDoubleFunction) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Assigns each vector element to the value generated by given function.
assignColumn(int, Vector) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Assigns values from given vector to the specified column in this matrix.
assignColumn(int, Vector) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Assigns values from given vector to the specified column in this matrix.
assignPartition(int, List<ClusterNode>, int, Map<UUID, Collection<ClusterNode>>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Returns collection of nodes (primary first) for specified partition.
assignPartitions(AffinityFunctionContext) - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Gets affinity nodes for a partition.
assignPartitions(AffinityFunctionContext) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets affinity nodes for a partition.
assignPartitions(AffinityFunctionContext) - Method in class org.apache.ignite.ml.dataset.impl.cache.util.DatasetAffinityFunctionWrapper
Gets affinity nodes for a partition.
assignPartitions(AffinityFunctionContext) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets affinity nodes for a partition.
assignRow(int, Vector) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Assigns values from given vector to the specified row in this matrix.
assignRow(int, Vector) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Assigns values from given vector to the specified row in this matrix.
asStream(Iterator<T>, long) - Static method in class org.apache.ignite.ml.util.Utils
Convert given iterator to a stream with known count of entries.
asStream(Iterator<T>) - Static method in class org.apache.ignite.ml.util.Utils
Convert given iterator to a stream.
AsymmetricKeyEncryptionService - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt
Provides an implementation of asymmetric encryption to encrypt/decrypt the data.
AsymmetricKeyEncryptionService() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionService
 
AsyncModelBuilder - Interface in org.apache.ignite.ml.inference.builder
Builder of asynchronous inference model.
AsyncNativeProcessRunner - Class in org.apache.ignite.tensorflow.core.util
Asynchronous native process runner.
AsyncNativeProcessRunner(Ignite, ExecutorService) - Constructor for class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Constructs a new asynchronous native process runner.
AtomicConfiguration - Class in org.apache.ignite.configuration
Configuration for atomic data structures.
AtomicConfiguration() - Constructor for class org.apache.ignite.configuration.AtomicConfiguration
 
atomicityMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
atomicityMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
atomicLong(String, long, boolean) - Method in interface org.apache.ignite.client.IgniteClient
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, ClientAtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.client.IgniteClient
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, AtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, AtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
 
AtomicLongView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicLong representation for a SystemView.
AtomicLongView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicLongView
 
atomicReference(String, T, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, AtomicConfiguration, T, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, T, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, AtomicConfiguration, T, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
AtomicReferenceView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicReference representation for a SystemView.
AtomicReferenceView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicReferenceView
 
atomicSequence(String, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, AtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, AtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
AtomicSequenceView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicSequence representation for a SystemView.
AtomicSequenceView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
atomicStamped(String, T, S, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, AtomicConfiguration, T, S, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, T, S, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, AtomicConfiguration, T, S, boolean) - Method in class org.apache.ignite.IgniteSpringBean
 
AtomicStampedView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicStamped representation for a SystemView.
AtomicStampedView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
attach(Object) - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Attaches the given object to this session.
AttachCommand - Class in org.apache.ignite.tensorflow.submitter.command
Command "attach" that is used to attach to running TensorFlow cluster and receive output of the user script.
AttachCommand() - Constructor for class org.apache.ignite.tensorflow.submitter.command.AttachCommand
 
attachment() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Retrieves the current attachment or null if there is no attachment.
ATTR_ADDRS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node IP addresses (value is comm.tcp.addrs).
ATTR_CONN_PROP - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Connection attribute property name.
ATTR_EXT_ADDRS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node's external addresses (value is comm.tcp.ext-addrs).
ATTR_EXT_ADDRS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Node attribute that is mapped to node's external addresses (value is disc.tcp.ext-addrs).
ATTR_FORCE_CLIENT_SERVER_CONNECTIONS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
ATTR_HOST_NAMES - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node host names (value is comm.tcp.host.names).
ATTR_PAIRED_CONN - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Attr paired connection.
ATTR_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node port number (value is comm.tcp.port).
ATTR_PREFIX - Static variable in class org.gridgain.grid.GridNodeAttributes
Prefix for internally reserved attribute names.
ATTR_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node port number (value is comm.shmem.tcp.port).
attribute(String) - Method in interface org.apache.ignite.cluster.BaselineNode
Gets a node attribute.
attribute(String) - Method in interface org.apache.ignite.cluster.ClusterNode
Gets a node attribute.
attribute(String) - Method in interface org.apache.ignite.services.ServiceCallContext
Get the string attribute.
attribute(String) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets a node attribute.
attributeName() - Method in interface org.gridgain.grid.product.ProductLicense
Gets license attribute name if any.
attributeNames() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get distinct attribute names for given nodes projection.
AttributeNames - Class in org.apache.ignite.spi.communication.tcp
Deprecated.
fix it in the ticket https://ggsystems.atlassian.net/browse/GG-29546
AttributeNames(String, String, String, String, String, String, String) - Constructor for class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
attributes() - Method in interface org.apache.ignite.cluster.BaselineNode
Gets all node attributes.
attributes() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets all node attributes.
attributes() - Method in class org.apache.ignite.events.TaskWithAttributesEvent
Gets map of attributes from attached task session.
attributes() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets all node attributes.
attributeValue() - Method in interface org.gridgain.grid.product.ProductLicense
Gets value for the license attribute if any.
attributeValues(String) - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get distinct attribute values for given nodes projection.
authenticate(AuthenticationContext) - Method in interface org.gridgain.grid.security.Authenticator
Authenticates a given subject (either node or remote client).
authenticate(AuthenticationContext) - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
Authenticates a given subject (either node or remote client).
authenticate(AuthenticationContext) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Authenticates a given subject (either node or remote client).
authenticate(AuthenticationContext) - Method in class org.gridgain.grid.security.passcode.IgniteAuthenticator
Authenticates a given subject (either node or remote client).
authenticate(AuthenticationContext) - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Authenticates a given subject (either node or remote client).
authenticatedSubject(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets security subject based on subject ID.
authenticatedSubject(UUID) - Method in interface org.gridgain.grid.GridSecurity
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.
authenticatedSubjects() - Method in interface org.gridgain.grid.GridSecurity
Gets collection of authenticated subjects together with their permissions.
authenticateNode(ClusterNode, SecurityCredentials) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
Security credentials.
AuthenticationAclBasicProvider - Class in org.gridgain.grid.security.passcode
Basic ACL provider.
AuthenticationAclBasicProvider(Map<SecurityCredentials, String>) - Constructor for class org.gridgain.grid.security.passcode.AuthenticationAclBasicProvider
Creates basic ACL provider.
AuthenticationAclProvider - Interface in org.gridgain.grid.security.passcode
Access control list provider.
AuthenticationContext - Class in org.apache.ignite.plugin.security
Authentication context.
AuthenticationContext() - Constructor for class org.apache.ignite.plugin.security.AuthenticationContext
 
AuthenticationEvent - Class in org.gridgain.grid.events
Grid authentication event.
AuthenticationEvent() - Constructor for class org.gridgain.grid.events.AuthenticationEvent
No-arg constructor.
AuthenticationEvent(ClusterNode, String, int) - Constructor for class org.gridgain.grid.events.AuthenticationEvent
Creates authentication event with given parameters.
AuthenticationEvent(ClusterNode, String, int, SecuritySubjectType, UUID, Object, InetSocketAddress) - Constructor for class org.gridgain.grid.events.AuthenticationEvent
Creates authentication event with given parameters.
AuthenticationEvent(ClusterNode, String, int, SecuritySubjectType, UUID, Object, InetSocketAddress, List<InetSocketAddress>) - Constructor for class org.gridgain.grid.events.AuthenticationEvent
Creates authentication event with given parameters.
authenticationFailedError(TcpDiscoveryAuthFailedMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
AuthenticationValidator - Interface in org.gridgain.grid.security
An implementation of Authenticator interface can optionally implement this interface to enable authenticator consistency configuration check on all nodes in topology.
Authenticator - Interface in org.gridgain.grid.security
Authenticator used for authenticating grid nodes.
authorizationContext() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
 
authorizationContext(AuthorizationContext) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Set authorization context acquired after native Apache Ignite authentication.
AuthorizationEvent - Class in org.gridgain.grid.events
Grid authorization event.
AuthorizationEvent() - Constructor for class org.gridgain.grid.events.AuthorizationEvent
No-arg constructor.
AuthorizationEvent(ClusterNode, String, int) - Constructor for class org.gridgain.grid.events.AuthorizationEvent
Creates authorization event with given parameters.
AuthorizationEvent(ClusterNode, String, int, SecurityPermission, SecuritySubject) - Constructor for class org.gridgain.grid.events.AuthorizationEvent
Creates authorization event with given parameters.
autoAdjustTimeout() - Method in class org.apache.ignite.events.BaselineConfigurationChangedEvent
Auto-adjust timeout value in milliseconds.
autoDelete() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets autoDelete flag.
autoDelete() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
autoFlushFrequency() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets automatic flush frequency.
autoFlushFrequency(long) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets automatic flush frequency.
autoIncrement() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
automaticAction() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Component can provide optional MaintenanceAction that will be executed automatically by MaintenanceRegistry when node enters maintenance mode.
autoUnsubscribe() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
AVAILABLE_PROC_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
availablePermits() - Method in interface org.apache.ignite.IgniteSemaphore
Returns the current number of permits available in this semaphore.
availablePermits() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
averageBatchAckTime() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets average time in milliseconds between sending batch to receiver cache nodes and successfully storing it.
averageBatchAckTime() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets average time in milliseconds between sending batch for the first time and receiving acknowledgement for it.
averageExecutionTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average execution time in milliseconds since future was created.
averageIdleTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average idle time for this scheduled task.
averageTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets average execution time of query.
averageTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets average execution time of query.
avg(List<NesterovParameterUpdate>) - Static method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Get average of parameters updates.
AVG - Static variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Averages updates returned by different trainings.
AVG - Static variable in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDParameterUpdate
Method used to sum updates inside of one of parallel trainings.
await() - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted.
await(long, TimeUnit) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
await() - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless current thread is interrupted.
await(long) - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
await(long, TimeUnit) - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
awaitNanos(long) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
awaitTermination(long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
awaitUninterruptibly() - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled.
awaitUntil(Date) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified deadline elapses.
AwsKmsEncryptionService - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt
Provides an implementation of AWS KMS to encrypt/decrypt the data.
AwsKmsEncryptionService() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
 
axpy(Double, Vector, Vector) - Static method in class org.apache.ignite.ml.math.Blas
Performs y += a * x

B

backoffTimeout(long, long) - Static method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
 
backupPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which given cluster node has backup ownership.
backupQueueSize() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets current amount of cache entries in backup queue.
backups() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets number of backups for new assignment.
backups() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
backups() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
BaggedModel - Class in org.apache.ignite.ml.composition.bagging
This class represents model produced by BaggedTrainer.
BaggedTrainer<L> - Class in org.apache.ignite.ml.composition.bagging
Trainer encapsulating logic of bootstrap aggregating (bagging).
BaggedTrainer(DatasetTrainer<? extends IgniteModel, L>, PredictionsAggregator, int, double, int, int) - Constructor for class org.apache.ignite.ml.composition.bagging.BaggedTrainer
Construct instance of this class with given parameters.
BaggingUpstreamTransformer - Class in org.apache.ignite.ml.trainers.transformers
This class encapsulates the logic needed to do bagging (bootstrap aggregating) by features.
BaggingUpstreamTransformer(long, double) - Constructor for class org.apache.ignite.ml.trainers.transformers.BaggingUpstreamTransformer
Construct instance of this transformer with a given subsample ratio.
balancedAccuracy() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Balanced accuracy.
BallTreeSpatialIndex<L> - Class in org.apache.ignite.ml.knn.utils.indices
Ball tree based implementation of SpatialIndex.
BallTreeSpatialIndex(List<LabeledVector<L>>, DistanceMeasure) - Constructor for class org.apache.ignite.ml.knn.utils.indices.BallTreeSpatialIndex
Constructs a new instance of Ball tree spatial index.
baselineAutoAdjustEnabled(boolean) - Method in interface org.apache.ignite.IgniteCluster
 
BaselineAutoAdjustMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on DistributedBaselineConfiguration.
baselineAutoAdjustStatus() - Method in interface org.apache.ignite.IgniteCluster
 
baselineAutoAdjustTimeout() - Method in interface org.apache.ignite.IgniteCluster
 
baselineAutoAdjustTimeout(long) - Method in interface org.apache.ignite.IgniteCluster
 
BaselineChangedEvent - Class in org.apache.ignite.events
Baseline changed event.
BaselineChangedEvent(ClusterNode, String, int, Collection<BaselineNode>) - Constructor for class org.apache.ignite.events.BaselineChangedEvent
Creates baseline changed event with given parameters.
BaselineConfigurationChangedEvent - Class in org.apache.ignite.events
Baseline configuration changed event.
BaselineConfigurationChangedEvent(ClusterNode, String, int, boolean, long) - Constructor for class org.apache.ignite.events.BaselineConfigurationChangedEvent
Creates baseline configuration changed event with given parameters.
BaselineNode - Interface in org.apache.ignite.cluster
Interface representing a single node from baseline topology.
baselineNodes() - Method in class org.apache.ignite.events.BaselineChangedEvent
New baseline nodes.
baselineNodes() - Method in class org.apache.ignite.events.ClusterActivationEvent
Deprecated.
Gets baseline nodes.
baselineNodes() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
Gets baseline nodes.
baselineTopology() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfoEx
Baseline topology on the moment when snapshot was created.
baseMdlTrainerBuilder - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Base model trainer builder.
BaseMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Base class to inherit from to implement specific mutations operation.
BaseMutation(String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Creates instance of mutation operation.
basePreprocessor - Variable in class org.apache.ignite.ml.preprocessing.encoding.EncoderPreprocessor
Base preprocessor.
BasicAddressResolver - Class in org.apache.ignite.configuration
Basic implementation of AddressResolver.
BasicAddressResolver(Map<String, String>) - Constructor for class org.apache.ignite.configuration.BasicAddressResolver
Created the address resolver.
BasicJdbcDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
Basic implementation of dialect based on JDBC specification.
BasicJdbcDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
 
BasicJdbcIpFinderDialect - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Basic JDBC dialect to use along with TcpDiscoveryJdbcIpFinder.
BasicJdbcIpFinderDialect() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.BasicJdbcIpFinderDialect
 
BasicWarmupClosure - Class in org.apache.ignite.startup
Basic warm-up closure which warm-ups cache operations.
BasicWarmupClosure() - Constructor for class org.apache.ignite.startup.BasicWarmupClosure
 
batchesAcked() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of sent batches acknowledged by sender hub.
batchesAcked() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets amount of batches stored in receiver caches.
batchesAcked() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets amount of sent batches with received acknowledgement from receiver hubs.
batchesFailed() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of failed batches.
batchesReceived() - Method in interface org.gridgain.grid.dr.DrReceiverInCacheMetrics
Gets the number of batches received from remote sender hubs.
batchesReceived() - Method in interface org.gridgain.grid.dr.DrSenderInMetrics
Gets amount of batches received from sender caches.
batchesRejected() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of rejected batches due to backpressure or any recoverable error.
batchesRejected() - Method in interface org.gridgain.grid.dr.DrSenderInMetrics
Gets amount of rejected batches.
batchesSent() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of batches sent to sender hubs.
batchesSent() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets amount of batches waiting to be stored in receiver caches.
batchesSent() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets amount of batches sent to receiver hubs.
BatchExecutionAssistant<R,V> - Interface in org.apache.ignite.cache.store.cassandra.session
Provides information for batch operations (loadAll, deleteAll, writeAll) of Ignite cache backed by CassandraCacheStore.
BatchLoaderAssistant - Interface in org.apache.ignite.cache.store.cassandra.session
Provides information for loadCache operation of CassandraCacheStore.
batchSize() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets local batch size for this atomic sequence.
batchSize(int) - Method in interface org.apache.ignite.IgniteAtomicSequence
Sets local batch size for atomic sequence.
batchSize() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
beforeInnerMessageRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback called before inner message is read.
beforeInnerMessageWrite() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called before inner message is written.
beforeMessageRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback that must be invoked by a message implementation before message body started decoding.
beforeTrainedModel(IgniteFunction<I1, I>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Let this trainer produce model mdl.
below - Variable in class org.apache.ignite.ml.nn.MultilayerPerceptron
MLP which is 'below' this MLP (i.e. below output goes to this MLP as input).
belowLayersCount() - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Count of layers in below MLP.
beta(double[], double, double) - Method in class org.apache.ignite.ml.math.isolve.lsqr.AbstractLSQR
Calculates beta.
beta(double[], double, double) - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQROnHeap
Calculates beta.
between(String, Object, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Between.
bias(int, int) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get the bias of given neuron in given layer.
biases - Variable in class org.apache.ignite.ml.nn.MLPLayer
Biases vector.
biases(int) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get biases of layer with given index.
BinarizationPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.binarization
Preprocessing function that makes binarization.
BinarizationPreprocessor(double, Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.binarization.BinarizationPreprocessor
Constructs a new instance of Binarization preprocessor.
BinarizationTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.binarization
Trainer of the binarization preprocessor.
BinarizationTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.binarization.BinarizationTrainer
 
binary() - Method in interface org.apache.ignite.client.IgniteClient
 
binary() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteBinary interface.
binary() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteBinary interface.
binaryAttribute(String) - Method in interface org.apache.ignite.services.ServiceCallContext
Get the binary attribute.
BinaryBasicIdMapper - Class in org.apache.ignite.binary
Base binary ID mapper implementation.
BinaryBasicIdMapper() - Constructor for class org.apache.ignite.binary.BinaryBasicIdMapper
Default constructor.
BinaryBasicIdMapper(boolean) - Constructor for class org.apache.ignite.binary.BinaryBasicIdMapper
 
BinaryBasicNameMapper - Class in org.apache.ignite.binary
Base binary name mapper implementation.
BinaryBasicNameMapper() - Constructor for class org.apache.ignite.binary.BinaryBasicNameMapper
Default constructor.
BinaryBasicNameMapper(boolean) - Constructor for class org.apache.ignite.binary.BinaryBasicNameMapper
 
BinaryClassificationMetrics - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Binary classification metrics calculator.
BinaryClassificationMetrics() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
BinaryClassificationMetricValues - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Provides access to binary metric values.
BinaryClassificationMetricValues(long, long, long, long, double) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Initialize an example by 4 metrics.
BinaryCollectionFactory<K> - Interface in org.apache.ignite.binary
Collection factory.
BinaryConfiguration - Class in org.apache.ignite.configuration
Configuration object for Ignite Binary Objects.
BinaryConfiguration() - Constructor for class org.apache.ignite.configuration.BinaryConfiguration
 
BinaryField - Interface in org.apache.ignite.binary
Binary object field.
BinaryIdMapper - Interface in org.apache.ignite.binary
Type and field ID mapper for binary objects.
BinaryInvalidTypeException - Exception in org.apache.ignite.binary
Exception indicating that class needed for deserialization of binary object does not exist.
BinaryInvalidTypeException(String) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with error message.
BinaryInvalidTypeException(Throwable) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with Throwable as a cause.
BinaryInvalidTypeException(String, Throwable) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with error message and Throwable as a cause.
Binarylizable - Interface in org.apache.ignite.binary
Interface that allows to implement custom serialization logic for binary objects.
BinaryMapFactory<K,V> - Interface in org.apache.ignite.binary
Map factory.
binaryMetadataFileStoreDir(File) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
BinaryNameMapper - Interface in org.apache.ignite.binary
Maps type and field names to different names.
BinaryObject - Interface in org.apache.ignite.binary
Wrapper for binary object in binary format.
BinaryObjectBuilder - Interface in org.apache.ignite.binary
Binary object builder.
BinaryObjectException - Exception in org.apache.ignite.binary
Exception indicating binary object serialization error.
BinaryObjectException(String) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with error message.
BinaryObjectException(Throwable) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with Throwable as a cause.
BinaryObjectException(String, Throwable) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with error message and Throwable as a cause.
BinaryObjectVectorizer<K> - Class in org.apache.ignite.ml.dataset.feature.extractor.impl
Vectorizer on binary objects.
BinaryObjectVectorizer(String...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Creates an instance of Vectorizer.
BinaryObjectVectorizer.Mapping - Class in org.apache.ignite.ml.dataset.feature.extractor.impl
Feature values mapping for non-number features.
BinaryRawReader - Interface in org.apache.ignite.binary
Raw reader for binary objects.
BinaryRawWriter - Interface in org.apache.ignite.binary
Raw writer for binary object.
BinaryReader - Interface in org.apache.ignite.binary
Reader for binary objects used in Binarylizable implementations.
BinaryReflectiveSerializer - Class in org.apache.ignite.binary
Binary serializer which writes object fields using reflection.
BinaryReflectiveSerializer() - Constructor for class org.apache.ignite.binary.BinaryReflectiveSerializer
 
BinarySerializer - Interface in org.apache.ignite.binary
Interface that allows to implement custom serialization logic for binary objects.
BinaryType - Interface in org.apache.ignite.binary
Binary type meta data.
BinaryTypeConfiguration - Class in org.apache.ignite.binary
Defines configuration properties for a specific binary type.
BinaryTypeConfiguration() - Constructor for class org.apache.ignite.binary.BinaryTypeConfiguration
Constructor.
BinaryTypeConfiguration(BinaryTypeConfiguration) - Constructor for class org.apache.ignite.binary.BinaryTypeConfiguration
Copying constructor.
BinaryTypeConfiguration(String) - Constructor for class org.apache.ignite.binary.BinaryTypeConfiguration
 
BinaryWriter - Interface in org.apache.ignite.binary
Writer for binary object used in Binarylizable implementations.
bind(Object...) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
bind() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
bindKey(PreparedStatement, Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Binds Ignite cache key object to PreparedStatement.
bindKeyValue(PreparedStatement, Object, Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Binds Ignite cache key and value object to PreparedStatement.
bindStatement(PreparedStatement, V) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Binds prepared statement to current Cassandra session.
bindStatement(PreparedStatement) - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Binds prepared statement.
bindStatement(PreparedStatement) - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Binds prepared statement to current Cassandra session.
bindStatement(PreparedStatement) - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Binds prepared statement to current Cassandra session.
bindStatement(PreparedStatement) - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Binds prepared statement to current Cassandra session.
Blas - Class in org.apache.ignite.ml.math
Useful subset of BLAS operations.
Blas() - Constructor for class org.apache.ignite.ml.math.Blas
 
blockSize() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
 
blockSize() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
blockSize() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
blur(RandomProducer) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Apply pseudorandom noize to vectors without labels mapping.
bnorm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.AbstractLSQR
Calculates bnorm.
bnorm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQROnHeap
Calculates bnorm.
body() - Method in class org.apache.ignite.spi.IgniteSpiThread
Body of SPI thread.
BooleanMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds boolean primitive.
BOOSTER - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
BOOSTER - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
BOOSTER() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
 
BootstrappedDatasetBuilder<K,V> - Class in org.apache.ignite.ml.dataset.impl.bootstrapping
Builder for bootstrapped dataset.
BootstrappedDatasetBuilder(Preprocessor<K, V>, int, double) - Constructor for class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetBuilder
Creates an instance of BootstrappedDatasetBuilder.
BootstrappedDatasetPartition - Class in org.apache.ignite.ml.dataset.impl.bootstrapping
Partition of bootstrapped vectors.
BootstrappedDatasetPartition(BootstrappedVector[]) - Constructor for class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetPartition
Creates an instance of BootstrappedDatasetPartition.
BootstrappedVector - Class in org.apache.ignite.ml.dataset.impl.bootstrapping
Represents vector with repetitions counters for subsamples in bootstrapped dataset.
BootstrappedVector(Vector, double, int[]) - Constructor for class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedVector
Creates an instance of BootstrappedVector.
BootstrappedVectorsHistogram - Class in org.apache.ignite.ml.tree.randomforest.data.impurity.basic
Histogram for bootstrapped vectors with predefined bucket mapping logic for feature id == featureId.
BootstrappedVectorsHistogram(Set<Integer>, BucketMeta, int) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.BootstrappedVectorsHistogram
Creates an instance of BootstrappedVectorsHistogram.
bounded() - Method in interface org.apache.ignite.IgniteQueue
Returns true if this queue is bounded.
bounded() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
bounds() - Method in interface org.apache.ignite.spi.metric.HistogramMetric
 
brakeConnection() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST PURPOSE ONLY!
broadcast(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job to all nodes in the cluster group.
broadcast(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job to all nodes in cluster group.
broadcast(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given closure job with passed in argument to all nodes in the cluster group.
broadcastAsync(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job asynchronously to all nodes in the cluster group.
broadcastAsync(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job asynchronously to all nodes in cluster group.
broadcastAsync(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given closure job asynchronously with passed in argument to all nodes in the cluster group.
broken() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
broken() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
BruteForceStrategy - Class in org.apache.ignite.ml.selection.paramgrid
This strategy enables the brute-force search in hyper-parameter space.
BruteForceStrategy() - Constructor for class org.apache.ignite.ml.selection.paramgrid.BruteForceStrategy
 
BUCKET_NAME_PREFIX - Static variable in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Prefix to use in bucket name generation.
bucketIds - Variable in class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.BootstrappedVectorsHistogram
Bucket ids.
bucketIds - Variable in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogram
Bucket ids.
bucketIdToValue(int) - Method in class org.apache.ignite.ml.dataset.feature.BucketMeta
Returns mean value by bucket id.
BucketMeta - Class in org.apache.ignite.ml.dataset.feature
Bucket meta-information for feature histogram.
BucketMeta(FeatureMeta) - Constructor for class org.apache.ignite.ml.dataset.feature.BucketMeta
Creates an instance of BucketMeta.
bucketMeta - Variable in class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.BootstrappedVectorsHistogram
Bucket meta.
bucketNumber() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
buckets() - Method in interface org.apache.ignite.ml.dataset.feature.Histogram
 
buckets() - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
buckets() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
buckets() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
bucketSize() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
bufferSize() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
bufferSize(int) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
build() - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Builds binary object.
build(LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>, LearningEnvironment) - Method in interface org.apache.ignite.ml.dataset.DatasetBuilder
Constructs a new instance of Dataset that includes allocation required data structures and initialization of context part of partitions.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, EmptyContext) - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>, LearningEnvironment) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Constructs a new instance of Dataset that includes allocation required data structures and initialization of context part of partitions.
build(LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>, LearningEnvironment) - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder
Constructs a new instance of Dataset that includes allocation required data structures and initialization of context part of partitions.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long) - Method in interface org.apache.ignite.ml.dataset.PartitionContextBuilder
Builds a new partition context from an upstream data.
build(LearningEnvironment, Stream<UpstreamEntry<K, V>>, long) - Method in interface org.apache.ignite.ml.dataset.PartitionContextBuilder
Builds a new partition context from an upstream data.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in interface org.apache.ignite.ml.dataset.PartitionDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Stream<UpstreamEntry<K, V>>, long, C) - Method in interface org.apache.ignite.ml.dataset.PartitionDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long) - Method in class org.apache.ignite.ml.dataset.primitive.builder.context.EmptyContextBuilder
Builds a new partition context from an upstream data.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in class org.apache.ignite.ml.dataset.primitive.builder.data.SimpleDatasetDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in class org.apache.ignite.ml.dataset.primitive.builder.data.SimpleLabeledDatasetDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in class org.apache.ignite.ml.dataset.primitive.FeatureMatrixWithLabelsOnHeapDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment) - Method in interface org.apache.ignite.ml.dataset.UpstreamTransformerBuilder
Create UpstreamTransformer based on learning environment.
build(ModelReader, ModelParser<I, O, ?>) - Method in interface org.apache.ignite.ml.inference.builder.AsyncModelBuilder
Builds asynchronous inference model using specified model reader and model parser.
build(ModelReader, ModelParser<I, O, ?>) - Method in class org.apache.ignite.ml.inference.builder.IgniteDistributedModelBuilder
Starts the specified in constructor number of service instances and request/response queues.
build(ModelReader, ModelParser<I, O, M>) - Method in class org.apache.ignite.ml.inference.builder.SingleModelBuilder
Builds synchronous inference model using specified model reader and model parser.
build(ModelReader, ModelParser<I, O, M>) - Method in interface org.apache.ignite.ml.inference.builder.SyncModelBuilder
Builds synchronous inference model using specified model reader and model parser.
build(ModelReader, ModelParser<I, O, ?>) - Method in class org.apache.ignite.ml.inference.builder.ThreadedModelBuilder
Builds asynchronous inference model using specified model reader and model parser.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, EmptyContext) - Method in class org.apache.ignite.ml.knn.KNNPartitionDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<Object, BinaryObject>>, long, EmptyContext) - Method in class org.apache.ignite.ml.recommendation.util.RecommendationBinaryDatasetDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, Z>>, long, EmptyContext) - Method in class org.apache.ignite.ml.recommendation.util.RecommendationDatasetDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in class org.apache.ignite.ml.structures.partition.LabeledDatasetPartitionDataBuilderOnHeap
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in class org.apache.ignite.ml.structures.partition.LabelPartitionDataBuilderOnHeap
Builds a new partition data from a partition upstream data and partition context.
build(LearningEnvironment, Iterator<UpstreamEntry<K, V>>, long, C) - Method in class org.apache.ignite.ml.tree.data.DecisionTreeDataBuilder
Builds a new partition data from a partition upstream data and partition context.
build() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.Builder
Builds VectorGeneratorsFamily instance.
build(long) - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.Builder
Builds VectorGeneratorsFamily instance.
build() - Method in class org.apache.ignite.ml.util.generators.standard.GaussianMixtureDataStream.Builder
 
build(long) - Method in class org.apache.ignite.ml.util.generators.standard.GaussianMixtureDataStream.Builder
 
build() - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
build() - Method in class org.apache.ignite.services.ServiceCallContextBuilder
 
build() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates.Builder
Builder's build() method.
build() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
Builder's build() method.
build() - Method in class org.gridgain.grid.persistentstore.SnapshotPath.FileSnapshotPathBuilder
 
build() - Method in class org.gridgain.grid.persistentstore.SnapshotPath.SftpSnapshotPathBuilder
 
build() - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams.Builder
 
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
buildBaseModelTrainer() - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Returns regressor model trainer for one step of GDB.
buildBaseModelTrainer() - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Returns regressor model trainer for one step of GDB.
buildBaseModelTrainer() - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Returns regressor model trainer for one step of GDB.
buildBinaryObject(String, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Construct binary object from query result.
buildComposition(List<TreeRoot>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Returns composition of built trees.
buildComposition(List<TreeRoot>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestRegressionTrainer
Returns composition of built trees.
buildComposition(List<TreeRoot>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Returns composition of built trees.
buildDataset(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.knn.utils.KNNUtils
Builds dataset.
buildDomainDataRegion(DomainDataRegionConfig, DomainDataRegionBuildingContext) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildEnum(String, int) - Method in interface org.apache.ignite.IgniteBinary
Create enum object using value.
buildEnum(String, String) - Method in interface org.apache.ignite.IgniteBinary
Create enum object using name.
builder(String) - Method in interface org.apache.ignite.IgniteBinary
Creates new binary builder.
builder(BinaryObject) - Method in interface org.apache.ignite.IgniteBinary
Creates binary builder initialized by existing binary object.
builder(double, int) - Static method in class org.apache.ignite.ml.trainers.transformers.BaggingUpstreamTransformer
Get builder of BaggingUpstreamTransformer for a model with a specified index in ensemble.
Builder() - Constructor for class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.Builder
 
Builder() - Constructor for class org.apache.ignite.ml.util.generators.standard.GaussianMixtureDataStream.Builder
 
builder(String, boolean) - Static method in class org.apache.ignite.ml.util.ModelTrace
Creates an instance of ModelTrace.
builder(String) - Static method in class org.apache.ignite.ml.util.ModelTrace
Creates an instance of ModelTrace.
builder() - Static method in interface org.apache.ignite.services.ServiceCallContext
Create a context builder.
Builder(Scope) - Constructor for class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates.Builder
Constructor.
Builder() - Constructor for class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
 
Builder() - Constructor for class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams.Builder
 
buildForTrainer() - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Builds learning environment for trainer.
buildForWorker(int) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Builds LearningEnvironment for worker on given partition.
buildForWorker(int) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Builds LearningEnvironment for worker on given partition.
buildKeyObject(Row) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Builds Ignite cache key object from returned Cassandra table row.
buildLabeledDatasetOnListOfVectors(List<LabeledVector>) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
 
buildObject(String, String, CacheAbstractJdbcStore.TypeKind, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Construct object from query result.
buildObject(String, String, CacheAbstractJdbcStore.TypeKind, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Construct object from query result.
buildPartitonPath(T, int, int) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathOperationsHelper
Build partition path.
buildQueryResultsRegion(String, SessionFactoryImplementor) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildTimestampsRegion(String, SessionFactoryImplementor) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
buildValueObject(Row) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Builds Ignite cache value object from Cassandra table row .
BUILT_IN_TYPES - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Built in Java types names.
BulkLoadContextCursor - Class in org.apache.ignite.cache.query
A special FieldsQueryCursor subclass that is used as a sentinel to transfer data from bulk load (COPY) command to the JDBC or other client-facing driver: the bulk load batch processor and parameters to send to the client.
BulkLoadContextCursor(BulkLoadProcessor, BulkLoadAckClientParameters) - Constructor for class org.apache.ignite.cache.query.BulkLoadContextCursor
Creates a cursor.
bulkLoadProcessor() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Returns a bulk load context.
ByteChannelSnapshotOutputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
WritableByteChannel based implementation of SnapshotOutputStream.
bytesAcked() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets amount of bytes stored in receiver caches.
bytesAcked() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets amount of sent bytes with received acknowledgement from receiver hubs.
bytesCompressed() - Method in interface org.gridgain.grid.cache.compress.CompressionMetrics
Gets total number of bytes of all uncompressed data taken as input for compression, regardless of whether it was accepted for compression and of compression ratio.
bytesDecompressed() - Method in interface org.gridgain.grid.cache.compress.CompressionMetrics
Gets total number of bytes of all compressed data taken as input for decompression.
bytesReceived() - Method in interface org.gridgain.grid.dr.DrReceiverInCacheMetrics
Gets total amount of bytes received from remote sender hubs.
bytesReceived() - Method in interface org.gridgain.grid.dr.DrSenderInMetrics
Gets amount of bytes received from sender caches.
bytesSent() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets amount of bytes waiting to be stored.
bytesSent() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets amount of bytes sent to receiver hubs.

C

cache - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
cache() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets base cache for this projection.
cache - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
Cache instance.
cache() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
cache(String) - Method in interface org.apache.ignite.client.IgniteClient
Get existing cache.
cache(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCache API for the given name if one is configured or null otherwise.
cache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCache API for the given name if one is configured or null otherwise.
cache(String) - Method in class org.apache.ignite.springdata.proxy.IgniteClientProxy
Gets cache with the given name.
cache(String) - Method in interface org.apache.ignite.springdata.proxy.IgniteProxy
Gets cache with the given name.
cache(String) - Method in class org.apache.ignite.springdata.proxy.IgniteProxyImpl
Gets cache with the given name.
cache() - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Returns the Ignite Cache bound to the repository
cache() - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Returns the Ignite Cache bound to the repository
cache(String, byte) - Method in interface org.gridgain.grid.GridGain
Gets cache with specified dataCenterId.
CACHE_PREFIX - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
When set, all cache names in ignite will be fetched using the specified prefix.
CacheAbstractJdbcStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Implementation of CacheStore backed by JDBC.
CacheAbstractJdbcStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
CacheAbstractJdbcStore.EntryMapping - Class in org.apache.ignite.cache.store.jdbc
Entry mapping description.
CacheAbstractJdbcStore.TypeKind - Enum in org.apache.ignite.cache.store.jdbc
Type kind.
cacheAffinity(String) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
CacheAtomicityMode - Enum in org.apache.ignite.cache
Cache atomicity mode controls whether cache should maintain fully transactional semantics or more light-weight atomic behavior.
CacheBasedDataset<K,V,C extends Serializable,D extends AutoCloseable> - Class in org.apache.ignite.ml.dataset.impl.cache
An implementation of dataset based on Ignite Cache, which is used as upstream and as reliable storage for partition context as well.
CacheBasedDataset(Ignite, IgniteCache<K, V>, IgniteBiPredicate<K, V>, UpstreamTransformerBuilder, IgniteCache<Integer, C>, LearningEnvironmentBuilder, PartitionDataBuilder<K, V, C, D>, UUID, boolean, LearningEnvironment, int) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDataset
Constructs a new instance of dataset based on Ignite Cache, which is used as upstream and as reliable storage for partition context as well.
CacheBasedDatasetBuilder<K,V> - Class in org.apache.ignite.ml.dataset.impl.cache
A dataset builder that makes CacheBasedDataset.
CacheBasedDatasetBuilder(Ignite, IgniteCache<K, V>) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset with default predicate that passes all upstream entries to dataset.
CacheBasedDatasetBuilder(Ignite, IgniteCache<K, V>, IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset.
CacheBasedDatasetBuilder(Ignite, IgniteCache<K, V>, IgniteBiPredicate<K, V>, UpstreamTransformerBuilder) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset.
CacheBasedDatasetBuilder(Ignite, IgniteCache<K, V>, IgniteBiPredicate<K, V>, UpstreamTransformerBuilder, Boolean, int) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset.
CacheBasedLabelPairCursor<L,K,V> - Class in org.apache.ignite.ml.selection.scoring.cursor
Truth with prediction cursor based on a data stored in Ignite cache.
CacheBasedLabelPairCursor(IgniteCache<K, V>, IgniteBiPredicate<K, V>, Preprocessor<K, V>, IgniteModel<Vector, L>) - Constructor for class org.apache.ignite.ml.selection.scoring.cursor.CacheBasedLabelPairCursor
Constructs a new instance of cache based truth with prediction cursor.
CacheBasedLabelPairCursor(IgniteCache<K, V>, Preprocessor<K, V>, IgniteModel<Vector, L>) - Constructor for class org.apache.ignite.ml.selection.scoring.cursor.CacheBasedLabelPairCursor
Constructs a new instance of cache based truth with prediction cursor.
CacheCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.cache
This class defines cache-based implementation for checkpoint SPI.
CacheCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
 
CacheCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.cache
Management bean that provides general administrative and configuration information about cache checkpoint SPI.
CacheConfiguration<K,V> - Class in org.apache.ignite.configuration
This class defines grid cache configuration.
CacheConfiguration() - Constructor for class org.apache.ignite.configuration.CacheConfiguration
Empty constructor (all values are initialized to their defaults).
CacheConfiguration(String) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
 
CacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
Copy constructor.
CacheConfiguration.IgniteAllNodesPredicate - Class in org.apache.ignite.configuration
Filter that accepts all nodes.
CacheConflictContext<K,V> - Interface in org.gridgain.grid.cache.conflict
Cache conflict resolution context.
CacheConflictEntry<K,V> - Interface in org.gridgain.grid.cache.conflict
Cache entry along with version information.
CacheConflictMode - Enum in org.gridgain.grid.cache.conflict
Cache conflict resolver mode.
CacheConflictResolver<K,V> - Interface in org.gridgain.grid.cache.conflict
Cache conflict resolver.
cacheCount() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cachedPagesCount() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
cachedRegistry(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
 
CacheDrEntry<K,V> - Interface in org.gridgain.grid.cache.dr
Data center replication cache entry.
CacheDrEntryFilter<K,V> - Interface in org.gridgain.grid.cache.dr
Data center replication sender cache filter.
CacheDrMBean - Interface in org.gridgain.grid.cache.dr
This interface defines JMX view on cache data center replication.
CacheDrPauseReason - Enum in org.gridgain.grid.cache.dr
Reason of data center replication stop.
CacheDrReceiverMetrics - Interface in org.gridgain.grid.cache.dr
Metrics for data center replication receiver cache.
CacheDrSenderConfiguration - Class in org.gridgain.grid.cache.dr
Data center replication sender cache configuration.
CacheDrSenderConfiguration() - Constructor for class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default constructor.
CacheDrSenderConfiguration(CacheDrSenderConfiguration) - Constructor for class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Copying constructor.
CacheDrSenderMetrics - Interface in org.gridgain.grid.cache.dr
Metrics for data center replication sender cache.
CacheDrStateTransfer - Class in org.gridgain.grid.cache.dr
Data center replication state transfer descriptor.
CacheDrStateTransfer() - Constructor for class org.gridgain.grid.cache.dr.CacheDrStateTransfer
CacheDrStateTransfer(IgniteUuid, Collection<Byte>) - Constructor for class org.gridgain.grid.cache.dr.CacheDrStateTransfer
CacheDrStateTransfer(IgniteUuid, Collection<Byte>, String, UUID, long, boolean, int) - Constructor for class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Constructor.
CacheDrStatus - Class in org.gridgain.grid.cache.dr
Data center replication status.
CacheDrStatus() - Constructor for class org.gridgain.grid.cache.dr.CacheDrStatus
Required by Externalizable.
CacheDrStatus(CacheDrPauseReason, String) - Constructor for class org.gridgain.grid.cache.dr.CacheDrStatus
Constructor.
CacheEntry<K,V> - Interface in org.apache.ignite.cache
Cache entry that extends Cache.Entry by providing additional entry related information.
CacheEntryEventSerializableFilter<K,V> - Interface in org.apache.ignite.cache
This filter adds Serializable interface to CacheEntryEventFilter object.
CacheEntryProcessor<K,V,T> - Interface in org.apache.ignite.cache
This processor adds Serializable interface to EntryProcessor object.
CacheEntryVersion - Interface in org.apache.ignite.cache
Entry event order.
CacheEvent - Class in org.apache.ignite.events
In-memory database (cache) event.
CacheEvent(String, ClusterNode, ClusterNode, String, int, int, boolean, Object, IgniteUuid, String, Object, Object, boolean, Object, boolean, UUID, String, String) - Constructor for class org.apache.ignite.events.CacheEvent
Constructs cache event.
CacheExistsException - Exception in org.apache.ignite.cache
Exception thrown when cache must be created but it already exists.
CacheExistsException(String) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheExistsException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheExistsException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheFileLocalStore<K,V> - Class in org.gridgain.grid.cache.store.local
Local file based CacheStore implementation.
CacheFileLocalStore() - Constructor for class org.gridgain.grid.cache.store.local.CacheFileLocalStore
 
CacheFileLocalStoreWriteMode - Enum in org.gridgain.grid.cache.store.local
Write mode for file local store.
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CachePagesListView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns cache group ID.
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns cache group ID.
cacheGroupIds() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
CacheGroupMetricsMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use GridMetricManager instead.
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns Cache group name.
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns Cache group name.
cacheGroupName() - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
 
CacheGroupView - Class in org.apache.ignite.spi.systemview.view
Cache group representation for the SystemView.
CacheGroupView(CacheGroupDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.CacheGroupView
 
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.
CacheHibernateBlobStoreFactory<K,V> - Class in org.apache.ignite.cache.store.hibernate
Factory implementation for CacheHibernateBlobStore.
CacheHibernateBlobStoreFactory() - Constructor for class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
 
CacheHibernateStoreSessionListener - Class in org.apache.ignite.cache.store.hibernate
Hibernate-based cache store session listener.
CacheHibernateStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns cache ID.
cacheId() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns cache ID.
cacheIds() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
cacheInputStreams(int, String, int) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
cacheInputStreams(int, String, String, int) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
CacheInterceptor<K,V> - Interface in org.apache.ignite.cache
Cache interceptor.
CacheInterceptorAdapter<K,V> - Class in org.apache.ignite.cache
Cache interceptor convenience adapter.
CacheInterceptorAdapter() - Constructor for class org.apache.ignite.cache.CacheInterceptorAdapter
 
CacheInterceptorEntry<K,V> - Class in org.apache.ignite.cache
A cache interceptor map entry.
CacheInterceptorEntry() - Constructor for class org.apache.ignite.cache.CacheInterceptorEntry
 
CacheJdbcBlobStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
CacheStore implementation backed by JDBC.
CacheJdbcBlobStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
 
CacheJdbcBlobStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
Factory implementation for CacheJdbcBlobStore.
CacheJdbcBlobStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
 
CacheJdbcPojoStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Implementation of CacheStore backed by JDBC and POJO via reflection.
CacheJdbcPojoStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
 
CacheJdbcPojoStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
Factory implementation for CacheJdbcPojoStore.
CacheJdbcPojoStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
 
CacheJdbcStoreSessionListener - Class in org.apache.ignite.cache.store.jdbc
Cache store session listener based on JDBC connection.
CacheJdbcStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
 
CacheJndiTmFactory - Class in org.apache.ignite.cache.jta.jndi
Implementation of Factory<TransactionManager> interface that is using JNDI names to find TM.
CacheJndiTmFactory() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Creates uninitialized jndi TM lookup.
CacheJndiTmFactory(String...) - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Creates generic TM lookup with given jndi names.
CacheJndiTmLookup - Class in org.apache.ignite.cache.jta.jndi
Implementation of CacheTmLookup interface that is using list of JNDI names to find TM.
CacheJndiTmLookup() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
 
CacheKeyConfiguration - Class in org.apache.ignite.cache
Configuration defining various aspects of cache keys without explicit usage of annotations on user classes.
CacheKeyConfiguration() - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
Creates an empty cache key configuration that should be populated via setters.
CacheKeyConfiguration(Class) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
 
CacheKeyConfiguration(String, String) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
Creates cache key configuration with given type name and affinity field name.
cacheLoaderFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheLoadOnlyStoreAdapter<K,V,I> - Class in org.apache.ignite.cache.store
This adapter designed to support stores with bulk loading from stream-like source.
CacheLoadOnlyStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
 
CacheManager - Class in org.apache.ignite.cache
Implementation of JSR-107 CacheManager.
CacheManager(URI, CachingProvider, ClassLoader, Properties) - Constructor for class org.apache.ignite.cache.CacheManager
 
cacheMappings - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Cache with entry mapping description.
CacheMetrics - Interface in org.apache.ignite.cache
Cache metrics used to obtain statistics on cache itself.
cacheMetrics() - Method in interface org.apache.ignite.spi.discovery.DiscoveryMetricsProvider
Returns metrics data about all caches on local node.
cacheMetrics() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collections of cache metrics for this node.
CacheMetricsMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use GridMetricManager instead.
CacheMode - Enum in org.apache.ignite.cache
Enumeration of all supported caching modes.
cacheMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheModes() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfoEx
Cache mode per cache
cacheName() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Cache name for the current store operation.
cacheName() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in class org.apache.ignite.events.CacheEvent
Gets cache name.
cacheName() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets cache name on which query was executed.
cacheName() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets cache name on which query was executed.
cacheName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets cache name.
cacheName() - Method in interface org.apache.ignite.IgniteDataStreamer
Name of cache to stream data to.
cacheName - Variable in class org.apache.ignite.services.ServiceConfiguration
Cache name.
cacheName() - Method in interface org.apache.ignite.services.ServiceContext
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns cache name.
cacheName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns cache name.
cacheName() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets cache name state transfer is started for.
cacheName - Variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
 
cacheName() - Method in class org.gridgain.grid.events.DrCacheFstEvent
Returns name of the cache that should be transferred to the remote sites.
cacheName() - Method in class org.gridgain.grid.events.DrCacheReplicationEvent
Returns cache name.
CacheNameResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of grid cache name.
cacheNames() - Method in interface org.apache.ignite.client.IgniteClient
Gets the names of all available caches.
cacheNames() - Method in interface org.apache.ignite.Ignite
Gets the collection of names of currently available caches.
cacheNames() - Method in class org.apache.ignite.IgniteSpringBean
Gets the collection of names of currently available caches.
cacheNames() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Cache names to check.
cacheNames(Set<String>) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets cache names to check.
cacheNames() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Collection of cache names to restore from this snapshot.
cacheNames(Set<String>) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets collection of cache names to restore from this snapshot.
cacheNames() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Gets a collection of cache names included into this snapshot.
cacheNames() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
 
cacheNamesAsync() - Method in interface org.apache.ignite.client.IgniteClient
Gets the names of all available caches.
CachePagesListView - Class in org.apache.ignite.spi.systemview.view
Pages-list representation for a SystemView.
CachePagesListView(PagesList, int, int) - Constructor for class org.apache.ignite.spi.systemview.view.CachePagesListView
 
CachePartialUpdateException - Exception in org.apache.ignite.cache
Exception thrown from non-transactional cache in case when update succeeded only partially.
CachePartialUpdateException(CachePartialUpdateCheckedException) - Constructor for exception org.apache.ignite.cache.CachePartialUpdateException
 
cachePartitionOwners(String) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
CachePeekMode - Enum in org.apache.ignite.cache
Enumeration of all supported cache peek modes.
cachePermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of cache names to cache permissions.
cachePermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of cache names to cache permissions.
CachePluginConfiguration<K,V> - Interface in org.apache.ignite.plugin
Cache plugin configuration.
CachePluginContext<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
Cache plugin context.
CachePluginProvider<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
Cache plugin provider is a point for processing of properties which provide specific CachePluginConfiguration.
cachePoolThread() - Method in class org.apache.ignite.thread.IgniteThread
 
CacheQueryEntryEvent<K,V> - Class in org.apache.ignite.cache.query
A Cache continuous query entry event.
CacheQueryEntryEvent(Cache, EventType) - Constructor for class org.apache.ignite.cache.query.CacheQueryEntryEvent
Constructs a cache entry event from a given cache as source.
CacheQueryExecutedEvent<K,V> - Class in org.apache.ignite.events
Cache query execution event.
CacheQueryExecutedEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String) - Constructor for class org.apache.ignite.events.CacheQueryExecutedEvent
 
CacheQueryReadEvent<K,V> - Class in org.apache.ignite.events
Cache query read event.
CacheQueryReadEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String, K, V, V, Object) - Constructor for class org.apache.ignite.events.CacheQueryReadEvent
 
CacheRebalanceMode - Enum in org.apache.ignite.cache
Cache rebalance mode.
CacheRebalancingEvent - Class in org.apache.ignite.events
In-memory database (cache) rebalancing event.
CacheRebalancingEvent(String, ClusterNode, String, int, int, ClusterNode, int, long) - Constructor for class org.apache.ignite.events.CacheRebalancingEvent
Constructs cache event.
CacheReflectionTmLookup - Class in org.apache.ignite.cache.jta.reflect
Implementation of CacheTmLookup interface that attempts to obtain JTA manager by calling static method on the class.
CacheReflectionTmLookup() - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Creates uninitialized reflection TM lookup.
CacheReflectionTmLookup(String, String) - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Creates generic TM lookup with given class and method name.
CacheServerNotFoundException - Exception in org.apache.ignite.cache
Exception thrown when all data nodes left the grid.
CacheServerNotFoundException(String) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheServerNotFoundException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheServerNotFoundException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheSpringStoreSessionListener - Class in org.apache.ignite.cache.store.spring
Cache store session listener based on Spring transaction management.
CacheSpringStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
 
CacheStore<K,V> - Interface in org.apache.ignite.cache.store
API for cache persistent storage for read-through and write-through behavior.
CacheStoreAdapter<K,V> - Class in org.apache.ignite.cache.store
Cache storage convenience adapter.
CacheStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheStoreAdapter
 
cacheStoreFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheStoreSession - Interface in org.apache.ignite.cache.store
Session for the cache store operations.
CacheStoreSessionListener - Interface in org.apache.ignite.cache.store
Cache store session listener that allows to implement callbacks for session lifecycle.
CacheStoreSessionResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of current CacheStoreSession instance.
CacheTmLookup - Interface in org.apache.ignite.cache.jta
Allows grid to use different transactional systems.
cacheType() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheView - Class in org.apache.ignite.spi.systemview.view
Cache representation for a SystemView.
CacheView(DynamicCacheDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.CacheView
 
cacheWriterFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheWriteSynchronizationMode - Enum in org.apache.ignite.cache
Mode indicating how Ignite should wait for write replies from other nodes.
CachingProvider - Class in org.apache.ignite.cache
Implementation of JSR-107 CachingProvider.
CachingProvider() - Constructor for class org.apache.ignite.cache.CachingProvider
 
calculate(DecisionTreeData, TreeFilter, int) - Method in class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasureCalculator
Calculates all impurity measures required required to find a best split and returns them as an array of StepFunction (for every column).
calculate(DecisionTreeData, TreeFilter, int) - Method in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Calculates all impurity measures required required to find a best split and returns them as an array of StepFunction (for every column).
calculate(DecisionTreeData, TreeFilter, int) - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasureCalculator
Calculates all impurity measures required required to find a best split and returns them as an array of StepFunction (for every column).
calculatedField() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Indicates if it's a calculated field - field which value just generated based on other field values.
calculateFitnessForAll(Function<Chromosome, Double>) - Method in class org.apache.ignite.ml.util.genetic.Population
Calculates fintness for all chromosomes with custom fitness function.
calculateFitnessForChromosome(int, Function<Chromosome, Double>) - Method in class org.apache.ignite.ml.util.genetic.Population
Calculates fitness for chromosome found by index with custom fitness function.
calculateGradient(Map<O, Vector>, Map<S, Vector>, int, int, double, double) - Method in class org.apache.ignite.ml.recommendation.util.RecommendationDatasetData
Calculates gradient of the loss function of recommendation system SGD training.
calculateMask(int) - Static method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Helper method to calculates mask.
calculateNewUpdate(M, NesterovParameterUpdate, int, Matrix, Matrix) - Method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovUpdateCalculator
Calculate new update.
calculateNewUpdate(M, P, int, Matrix, Matrix) - Method in interface org.apache.ignite.ml.optimization.updatecalculators.ParameterUpdateCalculator
Calculate new update.
calculateNewUpdate(SmoothParametrized, RPropParameterUpdate, int, Matrix, Matrix) - Method in class org.apache.ignite.ml.optimization.updatecalculators.RPropUpdateCalculator
Calculate new update.
calculateNewUpdate(SmoothParametrized, SimpleGDParameterUpdate, int, Matrix, Matrix) - Method in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Calculate new update.
calculatePartition(Object, int, int) - Static method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Helper method to calculate partition.
calculateROCAUC(PriorityQueue<Pair<Double, Double>>, long, long, double) - Static method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Calculates the ROC AUC value based on queue of pairs, amount of positive/negative cases and label of positive class.
call() - Method in class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
call() - Method in class org.apache.ignite.compute.ComputeJobAdapter
call(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job on a node within the underlying cluster group.
call(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within the underlying cluster group.
call(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within the underlying cluster group.
call(long, byte, BinaryRawReader) - Method in class org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor
Call operation of processor by its id.
call() - Method in class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessClearTask
call() - Method in class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessPingTask
call() - Method in class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessStartTask
call() - Method in class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessStopTask
callAsync(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job asynchronously on a node within the underlying cluster group.
callAsync(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on nodes within the underlying cluster group.
callAsync(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on nodes within the underlying cluster group.
callcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callLocal(Callable<R>) - Method in interface org.apache.ignite.IgniteScheduler
Executes given callable on internal system thread pool asynchronously.
cancel() - Method in interface org.apache.ignite.compute.ComputeJob
This method is called when system detects that completion of this job can no longer alter the overall outcome (for example, when parent task has already reduced the results).
cancel() - Method in class org.apache.ignite.compute.ComputeJobAdapter
This method is called when system detects that completion of this job can no longer alter the overall outcome (for example, when parent task has already reduced the results).
cancel() - Method in interface org.apache.ignite.compute.ComputeJobSibling
Sends a request to cancel this sibling.
cancel(String) - Method in interface org.apache.ignite.IgniteServices
Cancels service deployment.
cancel() - Method in interface org.apache.ignite.lang.IgniteFuture
Cancels this future.
cancel(boolean) - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy.FutureWrapper
cancel(boolean) - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy.Stub
cancel() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Cancel defragmentation.
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.
cancel(ServiceContext) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterMaintainer
Cancels this service.
cancel() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
Marks this snapshot session as invalid.
cancelAll(Collection<String>) - Method in interface org.apache.ignite.IgniteServices
Cancels services with specified names.
cancelAll() - Method in interface org.apache.ignite.IgniteServices
Cancels all deployed services.
cancelAllAsync(Collection<String>) - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels services with specified names.
cancelAllAsync() - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels all deployed services.
cancelAsync(String) - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels service deployment.
canceled() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
CANCELLED_FILENAME - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Cancelled filename.
cancelSnapshotOperation(IgniteUuid, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Tries to gracefully cancel an ongoing snapshot operation.
cancelStateTransfer(IgniteUuid) - Method in interface org.gridgain.grid.GridDr
Cancel state transfer operation with given uid.
capacity() - Method in interface org.apache.ignite.IgniteQueue
Gets maximum number of elements of the queue.
capacity() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
CardinalityException - Exception in org.apache.ignite.ml.math.exceptions
Indicates a cardinality mismatch in matrix or vector operations.
CardinalityException(int, int) - Constructor for exception org.apache.ignite.ml.math.exceptions.CardinalityException
Creates new cardinality violation exception.
CassandraCacheStore<K,V> - Class in org.apache.ignite.cache.store.cassandra
Implementation of CacheStore backed by Cassandra database.
CassandraCacheStore(DataSource, KeyValuePersistenceSettings, int) - Constructor for class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
Store constructor.
CassandraCacheStoreFactory<K,V> - Class in org.apache.ignite.cache.store.cassandra
Factory class to instantiate CassandraCacheStore.
CassandraCacheStoreFactory() - Constructor for class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
 
CassandraHelper - Class in org.apache.ignite.cache.store.cassandra.common
Helper class providing methods to work with Cassandra session and exceptions
CassandraHelper() - Constructor for class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
 
CassandraSession - Interface in org.apache.ignite.cache.store.cassandra.session
Wrapper around Cassandra driver session, to automatically handle: Keyspace and table absence exceptions Timeout exceptions Batch operations
CassandraSessionImpl - Class in org.apache.ignite.cache.store.cassandra.session
Implementation for CassandraSession.
CassandraSessionImpl(Cluster.Builder, Integer, ConsistencyLevel, ConsistencyLevel, long, IgniteLogger) - Constructor for class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Creates instance of Cassandra driver session wrapper.
cassandraUniqueFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
List of POJO fields having unique mapping to Cassandra columns - skipping aliases pointing to the same Cassandra table column.
categoryFrequencies() - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderPartitionData
Gets the array of maps of frequencies by value in partition for each feature in the dataset.
centerShow(String, String, String, Date, String) - Static method in class org.apache.ignite.startup.cmdline.AboutDialog
Show about dialog.
CentroidStat() - Constructor for class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer.CentroidStat
 
CertificateAuthenticator - Class in org.gridgain.grid.security.certificate
Authorizes client nodes and thin clients based on client SSL certificates and assigns permissions.
CertificateAuthenticator() - Constructor for class org.gridgain.grid.security.certificate.CertificateAuthenticator
 
certificates() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
 
certificates(Certificate[]) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Set client SSL certificates.
certificates() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject client certificates, or null if SSL were not used or client certificate checking not enabled.
certificates() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
Gets subject client certificates, or null if SSL were not used or client certificate checking not enabled.
cfg - Variable in class org.apache.ignite.tensorflow.submitter.command.AbstractCommand
Ignite node configuration path.
CFG_URL_PREFIX - Static variable in class org.apache.ignite.IgniteJdbcDriver
Config URL prefix.
cfgNodeId - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
chain(IgniteClosure<? super IgniteFuture<V>, T>) - Method in interface org.apache.ignite.lang.IgniteFuture
Make a chained future to convert result of this future (when complete) into a new format.
chainAsync(IgniteClosure<? super IgniteFuture<V>, T>, Executor) - Method in interface org.apache.ignite.lang.IgniteFuture
Make a chained future to convert result of this future (when complete) into a new format.
chainMode() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
chainMode(SnapshotChainMode) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets chain mode.
chainMode() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
chainMode(SnapshotChainMode) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets chain mode.
chainMode() - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
 
changeCacheGroupKey(Collection<String>) - Method in interface org.apache.ignite.IgniteEncryption
Starts cache group encryption key change process.
changeCacheGroupKey(String) - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
Starts cache group encryption key change process.
changeMasterKey(String) - Method in interface org.apache.ignite.IgniteEncryption
Starts master key change process.
changeMasterKey(String) - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
Starts master key change process.
channelNames - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Channel names.
check(CheckSnapshotParams) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Verifies snapshot integrity.
checkAndReturnSplitValue(int, double, double, double) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogram
Checks split value validity and return Optional-wrap of it.
checkCardinality(Matrix, Vector) - Static method in class org.apache.ignite.ml.math.Blas
Checks if Matrix A can be multiplied by vector v, if not CardinalityException is thrown.
checkCardinality(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
checkCardinality(double[]) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
checkCardinality(int[]) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
checkConfigurationConsistency0(IgniteSpiContext, ClusterNode, boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Method which is called in the end of checkConfigurationConsistency() method.
checkConfigurationConsistency0(IgniteSpiContext, ClusterNode, boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Method which is called in the end of checkConfigurationConsistency() method.
checkConnection(List<ClusterNode>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
checkConvergenceStgyFactory - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Check convergence strategy factory.
checkConvergenceStgyFactory - Variable in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Check convergence strategy factory.
checkDuplicates(List<F>) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Checks if there are POJO filed with the same name or same Cassandra column specified in persistence settings.
checkFailedError(TcpDiscoveryCheckFailedMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
checkFailureTimeoutReached(Exception) - Method in class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Checks whether the given Exception is generated because failure detection timeout has been reached.
checkIgnite() - Method in class org.apache.ignite.IgniteSpringBean
Checks if this bean is valid.
checkIndex(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Check index bounds.
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.
checkpoint() - Method in interface org.apache.ignite.IgniteCluster
Force checkpointing on whole cluster
checkpoint() - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
 
CHECKPOINT_PARALLEL_SORT_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Starting from this number of dirty pages in checkpoint, array will be sorted with Arrays.parallelSort(Comparable[]) in case of CheckpointWriteOrder.SEQUENTIAL.
CHECKPOINT_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CheckpointEvent - Class in org.apache.ignite.events
Grid checkpoint event.
CheckpointEvent() - Constructor for class org.apache.ignite.events.CheckpointEvent
No-arg constructor.
CheckpointEvent(ClusterNode, String, int, String) - Constructor for class org.apache.ignite.events.CheckpointEvent
Creates new checkpoint event with given parameters.
CheckpointListener - Interface in org.apache.ignite.spi.checkpoint
Listener for notifications of checkpoints removed by CheckpointSpi.
CheckpointSpi - Interface in org.apache.ignite.spi.checkpoint
Checkpoint SPI provides an ability to save an intermediate job state.
CheckpointWriteOrder - Enum in org.apache.ignite.configuration
This enum defines order of writing pages to disk storage during checkpoint.
checkRingLatency(int) - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Diagnosis method for determining ring message latency.
checkSnapshot(long, Collection<File>, boolean, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
checkSnapshot(long, Collection<File>, Set<String>, boolean, boolean, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
checkSnapshot(long, SnapshotOperationType, Set<String>, boolean, Collection<File>, boolean, IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
CheckSnapshotParams - Class in org.gridgain.grid.persistentstore
Parameters for verify snapshot integrity operation.
CheckSnapshotParams() - Constructor for class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
checkStarvation() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
Deprecated.
Will be removed at 3.0.
checkTimeout(long) - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Check if total timeout will be reached in now() + timeInFut.
checkTimeout(long) - Method in interface org.apache.ignite.spi.TimeoutStrategy
Check if total timeout will be reached in now() + timeInFut.
checkTimeout() - Method in interface org.apache.ignite.spi.TimeoutStrategy
Check if total timeout will be reached by now.
CHIEF_JOB_NAME - Static variable in class org.apache.ignite.tensorflow.cluster.util.TensorFlowClusterResolver
TensorFlow chief job name.
Chromosome - Class in org.apache.ignite.ml.genetic
Represents a potential solution consisting of a fixed-length collection of genes.
Chromosome(long[]) - Constructor for class org.apache.ignite.ml.genetic.Chromosome
 
Chromosome - Class in org.apache.ignite.ml.util.genetic
Representes the set of genes, known as chromosome in genetic programming.
Chromosome(int) - Constructor for class org.apache.ignite.ml.util.genetic.Chromosome
 
Chromosome(Double[]) - Constructor for class org.apache.ignite.ml.util.genetic.Chromosome
 
ChromosomeCriteria - Class in org.apache.ignite.ml.genetic.parameter
Responsible for describing the characteristics of an individual Chromosome.
ChromosomeCriteria() - Constructor for class org.apache.ignite.ml.genetic.parameter.ChromosomeCriteria
 
CIPHER_ALGO - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Algorithm supported by implementation.
circle(double) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of 2D-vectors from circle-like distribution around zero.
circle(double, long) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of 2D-vectors from circle-like distribution around zero.
ClassifierLeafValuesComputer - Class in org.apache.ignite.ml.tree.randomforest.data.statistics
Implementation of LeafValuesComputer for classification task.
ClassifierLeafValuesComputer(Map<Double, Integer>) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.statistics.ClassifierLeafValuesComputer
Creates an instance of ClassifierLeafValuesComputer.
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.
ClassMetric<L> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Metric calculator for one class label.
ClassMetric(L) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.ClassMetric
The class of interest or positive class.
className() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets queried class name.
className() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets queried class name.
classNameFilter() - Method in interface org.apache.ignite.marshaller.MarshallerContext
Returns class name filter.
classNameFilter(ClassLoader) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns class name filter for marshaller.
clause() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query clause.
clause() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query clause.
cleanup() - Method in class org.apache.ignite.spi.IgniteSpiThread
Should be overridden by child classes if cleanup logic is required.
clear(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears key on all nodes that store it's data.
clear() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears cache on all nodes that store it's data.
clear() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
clear() - Method in class org.apache.ignite.cache.hibernate.IgniteGeneralDataRegion
clear() - Method in interface org.apache.ignite.client.ClientCache
Clears the contents of the cache.
clear(K) - Method in interface org.apache.ignite.client.ClientCache
Clears entry with specified key from the cache.
clear() - Method in interface org.apache.ignite.client.ClientIgniteSet
clear() - Method in interface org.apache.ignite.IgniteCache
clear(K) - Method in interface org.apache.ignite.IgniteCache
Clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
clear() - Method in interface org.apache.ignite.IgniteQueue
clear(int) - Method in interface org.apache.ignite.IgniteQueue
Removes all of the elements from this queue.
clear() - Method in interface org.apache.ignite.IgniteSet
clear() - Method in class org.apache.ignite.lang.IgniteBiTuple
clear() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
clear() - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Clears the contents of the cache.
clear() - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Clears the contents of the cache.
clear() - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Clears the contents of the cache.
clear(Map<UUID, List<UUID>>) - Method in class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcessManager
Clears metadata of the given processes.
clear(Map<UUID, List<UUID>>) - Method in interface org.apache.ignite.tensorflow.core.ProcessManager
Clears metadata of the given processes.
clear(Map<UUID, List<UUID>>) - Method in class org.apache.ignite.tensorflow.core.ProcessManagerWrapper
Clears metadata of the given processes.
clear() - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Removes all data from store and resets overflow flag to false.
clear() - Method in interface org.gridgain.grid.dr.store.DrSenderStore
Removes all data from store and resets overflow flag to false.
clear0() - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Remove all store data and reset store's state.
clear0() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Clears store.
clear0() - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Remove all store data and reset store's state.
clearAll(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears keys on all nodes that store it's data.
clearAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Clears entries with specified keys from the cache.
clearAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
clearAll() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Removes all events from the event queue.
clearAll() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Removes all events from the event queue.
clearAllAsync(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
clearAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Clears entries with specified keys from the cache asynchronously.
clearAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
clearAsync() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
clearAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
clearAsync() - Method in interface org.apache.ignite.client.ClientCache
Clears the contents of the cache asynchronously.
clearAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Clears entry with specified key from the cache asynchronously.
clearAsync() - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears the contents of the cache, without notifying listeners or CacheWriters.
clearAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
clearCache() - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Intended for test purposes only.
clearFullStateTransferBuffer() - Method in interface org.gridgain.grid.dr.DrSender
Clear full state transfer buffer.
clearGlobalStore() - Method in interface org.gridgain.grid.dr.DrSender
Clear global sender store if it is configured.
clearLocally(boolean, boolean, boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears all entries from this cache only if the entry is not currently locked or participating in a transaction.
clearLocally(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears an entry from this cache and swap storage only if the entry is not currently locked, and is not participating in a transaction.
clearLocallyAll(Set, boolean, boolean, boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Clears entries from this cache and swap storage only if the entry is not currently locked, and is not participating in a transaction.
clearNodeLocalMap() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Clears node local map.
clearQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Clear query entities.
clearStatistics() - Method in interface org.apache.ignite.IgniteCache
Clear cluster statistics for this cache.
clearStatistics(Collection<String>) - Method in interface org.apache.ignite.IgniteCluster
Clear statistics for caches cluster wide.
clearStore() - Method in interface org.gridgain.grid.dr.DrSenderConnection
Clear sender store for current data center connection.
CLIENT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Time interval that indicates that client reconnect throttle must be reset to zero. 2 minutes by default.
ClientAddressFinder - Interface in org.apache.ignite.client
This interface provides a list of addresses of Ignite server nodes within a cluster.
ClientAtomicConfiguration - Class in org.apache.ignite.client
Configuration for atomic data structures.
ClientAtomicConfiguration() - Constructor for class org.apache.ignite.client.ClientAtomicConfiguration
 
ClientAtomicLong - Interface in org.apache.ignite.client
Distributed atomic long API.
ClientAuthenticationException - Exception in org.apache.ignite.client
Indicates user name or password is invalid.
ClientAuthenticationException(String) - Constructor for exception org.apache.ignite.client.ClientAuthenticationException
Default constructor.
ClientAuthenticationException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthenticationException
Constructs a new exception with the specified detail message and cause.
ClientAuthorizationException - Exception in org.apache.ignite.client
Indicates user has no permission to perform operation.
ClientAuthorizationException() - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Default constructor.
ClientAuthorizationException(String) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified message.
ClientAuthorizationException(Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified cause and a detail message of (cause==null ?
ClientAuthorizationException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified detail message and cause.
ClientAutoCloseableIterator<T> - Interface in org.apache.ignite.client
Auto closeable iterator.
ClientCache<K,V> - Interface in org.apache.ignite.client
Thin client cache.
ClientCacheConfiguration - Class in org.apache.ignite.client
Cache configuration.
ClientCacheConfiguration() - Constructor for class org.apache.ignite.client.ClientCacheConfiguration
Default constructor.
ClientCacheConfiguration(ClientCacheConfiguration) - Constructor for class org.apache.ignite.client.ClientCacheConfiguration
Creates client cache configuration by coping all configuration properties from the given one.
clientClassLoader() - Method in interface org.apache.ignite.ml.environment.deploy.DeployingContext
 
clientClassLoader() - Method in class org.apache.ignite.ml.environment.deploy.DeployingContextImpl
ClientCluster - Interface in org.apache.ignite.client
Thin client cluster facade.
ClientClusterGroup - Interface in org.apache.ignite.client
Thin client cluster group facade.
ClientCollectionConfiguration - Class in org.apache.ignite.client
Configuration for Ignite collections.
ClientCollectionConfiguration() - Constructor for class org.apache.ignite.client.ClientCollectionConfiguration
 
ClientCompute - Interface in org.apache.ignite.client
Thin client compute facade.
ClientConfiguration - Class in org.apache.ignite.configuration
TcpIgniteClient configuration.
ClientConfiguration() - Constructor for class org.apache.ignite.configuration.ClientConfiguration
 
ClientConnectionAttributeView - Class in org.apache.ignite.spi.systemview.view
Client connection attribute system view row.
ClientConnectionAttributeView(long, String, String) - Constructor for class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
ClientConnectionException - Exception in org.apache.ignite.client
Indicates all the Ignite servers specified in the client configuration are no longer available.
ClientConnectionException(String) - Constructor for exception org.apache.ignite.client.ClientConnectionException
Constructs a new exception with the specified detail message.
ClientConnectionException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientConnectionException
Constructs a new exception with the specified cause and detail message.
ClientConnectionView - Class in org.apache.ignite.spi.systemview.view
Client connection system view row.
ClientConnectionView(GridNioSession) - Constructor for class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
ClientConnectorConfiguration - Class in org.apache.ignite.configuration
Client connector configuration.
ClientConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ClientConnectorConfiguration
Creates SQL connector configuration with all default values.
ClientConnectorConfiguration(ClientConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ClientConnectorConfiguration
Creates SQL connector configuration by copying all properties from given configuration.
ClientDisconnectListener - Interface in org.apache.ignite.client
Client disconnected event listener.
ClientException - Exception in org.apache.ignite.client
Common thin client unchecked exception.
ClientException() - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with null as its detail message.
ClientException(String) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message.
ClientException(Throwable) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified cause and a detail message of (cause==null ?
ClientException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message and cause.
ClientException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message, cause, suppression enabled or disabled, and writable stack trace enabled or disabled.
ClientExceptionsUtils - Class in org.apache.ignite.spi.communication.tcp
Utils to analyze client-related exceptions.
ClientExceptionsUtils() - Constructor for class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
 
clientFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns client failure detection timeout set to use for network related operations.
ClientFeatureNotSupportedByServerException - Exception in org.apache.ignite.client
Feature not supported by server exception.
ClientFeatureNotSupportedByServerException(String) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
Constructs a new exception with the specified detail message.
ClientFeatureNotSupportedByServerException(ProtocolBitmaskFeature) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
 
ClientFeatureNotSupportedByServerException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
Constructs a new exception with the specified cause and detail message.
ClientIgniteSet<T> - Interface in org.apache.ignite.client
Distributed Set.
ClientOperationType - Enum in org.apache.ignite.client
Client operation type.
clientParams() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Returns the bulk load parameters to send to the client.
ClientProcessorMXBean - Interface in org.apache.ignite.mxbean
MXBean interface that provides access to ODBC\JDBC\Thin client connections.
clientReconnect() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
clientReconnect() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
clientReconnect() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
ClientReconnectedException - Exception in org.apache.ignite.client
Indicates that previous connection was lost and a new connection established, which can lead to inconsistency of non-atomic operations.
ClientReconnectedException() - Constructor for exception org.apache.ignite.client.ClientReconnectedException
Default constructor.
ClientReconnectedException(String) - Constructor for exception org.apache.ignite.client.ClientReconnectedException
Constructs a new exception with the specified message.
ClientReconnectedException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientReconnectedException
Constructs a new exception with the specified cause and detail message.
clientReconnectFuture() - Method in interface org.apache.ignite.IgniteCluster
If local client node disconnected from cluster returns future that will be completed when client reconnected.
clientReconnectSupported() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
clientReconnectSupported() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
clientReconnectSupported() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
ClientRetryAllPolicy - Class in org.apache.ignite.client
Retry policy that always returns true.
ClientRetryAllPolicy() - Constructor for class org.apache.ignite.client.ClientRetryAllPolicy
 
ClientRetryNonePolicy - Class in org.apache.ignite.client
Retry policy that always returns false.
ClientRetryNonePolicy() - Constructor for class org.apache.ignite.client.ClientRetryNonePolicy
 
ClientRetryPolicy - Interface in org.apache.ignite.client
Client retry policy determines whether client operations that have failed due to a connection issue should be retried.
ClientRetryPolicyContext - Interface in org.apache.ignite.client
Retry policy context.
ClientRetryReadPolicy - Class in org.apache.ignite.client
Retry policy that returns true for all read-only operations that do not modify data.
ClientRetryReadPolicy() - Constructor for class org.apache.ignite.client.ClientRetryReadPolicy
 
ClientServiceDescriptor - Interface in org.apache.ignite.client
Descriptor of Service.
ClientServices - Interface in org.apache.ignite.client
Thin client services facade.
ClientTransaction - Interface in org.apache.ignite.client
Thin client transaction.
ClientTransactionConfiguration - Class in org.apache.ignite.configuration
Thin client transactions configuration.
ClientTransactionConfiguration() - Constructor for class org.apache.ignite.configuration.ClientTransactionConfiguration
Empty constructor.
ClientTransactionConfiguration(ClientTransactionConfiguration) - Constructor for class org.apache.ignite.configuration.ClientTransactionConfiguration
 
ClientTransactions - Interface in org.apache.ignite.client
Thin client transactions facade.
clientWorkerCount() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
clone() - Method in interface org.apache.ignite.binary.BinaryObject
Copies this binary object.
clone() - Method in class org.apache.ignite.lang.IgniteBiTuple
clone() - Method in class org.apache.ignite.lang.IgniteUuid
close() - Method in class org.apache.ignite.cache.CacheManager
close() - Method in class org.apache.ignite.cache.CachingProvider
close(ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
close(URI, ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
close() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Closes all resources related to this cursor.
close() - Method in interface org.apache.ignite.cache.query.QueryCursor
Closes all resources related to this cursor.
close() - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
close() - Method in interface org.apache.ignite.client.ClientAtomicLong
Removes this atomic long.
close() - Method in interface org.apache.ignite.client.ClientIgniteSet
Removes this set.
close() - Method in interface org.apache.ignite.client.ClientTransaction
Ends the transaction.
close() - Method in interface org.apache.ignite.client.IgniteClient
Closes this client's open connections and relinquishes all underlying resources.
close() - Method in interface org.apache.ignite.Ignite
Closes this instance of grid.
close() - Method in interface org.apache.ignite.IgniteAtomicLong
Removes this atomic long.
close() - Method in interface org.apache.ignite.IgniteAtomicReference
Removes this atomic reference.
close() - Method in interface org.apache.ignite.IgniteAtomicSequence
Removes this atomic sequence.
close() - Method in interface org.apache.ignite.IgniteAtomicStamped
Removes this atomic stamped.
close() - Method in interface org.apache.ignite.IgniteCache
Closes this cache instance.
close() - Method in interface org.apache.ignite.IgniteCountDownLatch
Removes this count down latch.
close(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Streams any remaining data and closes this streamer.
close() - Method in interface org.apache.ignite.IgniteDataStreamer
Closes data streamer.
close() - Method in interface org.apache.ignite.IgniteLock
Removes reentrant lock.
close() - Method in interface org.apache.ignite.IgniteQueue
Removes this queue.
close() - Method in interface org.apache.ignite.IgniteSemaphore
Removes this semaphore.
close() - Method in interface org.apache.ignite.IgniteSet
Removes this set.
close() - Method in class org.apache.ignite.IgniteSpringBean
Closes this instance of grid.
close() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
close() - Method in class org.apache.ignite.logger.log4j2.Log4jBridgeHandler
close() - Method in class org.apache.ignite.ml.composition.bagging.BaggedModel
close() - Method in class org.apache.ignite.ml.composition.combinators.parallel.ModelsParallelComposition
close() - Method in class org.apache.ignite.ml.composition.combinators.sequential.ModelsSequentialComposition
close() - Method in class org.apache.ignite.ml.composition.stacking.StackedModel
close() - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetPartition
close() - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDataset
close() - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDataset
close() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleDatasetData
close() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleLabeledDatasetData
close() - Method in class org.apache.ignite.ml.dataset.primitive.DatasetWrapper
close() - Method in class org.apache.ignite.ml.dataset.primitive.FeatureMatrixWithLabelsOnHeapData
close() - Method in interface org.apache.ignite.ml.IgniteModel
close() - Method in interface org.apache.ignite.ml.inference.Model
close() - Method in class org.apache.ignite.ml.knn.KNNModel
close() - Method in interface org.apache.ignite.ml.knn.utils.indices.SpatialIndex
close() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQROnHeap
close() - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Destroys decomposition components and other internal components of decomposition.
close() - Method in class org.apache.ignite.ml.mleap.MLeapModel
close() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesSumsHolder
 
close() - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderPartitionData
 
close() - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
 
close() - Method in class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPartitionData
 
close() - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPartitionData
 
close() - Method in class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerData
 
close() - Method in class org.apache.ignite.ml.recommendation.util.RecommendationDatasetData
close() - Method in class org.apache.ignite.ml.selection.scoring.cursor.CacheBasedLabelPairCursor
close() - Method in class org.apache.ignite.ml.selection.scoring.cursor.LocalLabelPairCursor
close() - Method in class org.apache.ignite.ml.structures.LabeledVectorSet
Closes LabeledDataset.
close() - Method in class org.apache.ignite.ml.structures.partition.LabelPartitionDataOnHeap
close() - Method in class org.apache.ignite.ml.tree.data.DecisionTreeData
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.IgniteSpiCloseableIterator
Closes the iterator and frees all the resources held by the iterator.
close() - Method in class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery.QueryCursorWrapper
Closes all resources related to this cursor.
close() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGateway
close() - Method in interface org.apache.ignite.transactions.Transaction
Ends the transaction.
close() - Method in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
close() - Method in class org.gridgain.grid.persistentstore.snapshot.file.ByteChannelSnapshotOutputStream
Close method.
close() - Method in class org.gridgain.grid.persistentstore.snapshot.file.DigestSnapshotInputStream
close() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
close() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotOutputStream
Close method.
close() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
Closes all resources associated with the session.
closeConnection(Connection) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes connection.
closeSession(Session) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Closes Cassandra driver session.
closureClassName() - Method in class org.apache.ignite.events.CacheEvent
Gets closure class name (applicable only for TRANSFORM operations).
CLS_NAMES_FILE - Static variable in class org.apache.ignite.marshaller.MarshallerUtils
Class names file.
clsLb - Variable in class org.apache.ignite.ml.selection.scoring.metric.classification.ClassMetric
Class label.
cluster() - Method in interface org.apache.ignite.client.IgniteClient
Gets client cluster facade.
cluster() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCluster interface.
cluster() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCluster interface.
cluster(P, int) - Method in interface org.apache.ignite.ml.clustering.kmeans.Clusterer
Cluster given points set into k clusters.
CLUSTER_STATE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ClusterActivationEvent - Class in org.apache.ignite.events
Deprecated.
ClusterActivationEvent(ClusterNode, String, int, Collection<BaselineNode>) - Constructor for class org.apache.ignite.events.ClusterActivationEvent
Deprecated.
Creates activation event with given parameters.
Clusterer<P,M extends IgniteModel> - Interface in org.apache.ignite.ml.clustering.kmeans
Base interface for clusterers.
clusterGroup() - Method in interface org.apache.ignite.client.ClientCompute
Gets cluster group to which this ClientCompute instance belongs.
clusterGroup() - Method in interface org.apache.ignite.client.ClientServices
Gets the cluster group to which this ClientServices instance belongs.
ClusterGroup - Interface in org.apache.ignite.cluster
Defines a cluster group which contains all or a subset of cluster nodes.
clusterGroup() - Method in interface org.apache.ignite.IgniteCompute
Gets cluster group to which this IgniteCompute instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteEvents
Gets cluster group to which this IgniteEvents instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteMessaging
Gets the cluster group to which this GridMessaging instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteServices
Gets the cluster group to which this IgniteServices instance belongs.
ClusterGroupEmptyException - Exception in org.apache.ignite.cluster
This exception defines illegal call on empty cluster group.
ClusterGroupEmptyException() - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
Creates new exception with default error message.
ClusterGroupEmptyException(String) - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
Creates new exception with given error message.
ClusterGroupEmptyException(String, Throwable) - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
Creates a new exception with given error message and optional nested cause exception.
clusterId() - Method in interface org.apache.ignite.cache.CacheEntryVersion
Cluster id is a value to distinguish updates in case user wants to aggregate and sort updates from several Ignite clusters.
clusterId() - Method in class org.apache.ignite.events.ClusterTagUpdatedEvent
Cluster ID which tag was updated.
ClusterIdUpdatedEvent - Class in org.apache.ignite.events
Event type indicating that cluster ID has been updated.
ClusterIdUpdatedEvent(ClusterNode, String, UUID, UUID) - Constructor for class org.apache.ignite.events.ClusterIdUpdatedEvent
 
ClusterizationModel<P,V> - Interface in org.apache.ignite.ml.clustering.kmeans
Base interface for all clusterization models.
clusterMetrics() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets whole cluster metrics (statistics) for this cache.
clusterMetrics(ClusterGroup) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets cluster group metrics (statistics) for this cache.
ClusterMetrics - Interface in org.apache.ignite.cluster
This class represents runtime information on a cluster.
ClusterMetricsMXBean - Interface in org.apache.ignite.mxbean
Cluster metrics MBean.
clusterMxBean() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets whole cluster metrics (statistics) for this cache.
clusterName() - Method in class org.apache.ignite.mesos.ClusterProperties
 
clusterName() - Method in class org.apache.ignite.yarn.ClusterProperties
 
ClusterNode - Interface in org.apache.ignite.cluster
Interface representing a single cluster node.
ClusterNodeAttributeAffinityBackupFilter - Class in org.apache.ignite.cache.affinity.rendezvous
Attribute-based affinity backup filter that forces each partition's primary and backup nodes to different hardware which is not expected to fail simultaneously, e.g., in AWS, to different "availability zones".
ClusterNodeAttributeAffinityBackupFilter(String...) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
 
clusterNodes() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
 
ClusterNodeView - Class in org.apache.ignite.spi.systemview.view
Cluster node representation for a SystemView.
ClusterNodeView(ClusterNode) - Constructor for class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
ClusterPortManager - Class in org.apache.ignite.tensorflow.cluster.util
Cluster port manager that allows to reliably ClusterPortManager.acquirePort(UUID) and ClusterPortManager.releasePort(UUID, int) on the cluster nodes.
ClusterPortManager(Ignite, String, int, int) - Constructor for class org.apache.ignite.tensorflow.cluster.util.ClusterPortManager
Constructs a new instance of cluster port manager.
ClusterProperties - Class in org.apache.ignite.mesos
The class defines cluster configuration.
ClusterProperties() - Constructor for class org.apache.ignite.mesos.ClusterProperties
 
ClusterProperties - Class in org.apache.ignite.yarn
Cluster settings.
ClusterProperties() - Constructor for class org.apache.ignite.yarn.ClusterProperties
 
ClusterStartNodeResult - Interface in org.apache.ignite.cluster
Cluster start node result information.
ClusterState - Enum in org.apache.ignite.cluster
Cluster states.
clusterState() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
clusterState(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Changes current cluster state.
ClusterStateChangeEvent - Class in org.apache.ignite.events
Cluster state change event.
ClusterStateChangeEvent(ClusterState, ClusterState, Collection<BaselineNode>, ClusterNode, String) - Constructor for class org.apache.ignite.events.ClusterStateChangeEvent
 
ClusterStateChangeStartedEvent - Class in org.apache.ignite.events
Cluster state change started event.
ClusterStateChangeStartedEvent(ClusterState, ClusterState, ClusterNode, String) - Constructor for class org.apache.ignite.events.ClusterStateChangeStartedEvent
 
ClusterTagUpdatedEvent - Class in org.apache.ignite.events
Event type indicating that cluster tag has been updated.
ClusterTagUpdatedEvent(ClusterNode, String, UUID, String, String) - Constructor for class org.apache.ignite.events.ClusterTagUpdatedEvent
 
ClusterTopologyException - Exception in org.apache.ignite.cluster
This exception is used to indicate error with the cluster topology (e.g., crashed node, etc.).
ClusterTopologyException(String) - Constructor for exception org.apache.ignite.cluster.ClusterTopologyException
Creates new topology exception with given error message.
ClusterTopologyException(String, Throwable) - Constructor for exception org.apache.ignite.cluster.ClusterTopologyException
Creates new topology exception with given error message and optional nested exception.
cntOfIterations - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Count of iterations.
collect(E) - Method in interface org.apache.ignite.lang.IgniteReducer
Collects given value.
collect(DiscoveryDataBag) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
Collects data from all components.
collectedBytes() - Method in interface org.gridgain.grid.cache.compress.DictionaryMetrics
Gets total number of bytes of samples collected currently.
collectedSamples() - Method in interface org.gridgain.grid.cache.compress.DictionaryMetrics
Gets number of samples collected currently.
CollectionConfiguration - Class in org.apache.ignite.configuration
Configuration for Ignite collections.
CollectionConfiguration() - Constructor for class org.apache.ignite.configuration.CollectionConfiguration
 
collectionOf(Collection<DataRegionMetrics>) - Static method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Converts collection of DataRegionMetrics into collection of legacy MemoryMetrics.
collectMessagesCountByNodeId(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collect messages count by nodeId
collectMessagesCountByType(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collect messages count by type
COLLISION_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CollisionContext - Interface in org.apache.ignite.spi.collision
Context for resolving collisions.
CollisionExternalListener - Interface in org.apache.ignite.spi.collision
Listener to be set on CollisionSpi for notification of external collision events (e.g. job stealing).
CollisionJobContext - Interface in org.apache.ignite.spi.collision
This interface defines set of operations that collision SPI implementation can perform on jobs that are either waiting or executing.
CollisionSpi - Interface in org.apache.ignite.spi.collision
Collision SPI allows to regulate how grid jobs get executed when they arrive on a destination node for execution.
collocated() - Method in interface org.apache.ignite.IgniteQueue
Returns true if this queue can be kept on the one node only.
collocated() - Method in interface org.apache.ignite.IgniteSet
Returns true if this set can be kept on the one node only.
collocated() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
Collocated flag.
collocated() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
collocated() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets flag defining if this query is collocated.
colocated() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether all items of this set are stored on a single node.
colocated() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
COLON - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
COLON - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
COLON() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
 
COLON() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
 
COLON() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
colSize - Variable in class org.apache.ignite.ml.structures.Dataset
Amount of attributes in each vector.
colSize() - Method in class org.apache.ignite.ml.structures.Dataset
Gets amount of attributes.
column() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix.Element
Gets element's column index.
COLUMN_STORAGE_MODE - Static variable in interface org.apache.ignite.ml.math.StorageConstants
Storage mode optimized for column access.
columnIndex(Map<String, Integer>, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Find column index by database name.
ColumnIndexException - Exception in org.apache.ignite.ml.math.exceptions
This exception is used to indicate any error condition accessing matrix elements by invalid column index.
ColumnIndexException(int) - Constructor for exception org.apache.ignite.ml.math.exceptions.ColumnIndexException
 
columnName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
columnName() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
columnOffset() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
columns() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns all columns on which index is built.
columnsCount() - Method in class org.apache.ignite.ml.tree.data.TreeDataIndex
 
columnsCount(DecisionTreeData, TreeDataIndex) - Method in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Returns columns count in current dataset.
columnSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets number of columns in this matrix.
columnSize() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets number of columns in this matrix.
columnSize() - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
 
columnSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
columnSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
columnSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
columnsLength() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
combine(IgniteModel<T, W>, BiFunction<V, W, X>) - Method in interface org.apache.ignite.ml.IgniteModel
Combines this model with other model via specified combiner
COMMA - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
COMMA - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
COMMA() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
COMMA(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
CommandLineRandomNumberGenerator - Class in org.apache.ignite.startup.cmdline
Generates a random number and prints it to the console.
CommandLineRandomNumberGenerator() - Constructor for class org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
 
CommandLineStartup - Class in org.apache.ignite.startup.cmdline
This class defines command-line Ignite startup.
CommandLineTransformer - Class in org.apache.ignite.startup.cmdline
This class is a workaround for a versatile problems with passing arguments to the Ignite Windows batch launcher scripts.
commit() - Method in interface org.apache.ignite.client.ClientTransaction
Commits this transaction.
commit() - Method in interface org.apache.ignite.transactions.Transaction
Commits this transaction by initiating two-phase-commit process.
commitAsync() - Method in interface org.apache.ignite.transactions.Transaction
Asynchronously commits this transaction by initiating two-phase-commit process.
commitTime() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The last time, when transaction was commited.
commitTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets last time transaction was committed.
commonData(Map<Integer, Serializable>) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
commonData() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
commonData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData
 
commonDataCollectedFor(Integer) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
COMMUNICATION_METRICS_GROUP_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Communication metrics group name.
COMMUNICATION_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CommunicationFailureContext - Interface in org.apache.ignite.configuration
Communication Failure Context.
CommunicationFailureResolver - Interface in org.apache.ignite.configuration
Communication Failure Resolver.
communicationFailureResolveSupported() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
CommunicationListener<T extends Serializable> - Interface in org.apache.ignite.spi.communication
Listener SPI notifies IO manager with.
CommunicationSpi<T extends Serializable> - Interface in org.apache.ignite.spi.communication
Communication SPI is responsible for data exchange between nodes.
COMPARE - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns {@code a < b ?
compare(String, String) - Method in class org.apache.ignite.yarn.IgniteProvider.VersionComparator
compareAndSet(long, long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Atomically compares current value to the expected value, and if they are equal, sets current value to new value.
compareAndSet(long, long) - Method in interface org.apache.ignite.IgniteAtomicLong
Atomically compares current value to the expected value, and if they are equal, sets current value to new value.
compareAndSet(T, T) - Method in interface org.apache.ignite.IgniteAtomicReference
Conditionally sets the new value.
compareAndSet(T, T, S, S) - Method in interface org.apache.ignite.IgniteAtomicStamped
Conditionally sets the new value and new stamp.
compareTo(Event) - Method in class org.apache.ignite.events.EventAdapter
compareTo(IgniteProductVersion) - Method in class org.apache.ignite.lang.IgniteProductVersion
compareTo(IgniteUuid) - Method in class org.apache.ignite.lang.IgniteUuid
compareTo(PointWithDistance) - Method in class org.apache.ignite.ml.knn.utils.PointWithDistance
compareTo(T) - Method in interface org.apache.ignite.ml.tree.impurity.ImpurityMeasure
compareTo(Object) - Method in class org.apache.ignite.ml.util.genetic.Chromosome
compareTo(SnapshotProgress) - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
compareToIgnoreTimestamp(IgniteProductVersion) - Method in class org.apache.ignite.lang.IgniteProductVersion
 
completions() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets number of completed execution of query.
componentsProbs() - Method in class org.apache.ignite.ml.math.stat.DistributionMixture
 
compositeRwLockIndex() - Method in class org.apache.ignite.thread.IgniteThread
 
compositeRwLockIndex(int) - Method in class org.apache.ignite.thread.IgniteThread
 
CompositionUtils - Class in org.apache.ignite.ml.composition
Various utility functions for trainers composition.
CompositionUtils() - Constructor for class org.apache.ignite.ml.composition.CompositionUtils
 
compositionWeights - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Composition weights.
compress(StepFunction<T>) - Method in class org.apache.ignite.ml.tree.impurity.util.SimpleStepFunctionCompressor
Compresses the given step function.
compress(StepFunction<T>) - Method in interface org.apache.ignite.ml.tree.impurity.util.StepFunctionCompressor
Compresses the given step function.
compress(StepFunction<T>[]) - Method in interface org.apache.ignite.ml.tree.impurity.util.StepFunctionCompressor
Compresses every step function in the given array.
compressionLevel() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Compression level.
compressionLevel() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Compression level of snashot compression.
CompressionMetrics - Interface in org.gridgain.grid.cache.compress
Compression implementation metrics.
compressionOption() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Compression parameter of snasphot.
compressKeys() - Method in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
Gets flag indicating whether cache keys will be considered for compression.
compute() - Method in interface org.apache.ignite.client.IgniteClient
Gets compute facade over all cluster nodes started in server mode.
compute(ClientClusterGroup) - Method in interface org.apache.ignite.client.IgniteClient
Gets compute facade over the specified cluster group.
compute() - Method in interface org.apache.ignite.Ignite
Gets compute facade over all cluster nodes started in server mode.
compute(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets compute facade over the specified cluster group.
compute() - Method in class org.apache.ignite.IgniteSpringBean
Gets compute facade over all cluster nodes started in server mode.
compute(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets compute facade over the specified cluster group.
compute(IgniteBiFunction<D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data and LearningEnvironment in the dataset and then reduces map results to final result by using the reduce function.
compute(IgniteBiFunction<D, LearningEnvironment, R>, IgniteBinaryOperator<R>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data and LearningEnvironment in the dataset and then reduces map results to final result by using the reduce function.
compute(IgniteFunction<D, R>, IgniteBinaryOperator<R>, R) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data in the dataset and then reduces map results to final result by using the reduce function.
compute(IgniteFunction<D, R>, IgniteBinaryOperator<R>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data in the dataset and then reduces map results to final result by using the reduce function.
compute(IgniteBiConsumer<D, LearningEnvironment>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data in the dataset and LearningEnvironment.
compute(IgniteConsumer<D>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data in the dataset.
compute(IgniteBiFunction<D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDataset
Applies the specified map function to every partition data and LearningEnvironment in the dataset and then reduces map results to final result by using the reduce function.
compute(IgniteBiFunction<D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDataset
Applies the specified map function to every partition data and LearningEnvironment in the dataset and then reduces map results to final result by using the reduce function.
compute(IgniteBiFunction<D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in class org.apache.ignite.ml.dataset.primitive.DatasetWrapper
Applies the specified map function to every partition data and LearningEnvironment in the dataset and then reduces map results to final result by using the reduce function.
compute(Vector, Vector) - Method in interface org.apache.ignite.ml.math.distances.DistanceMeasure
Compute the distance between two n-dimensional vectors.
compute(Vector, double[]) - Method in interface org.apache.ignite.ml.math.distances.DistanceMeasure
Compute the distance between n-dimensional vector and n-dimensional array.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.EuclideanDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, double[]) - Method in class org.apache.ignite.ml.math.distances.EuclideanDistance
Compute the distance between n-dimensional vector and n-dimensional array.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.HammingDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, double[]) - Method in class org.apache.ignite.ml.math.distances.HammingDistance
Compute the distance between n-dimensional vector and n-dimensional array.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, double[]) - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
Compute the distance between n-dimensional vector and n-dimensional array.
compute(int, int, IgniteTriFunction<Integer, Integer, Double, Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Replace matrix entry with value oldVal at (row, col) with result of computing f(row, col, oldVal).
compute(int, int, IgniteTriFunction<Integer, Integer, Double, Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
Replace matrix entry with value oldVal at (row, col) with result of computing f(row, col, oldVal).
compute(int, int, IgniteTriFunction<Integer, Integer, Double, Double>) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Replace matrix entry with value oldVal at (row, col) with result of computing f(row, col, oldVal).
compute(int, int, IgniteTriFunction<Integer, Integer, Double, Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
 
compute(int, IgniteIntDoubleToDoubleBiFunction) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Replace vector entry with value oldVal at i with result of computing f(i, oldVal).
compute(int, IgniteIntDoubleToDoubleBiFunction) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Replace vector entry with value oldVal at i with result of computing f(i, oldVal).
compute(int, IgniteIntDoubleToDoubleBiFunction) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Replace vector entry with value oldVal at i with result of computing f(i, oldVal).
computeDistributionFunction() - Method in interface org.apache.ignite.ml.dataset.feature.DistributionComputer
Compute distribution function.
computeDistributionFunction() - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
Compute distribution function.
computeError(Vector, Double, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceChecker
Compute error for the specific vector of dataset.
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.
computeInitialValue(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Compute mean value of label as first approximation.
ComputeJob - Interface in org.apache.ignite.compute
Defines executable unit for ComputeTask.
ComputeJobAdapter - Class in org.apache.ignite.compute
Convenience adapter for ComputeJob implementations.
ComputeJobAdapter() - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
No-arg constructor.
ComputeJobAdapter(Object) - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
Creates job with one arguments.
ComputeJobAdapter(Object...) - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
Creates job with specified arguments.
ComputeJobAfterSend - Annotation Type in org.apache.ignite.compute
This annotation allows to call a method right after the job has been successfully sent for execution.
ComputeJobBeforeFailover - Annotation Type in org.apache.ignite.compute
This annotation allows to call a method right before job is submitted to FailoverSpi.
ComputeJobContext - Interface in org.apache.ignite.compute
Context attached to every job executed on the grid.
ComputeJobContinuation - Interface in org.apache.ignite.compute
Defines continuation support for grid job context.
ComputeJobContinuationAdapter - Class in org.apache.ignite.compute
Convenience adapter for ComputeJob implementations.
ComputeJobContinuationAdapter() - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
No-arg constructor.
ComputeJobContinuationAdapter(Object) - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
Creates job with one arguments.
ComputeJobContinuationAdapter(Object...) - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
Creates job with specified arguments.
ComputeJobFailoverException - Exception in org.apache.ignite.compute
This runtime exception can be thrown from ComputeJob.execute() method to force job failover to another node within task topology.
ComputeJobFailoverException(String) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
Creates new exception with given error message.
ComputeJobFailoverException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
Creates new given throwable as a cause and source of error message.
ComputeJobFailoverException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
Creates new exception with given error message and optional nested exception.
ComputeJobMasterLeaveAware - Interface in org.apache.ignite.compute
Annotation for handling master node leave during job execution.
ComputeJobResult - Interface in org.apache.ignite.compute
Result of remote job which gets passed into ComputeTask.result(ComputeJobResult, List) method.
ComputeJobResultPolicy - Enum in org.apache.ignite.compute
This enumeration provides different types of actions following the last received job result.
ComputeJobSibling - Interface in org.apache.ignite.compute
Job sibling interface defines a job from the same split.
ComputeJobView - Class in org.apache.ignite.spi.systemview.view
Compute job representation for a SystemView.
ComputeJobView(IgniteUuid, GridJobWorker, ComputeJobView.ComputeJobState) - Constructor for class org.apache.ignite.spi.systemview.view.ComputeJobView
 
ComputeJobView.ComputeJobState - Enum in org.apache.ignite.spi.systemview.view
Compute job state.
computeLeafValue(ObjectHistogram<BootstrappedVector>) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.ClassifierLeafValuesComputer
Returns the most frequent value in according to statistic.
computeLeafValue(T) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.LeafValuesComputer
Compute value from leaf based on statistics on labels corresponds to leaf.
computeLeafValue(MeanValueStatistic) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.RegressionLeafValuesComputer
Returns the mean value in according to statistic.
ComputeLoadBalancer - Interface in org.apache.ignite.compute
Load balancer is used for finding the best balanced node according to load balancing policy.
computeMeanErrorOnDataset(Dataset<EmptyContext, ? extends FeatureMatrixWithLabelsOnHeapData>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceChecker
Compute error for given model on learning dataset.
computeMeanErrorOnDataset(Dataset<EmptyContext, ? extends FeatureMatrixWithLabelsOnHeapData>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.mean.MeanAbsValueConvergenceChecker
Compute error for given model on learning dataset.
computeMeanErrorOnDataset(Dataset<EmptyContext, ? extends FeatureMatrixWithLabelsOnHeapData>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.median.MedianOfMedianConvergenceChecker
Compute error for given model on learning dataset.
computeMeanErrorOnDataset(Dataset<EmptyContext, ? extends FeatureMatrixWithLabelsOnHeapData>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.simple.ConvergenceCheckerStub
Compute error for given model on learning dataset.
computeState(Matrix) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Perform forward pass and return state of outputs of each layer.
computeStatistics(List<FeatureMeta>, Dataset<EmptyContext, BootstrappedDatasetPartition>) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatisticsComputer
Computes statistics of normal distribution on features in dataset.
computeStatsOnPartition(BootstrappedDatasetPartition, List<FeatureMeta>) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatisticsComputer
Aggregates normal distribution statistics for continual features in dataset partition.
ComputeTask<T,R> - Interface in org.apache.ignite.compute
Grid task interface defines a task that can be executed on the grid.
ComputeTaskAdapter<T,R> - Class in org.apache.ignite.compute
Convenience adapter for ComputeTask interface.
ComputeTaskAdapter() - Constructor for class org.apache.ignite.compute.ComputeTaskAdapter
 
ComputeTaskCancelledException - Exception in org.apache.ignite.compute
This exception indicates that grid task was cancelled.
ComputeTaskCancelledException(String) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
Creates new task cancellation exception with given error message.
ComputeTaskCancelledException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
Creates new task cancellation exception given throwable as a cause and source of error message.
ComputeTaskCancelledException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
Creates new task cancellation exception with given error message and optional nested exception.
ComputeTaskContinuousMapper - Interface in org.apache.ignite.compute
Defines a mapper that can be used for asynchronous job sending.
ComputeTaskFuture<R> - Interface in org.apache.ignite.compute
This class defines a handler for asynchronous task execution.
ComputeTaskMapAsync - Annotation Type in org.apache.ignite.compute
Annotation for asynchronous task mapping.
ComputeTaskName - Annotation Type in org.apache.ignite.compute
This annotation allows to assign optional name to grid task.
ComputeTaskNoResultCache - Annotation Type in org.apache.ignite.compute
This annotation disables caching of task results when attached to ComputeTask class being executed.
ComputeTaskSession - Interface in org.apache.ignite.compute
Defines a distributed session for particular task execution.
ComputeTaskSessionAttributeListener - Interface in org.apache.ignite.compute
This interface defines listener for task session attributes.
ComputeTaskSessionFullSupport - Annotation Type in org.apache.ignite.compute
Annotation for enabling task session attributes and checkpoints for tasks.
ComputeTaskSessionScope - Enum in org.apache.ignite.compute
Defines life-time scopes for checkpoint operations.
ComputeTaskSpis - Annotation Type in org.apache.ignite.compute
This annotation allows task to specify what SPIs it wants to use.
ComputeTaskSplitAdapter<T,R> - Class in org.apache.ignite.compute
This class defines simplified adapter for ComputeTask.
ComputeTaskSplitAdapter() - Constructor for class org.apache.ignite.compute.ComputeTaskSplitAdapter
 
ComputeTaskTimeoutException - Exception in org.apache.ignite.compute
This exception indicates that task execution timed out.
ComputeTaskTimeoutException(String) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
Creates task timeout exception with given task execution ID and error message.
ComputeTaskTimeoutException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
Creates new task timeout exception given throwable as a cause and source of error message.
ComputeTaskTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
Creates task timeout exception with given task execution ID, error message and optional nested exception.
ComputeTaskView - Class in org.apache.ignite.spi.systemview.view
Compute task representation for a SystemView.
ComputeTaskView(IgniteUuid, GridTaskWorker) - Constructor for class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
ComputeUserUndeclaredException - Exception in org.apache.ignite.compute
This exception is thrown when user's code throws undeclared runtime exception.
ComputeUserUndeclaredException(String) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
Creates user undeclared exception with given task execution ID and error message.
ComputeUserUndeclaredException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
Creates new user undeclared exception given throwable as a cause and source of error message.
ComputeUserUndeclaredException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
Creates user undeclared exception with given task execution ID, error message and optional nested exception.
ComputeUtils - Class in org.apache.ignite.ml.dataset.impl.cache.util
Util class that provides common methods to perform computations on top of the Ignite Compute Grid.
ComputeUtils() - Constructor for class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
 
computeWithCtx(IgniteTriFunction<C, D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data, context and partition index in the dataset and then reduces map results to final result by using the reduce function.
computeWithCtx(IgniteTriFunction<C, D, LearningEnvironment, R>, IgniteBinaryOperator<R>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data, context and LearningEnvironment in the dataset and then reduces map results to final result by using the reduce function.
computeWithCtx(IgniteBiFunction<C, D, R>, IgniteBinaryOperator<R>, R) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data and context in the dataset and then reduces map results to final result by using the reduce function.
computeWithCtx(IgniteBiFunction<C, D, R>, IgniteBinaryOperator<R>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data and context in the dataset and then reduces map results to final result by using the reduce function.
computeWithCtx(IgniteTriConsumer<C, D, LearningEnvironment>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data, context and LearningEnvironment in the dataset.
computeWithCtx(IgniteBiConsumer<C, D>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Applies the specified map function to every partition data and context in the dataset.
computeWithCtx(IgniteTriFunction<C, D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDataset
Applies the specified map function to every partition data, context and partition index in the dataset and then reduces map results to final result by using the reduce function.
computeWithCtx(IgniteTriFunction<C, D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDataset
Applies the specified map function to every partition data, context and partition index in the dataset and then reduces map results to final result by using the reduce function.
computeWithCtx(IgniteTriFunction<C, D, LearningEnvironment, R>, IgniteBinaryOperator<R>, R) - Method in class org.apache.ignite.ml.dataset.primitive.DatasetWrapper
Applies the specified map function to every partition data, context and partition index in the dataset and then reduces map results to final result by using the reduce function.
concat(Vector, Vector) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Concatenates two given vectors.
concat(Vector, Vector...) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Concatenates given vectors.
concat(Vector...) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Concatenates given vectors.
concat(VectorGenerator) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Creates new generator by concatenation of vectors of this generator and other.
concat(RandomProducer) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Creates new generator by concatenation of vectors of this generator and random producer.
concurrency() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
concurrency() - Method in interface org.apache.ignite.transactions.Transaction
Cache transaction concurrency mode.
ConditionFalse - Class in org.apache.ignite.springdata22.repository.support
Always false condition.
ConditionFalse() - Constructor for class org.apache.ignite.springdata22.repository.support.ConditionFalse
 
CONFIG_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
configInfo(String, Object) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformed string for configuration parameter.
configName() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
configuration() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets configuration bean for this cache.
configuration() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the client configuration.
configuration() - Method in interface org.apache.ignite.Ignite
Gets the configuration of this Ignite instance.
configuration() - Method in class org.apache.ignite.IgniteSpringBean
Gets the configuration of this Ignite instance.
configuration() - Method in interface org.gridgain.grid.GridGain
 
configureHistogramMetric(String, long[]) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
Change HistogramMetric configuration.
configureHitRateMetric(String, long) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
Change HitRateMetric configuration.
conflict(String) - Static method in class org.apache.ignite.cache.QueryEntityPatch
Builder method for patch with conflicts.
conflictMerge() - Method in interface org.gridgain.grid.cache.dr.CacheDrReceiverMetrics
Gets total amount of conflicts resolved by merge.
conflictNew() - Method in interface org.gridgain.grid.cache.dr.CacheDrReceiverMetrics
Gets total amount of conflicts resolved by using new value.
conflictOld() - Method in interface org.gridgain.grid.cache.dr.CacheDrReceiverMetrics
Gets total amount of conflicts resolved by using old value.
CONN_IDX_META - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Connection index meta for session.
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcThinDriver
connectCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
connection() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
connection(byte) - Method in interface org.gridgain.grid.dr.DrSender
Get connection to remote data center with provided ID.
connectionAvailable(ClusterNode, ClusterNode) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
ConnectionClosedEvent - Class in org.apache.ignite.client.events
Event that is fired when a connection is closed.
ConnectionClosedEvent(ConnectionDescription, Throwable) - Constructor for class org.apache.ignite.client.events.ConnectionClosedEvent
 
ConnectionDescription - Class in org.apache.ignite.client.events
Connection description.
ConnectionDescription(InetSocketAddress, InetSocketAddress, String, UUID) - Constructor for class org.apache.ignite.client.events.ConnectionDescription
 
connectionDescription() - Method in class org.apache.ignite.client.events.ConnectionEvent
 
connectionDescription() - Method in class org.apache.ignite.client.events.RequestEvent
 
ConnectionEvent - Class in org.apache.ignite.client.events
Base class for connection events.
ConnectionEvent(ConnectionDescription) - Constructor for class org.apache.ignite.client.events.ConnectionEvent
 
ConnectionEventListener - Interface in org.apache.ignite.client.events
Listener for connection events.
connectionId() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
connectionId() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
connections() - Method in interface org.gridgain.grid.dr.DrSender
Get all connections to remote data centers configured for this sender.
connectionState() - Method in interface org.gridgain.grid.dr.DrSenderConnection
Get state of the connection to remote data center.
ConnectorConfiguration - Class in org.apache.ignite.configuration
REST access configuration.
ConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
Creates client connection configuration with all default values.
ConnectorConfiguration(ConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
Creates client connection configuration by copying all properties from given configuration.
ConnectorMessageInterceptor - Interface in org.apache.ignite.configuration
Interface for user-defined object interceptors.
connRecoveryTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default connection recovery timeout in ms.
CONSISTENT_ID_META - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node consistent id meta for session.
CONSISTENT_ID_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite node consistent id.
consistentId() - Method in interface org.apache.ignite.cluster.BaselineNode
Gets consistent globally unique node ID.
consistentId() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets consistent globally unique node ID.
consistentId() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets consistent globally unique node ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
consistentId() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
ConsoleLogger - Class in org.apache.ignite.ml.environment.logging
Simple logger printing to STD-out.
ConsoleLogger.Factory - Class in org.apache.ignite.ml.environment.logging
ConsoleLogger factory.
constant(Double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns passed constant.
constant(R) - Static method in interface org.apache.ignite.ml.math.functions.IgniteFunction
IgniteFunction returning specified constant.
constant(Vector) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
 
contains(Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
contains(Object) - Method in interface org.apache.ignite.client.ClientIgniteSet
contains(Object) - Method in interface org.apache.ignite.IgniteQueue
contains(Object) - Method in interface org.apache.ignite.IgniteSet
containsAll(Collection<?>) - Method in interface org.apache.ignite.client.ClientIgniteSet
containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
containsField(List<? extends PojoField>, String) - Static method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Checks if list contains POJO field with the specified name.
containsKey(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
containsKey(K) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains an entry for the specified key.
containsKey(K) - Method in interface org.apache.ignite.IgniteCache
containsKey(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
containsKey(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns true if this cache contains a mapping for the specified key.
containsKey(K) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Determines if the ClientCache contains an entry for the specified key.
containsKey(K) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Determines if the ClientCache contains an entry for the specified key.
containsKey(K) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Determines if the ClientCache contains an entry for the specified key.
containsKeyAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
containsKeyAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains an entry for the specified key asynchronously.
containsKeyAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains an entry for the specified key.
containsKeys(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains entries for the specified keys.
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Determines if the Cache contains entries for the specified keys.
containsKeysAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
containsKeysAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains entries for the specified keys asynchronously.
containsKeysAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains entries for the specified keys.
containsValue(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
context() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
contextDestroyed(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
contextInitialized(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
ContinuousQuery<K,V> - Class in org.apache.ignite.cache.query
API for configuring continuous cache queries.
ContinuousQuery() - Constructor for class org.apache.ignite.cache.query.ContinuousQuery
Creates new continuous query.
continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets continuous query filter.
continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets continuous query filter.
ContinuousQueryView - Class in org.apache.ignite.spi.systemview.view
Continuous query representation for a SystemView.
ContinuousQueryView(UUID, GridContinuousProcessor.RoutineInfo) - Constructor for class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
ContinuousQueryWithTransformer<K,V,T> - Class in org.apache.ignite.cache.query
API for configuring continuous cache queries with transformer.
ContinuousQueryWithTransformer() - Constructor for class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Creates new continuous query with transformer.
ContinuousQueryWithTransformer.EventListener<T> - Interface in org.apache.ignite.cache.query
Interface for local listener of ContinuousQueryWithTransformer to implement.
controller() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Service method to get persistence controller instance
ConvergenceChecker<K,V> - Class in org.apache.ignite.ml.composition.boosting.convergence
Contains logic of error computing and convergence checking for Gradient Boosting algorithms.
ConvergenceChecker(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>, double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceChecker
Constructs an instance of ConvergenceChecker.
ConvergenceCheckerFactory - Class in org.apache.ignite.ml.composition.boosting.convergence
Factory for ConvergenceChecker.
ConvergenceCheckerFactory(double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceCheckerFactory
Creates an instance of ConvergenceCheckerFactory.
ConvergenceCheckerStub<K,V> - Class in org.apache.ignite.ml.composition.boosting.convergence.simple
This strategy skip estimating error on dataset step.
ConvergenceCheckerStub(long, IgniteFunction, Loss, DatasetBuilder, Preprocessor<K, V>, double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.simple.ConvergenceCheckerStub
Creates an instance of ConvergenceCheckerStub.
ConvergenceCheckerStubFactory - Class in org.apache.ignite.ml.composition.boosting.convergence.simple
ConvergenceCheckerStubFactory() - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.simple.ConvergenceCheckerStubFactory
Create an instance of ConvergenceCheckerStubFactory.
conversionClosure() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
conversionClosure(IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets optional closure for CacheConfiguration conversion during snapshot restore.
conversionClosure() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
conversionClosure(IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets closure for CacheConfiguration conversion during snapshot restore.
convert(Exception) - Method in interface org.apache.ignite.cache.hibernate.HibernateExceptionConverter
 
convert(byte[]) - Method in interface org.apache.ignite.stream.socket.SocketMessageConverter
Converter message represented by array of bytes to object.
convertDatasetIntoModel(Dataset<EmptyContext, SpatialIndex<Double>>) - Method in class org.apache.ignite.ml.knn.classification.KNNClassificationTrainer
Convers given dataset into KNN model (classification or regression depends on implementation).
convertDatasetIntoModel(Dataset<EmptyContext, SpatialIndex<Double>>) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Convers given dataset into KNN model (classification or regression depends on implementation).
convertDatasetIntoModel(Dataset<EmptyContext, SpatialIndex<Double>>) - Method in class org.apache.ignite.ml.knn.regression.KNNRegressionTrainer
Convers given dataset into KNN model (classification or regression depends on implementation).
convertStringNamesToFeatureMetadata(String[]) - Method in class org.apache.ignite.ml.structures.Dataset
 
copy() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
copy(Vector, Vector) - Method in class org.apache.ignite.ml.math.Blas
Copies Vector x into Vector y.
copy() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Clones this matrix.
copy() - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
Clones this matrix.
copy() - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
Clones this matrix.
copy() - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.ViewMatrix
Clones this matrix.
copy() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Clones this matrix.
copy() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new copy of this vector.
copy() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new copy of this vector.
copy() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
Creates new copy of this vector.
copy() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
Creates new copy of this vector.
copy() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new copy of this vector.
copy(Matrix) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Create the copy of matrix with read-only matrices support.
copy() - Method in class org.apache.ignite.ml.structures.LabeledVectorSet
Makes copy with new Label objects and old features and Metadata objects.
copy() - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Creates chromosome copy.
copy(T) - Static method in class org.apache.ignite.ml.util.Utils
Perform deep copy of an object.
copy(CopySnapshotParams) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Copy a snapshot with the given ID to the given destination folder.
copy(Path, SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.copy.TwoPhaseFilesCopyStrategy
Perform two phase copy.
copy() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
COPY_MARKER_FILENAME - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Copy marker filename.
copyDigestRegistry(long, SnapshotPath, SnapshotOperationContext) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
CopyFileVisitor - Class in org.gridgain.grid.persistentstore.snapshot.file
Visitor that copied dataFiles(partition, index) using CopyStrategy provided in constructor.
CopyFileVisitor(Path, SnapshotPath, SnapshotOperationContext, CopyStrategy, Consumer<Runnable>) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.CopyFileVisitor
 
copyFrom(Path) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Copies file from local destination with two phase copy pattern.
copyLocalToHdfs(FileSystem, String, String) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
copyMetadata(long, SnapshotPath, SnapshotOperationContext) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
copyOfRange(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Copies the specified range of the vector into a new vector.
copyOfRange(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Copies the specified range of the vector into a new vector.
copyOfRange(int, int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Copies the specified range of the vector into a new vector.
copyParametersFrom(NNClassificationModel) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Sets parameters from other model to this model.
copyPart(Vector, int, int) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Get copy of part of given length of given vector starting from given offset.
copyright() - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
copyright() - Method in interface org.apache.ignite.plugin.PluginProvider
 
COPYRIGHT_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
copySinglePartition(long, int, int, SnapshotPath, SnapshotOperationContext) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Will copy only single partition.
copySnapshot(long, File, SnapshotUpdateOperationParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
copySnapshot(long, File, SnapshotUpdateOperationParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
copySnapshot(long, File, boolean, SnapshotUpdateOperationParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
copySnapshot(long, File, boolean, SnapshotUpdateOperationParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
copySnapshotEntirely(long, SnapshotPath, SnapshotOperationContext, ExecutorService) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Will copy snapshot completely to the path.
CopySnapshotParams - Class in org.gridgain.grid.persistentstore
Parameters for copy snapshot operation.
CopySnapshotParams() - Constructor for class org.gridgain.grid.persistentstore.CopySnapshotParams
 
copyWalSegments(long, Collection<File>, SnapshotPath, SnapshotOperationContext) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
corr() - Method in class org.apache.ignite.ml.dataset.primitive.SimpleDataset
Calculates correlation matrix by all columns.
CORRUPTED_META_HASH_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
Error message when metadata hash is corrupted in snapshot digest registry.
CORRUPTED_PART_HASH_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.DigestSnapshotInputStream
Error message when data or index partition hash is corrupted in snapshot digest registry.
count() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets current count value of the latch.
count() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets total count of executions this task has already completed.
count() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
count() - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
 
count() - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
COUNT_QUERY_STRING - Static variable in class org.apache.ignite.springdata22.repository.query.QueryUtils
The constant COUNT_QUERY_STRING.
countDown() - Method in interface org.apache.ignite.IgniteCountDownLatch
Decrements the count of the latch, releasing all waiting threads on all nodes if the count reaches zero.
countDown(int) - Method in interface org.apache.ignite.IgniteCountDownLatch
Decreases the count of the latch using passed in value, releasing all waiting threads on all nodes if the count reaches zero.
countDownAll() - Method in interface org.apache.ignite.IgniteCountDownLatch
Counts down this latch to zero, releasing all waiting threads on all nodes.
countDownLatch(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates count down latch.
countDownLatch(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates count down latch.
CountDownLatchView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteCountDownLatch representation for a SystemView.
CountDownLatchView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
counters() - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedVector
 
CountersHistogram - Class in org.apache.ignite.ml.tree.randomforest.data.impurity.basic
Represents a historam of element counts per bucket.
CountersHistogram(Set<Integer>, BucketMeta, int, int) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.CountersHistogram
Creates an instance of CountersHistogram.
countOfComponents() - Method in class org.apache.ignite.ml.math.stat.DistributionMixture
 
counts() - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Gets the array of amounts of values in partition for each feature in the dataset.
COURTESY_LOGGER_NAME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Courtesy notice log category.
cov() - Method in class org.apache.ignite.ml.dataset.primitive.SimpleDataset
Calculates covariance matrix by all columns.
covariance() - Method in class org.apache.ignite.ml.math.stat.MultivariateGaussianDistribution
 
CovarianceMatricesAggregator - Class in org.apache.ignite.ml.clustering.gmm
This class encapsulates statistics aggregation logic for feature vector covariance matrix computation of one GMM component (cluster).
CPU - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Cpus.
cpuCores - Variable in class org.apache.ignite.mesos.IgniteTask
 
cpuCores() - Method in class org.apache.ignite.mesos.IgniteTask
 
cpuCores - Variable in class org.apache.ignite.yarn.IgniteContainer
 
cpuCores() - Method in class org.apache.ignite.yarn.IgniteContainer
 
cpus() - Method in class org.apache.ignite.mesos.ClusterProperties
 
cpus(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets CPU count limit.
cpusPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
cpusPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets CPU count limit.
cpusPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
cpusPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets CPU count limit.
create(int) - Method in interface org.apache.ignite.binary.BinaryCollectionFactory
Create collection.
create(int) - Method in interface org.apache.ignite.binary.BinaryMapFactory
Create collection.
create() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
create() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
create() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
create() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
create() - Method in class org.apache.ignite.cache.jta.websphere.WebSphereLibertyTmFactory
create() - Method in class org.apache.ignite.cache.jta.websphere.WebSphereTmFactory
create() - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
create() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
create() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
create(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceCheckerFactory
Create an instance of ConvergenceChecker.
create(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.convergence.mean.MeanAbsValueConvergenceCheckerFactory
Create an instance of ConvergenceChecker.
create(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.convergence.median.MedianOfMedianConvergenceCheckerFactory
Create an instance of ConvergenceChecker.
create(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.convergence.simple.ConvergenceCheckerStubFactory
Create an instance of ConvergenceChecker.
create(DatasetBuilder<K, V>, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>, LearningEnvironment) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed dataset using the specified partCtxBuilder and partDataBuilder.
create(DatasetBuilder<K, V>, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed dataset using the specified partCtxBuilder and partDataBuilder.
create(Ignite, IgniteCache<K, V>, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>, LearningEnvironment) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed dataset using the specified partCtxBuilder and partDataBuilder.
create(Ignite, IgniteCache<K, V>, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed dataset using the specified partCtxBuilder and partDataBuilder.
create(Map<K, V>, LearningEnvironmentBuilder, int, PartitionContextBuilder<K, V, C>, PartitionDataBuilder<K, V, C, D>, LearningEnvironment) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of local dataset using the specified partCtxBuilder and partDataBuilder.
create() - Static method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer.Mapping
Creates an instance of Mapping.
create(Class<T>) - Method in class org.apache.ignite.ml.environment.logging.ConsoleLogger.Factory
Creates an instance of MLLogger for target class.
create(Class<T>) - Method in interface org.apache.ignite.ml.environment.logging.MLLogger.Factory
Creates an instance of MLLogger for target class.
create() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
create() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
create() - Method in interface org.apache.ignite.platform.PlatformJavaObjectFactory
Constructs and returns a fully configured instance of T.
create(short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactory
Deprecated.
Creates new message instance of provided type.
create(short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactoryProvider
create() - Method in interface org.apache.ignite.plugin.platform.PlatformCachePluginConfigurationClosureFactory
Creates configuration closure instance.
create() - Method in interface org.apache.ignite.plugin.platform.PlatformPluginConfigurationClosureFactory
Creates configuration instance.
create() - Static method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Static factory method for create new permission builder.
create() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Creates new key for an encryption/decryption of cache persistent data: pages, WAL records.
create() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Creates new key for an encryption/decryption of cache persistent data: pages, WAL records.
create() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Creates new key for an encryption/decryption of cache persistent data: pages, WAL records.
create(String, byte[]) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
Creates Span given name and explicit parent.
create(String, NoopSpiSpecificSpan) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
Creates Span given name and explicit parent.
create(String, byte[]) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Creates Span given name and explicit parent.
create(String, OpenCensusSpanAdapter) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Creates Span given name and explicit parent.
create(String, byte[]) - Method in interface org.apache.ignite.spi.tracing.TracingSpi
Creates Span given name and explicit parent.
create(String, S) - Method in interface org.apache.ignite.spi.tracing.TracingSpi
Creates Span given name and explicit parent.
create() - Method in class org.apache.ignite.ssl.SslContextFactory
create(SnapshotRemotePath, SftpConfiguration) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathFactory
Creates snapshot path.
create(Collection<SnapshotRemotePath>, IgniteLogger, SftpConfiguration) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathFactory
Converts File to SnapshotPath in collection.
createCache(String, C) - Method in class org.apache.ignite.cache.CacheManager
createCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with a default configuration.
createCache(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with the specified configuration.
createCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache using template configuration.
createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache with the given cache configuration.
createCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache with the given cache configuration.
createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache using template configuration.
createCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with a default configuration.
createCacheAsync(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with the specified configuration.
createCacheProvider(CachePluginContext) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Creates cache plugin provider.
createCacheProvider(CachePluginContext) - Method in interface org.apache.ignite.plugin.PluginProvider
Creates cache plugin provider.
createCaches(Collection<CacheConfiguration>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new caches with the given cache configurations.
createCaches(Collection<CacheConfiguration>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new caches with the given cache configurations.
createCluster(UUID, TensorFlowJobArchive) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGatewayManager
Creates and starts a new TensorFlow cluster for the specified cache.
createCluster(UUID, TensorFlowJobArchive, Consumer<String>, Consumer<String>) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Creates and starts a new TensorFlow cluster for the specified cache.
createComponent(PluginContext, Class<T>) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Creates Ignite component.
createComponent(Class<T>) - Method in interface org.apache.ignite.plugin.CachePluginProvider
 
createComponent(PluginContext, Class<T>) - Method in interface org.apache.ignite.plugin.PluginProvider
Creates Ignite component.
createConsoleLogger() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates console appender with some reasonable default logging settings.
createDefaultPolicyConfig() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Creates a configuration for the default memory policy that will instantiate the default memory region.
createDescriptors(SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.DescriptorFactory
Creates descriptors based on path.
createDigest() - Method in interface org.gridgain.grid.persistentstore.MessageDigestFactory
 
createDirectories() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Creates directories.
createFileSnapshot(IgniteConfiguration, FileDatabaseSnapshotSpi, long, SnapshotPath, Collection<SnapshotPath>, IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>, boolean, boolean, SnapshotSecurityLevel, MessageDigestFactory, SnapshotRegistryTransformer, GridCacheSharedContext) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
To facilitate tests we need to wrap constructor of FileSnapshot in this method.
createFrom(Map<SecurityCredentials, SecurityPermissionSet>) - Static method in class org.gridgain.grid.security.passcode.AuthenticationAclBasicProvider
 
createFullSnapshot(Set<String>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates full snapshot creation.
createFullSnapshot(Set<String>, File, SnapshotCreateParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
createFullSnapshot(Set<String>, File, SnapshotCreateParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates full snapshot creation.
createFullSnapshot(Set<String>, File, SnapshotCommonParameters, SnapshotCreateParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
createFullSnapshot(Set<String>, File, SnapshotCommonParams, SnapshotCreateParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates full snapshot creation.
createFullSnapshot(Set<String>, Set<String>, File, SnapshotCommonParams, SnapshotCreateParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates full snapshot creation.
createImpurityComputerForFeature(int, BucketMeta) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogramsComputer
Creates impurity computer in according to specific algorithm based on random forest (for example GiniHistogram for classification).
createImpurityComputerForFeature(int, BucketMeta) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer
Creates impurity computer in according to specific algorithm based on random forest (for example GiniHistogram for classification).
createImpurityComputerForFeature(int, BucketMeta) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogramComputer
Creates impurity computer in according to specific algorithm based on random forest (for example GiniHistogram for classification).
createImpurityHistogramsComputer() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Creates an instance of Histograms Computer corresponding to RF implementation.
createImpurityHistogramsComputer() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestRegressionTrainer
Creates an instance of Histograms Computer corresponding to RF implementation.
createImpurityHistogramsComputer() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Creates an instance of Histograms Computer corresponding to RF implementation.
createIndexByFilter(int, TreeFilter) - Method in class org.apache.ignite.ml.tree.data.DecisionTreeData
Builds index in according to current tree depth and cached indexes in upper levels.
createLeaf(TreeNode) - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeSplit
Convert node to leaf.
createLeafNode(Dataset<EmptyContext, DecisionTreeData>, TreeFilter) - Method in interface org.apache.ignite.ml.tree.leaf.DecisionTreeLeafBuilder
Creates new leaf node for given dataset and node predicate.
createLeafNode(Dataset<EmptyContext, DecisionTreeData>, TreeFilter) - Method in class org.apache.ignite.ml.tree.leaf.MeanDecisionTreeLeafBuilder
Creates new leaf node for given dataset and node predicate.
createLeafNode(Dataset<EmptyContext, DecisionTreeData>, TreeFilter) - Method in class org.apache.ignite.ml.tree.leaf.MostCommonDecisionTreeLeafBuilder
Creates new leaf node for given dataset and node predicate.
createLeafStatisticsAggregator() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Creates an instance of Leaf Statistics Aggregator corresponding to RF implementation.
createLeafStatisticsAggregator() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestRegressionTrainer
Creates an instance of Leaf Statistics Aggregator corresponding to RF implementation.
createLeafStatisticsAggregator() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Creates an instance of Leaf Statistics Aggregator corresponding to RF implementation.
createLeafStatsAggregator(int) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.ClassifierLeafValuesComputer
Creates an instance of leaf statistics aggregator in according to concrete algorithm based on RandomForest.
createLeafStatsAggregator(int) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.LeafValuesComputer
Creates an instance of leaf statistics aggregator in according to concrete algorithm based on RandomForest.
createLeafStatsAggregator(int) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.RegressionLeafValuesComputer
Creates an instance of leaf statistics aggregator in according to concrete algorithm based on RandomForest.
createName(long, String, String) - Static method in class org.apache.ignite.thread.IgniteThread
Creates new thread name.
createNearCache(String, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Starts a near cache on local node if cache was previously started with one of the Ignite.createCache(CacheConfiguration) or Ignite.createCache(CacheConfiguration, NearCacheConfiguration) methods.
createNearCache(String, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Starts a near cache on local node if cache was previously started with one of the Ignite.createCache(CacheConfiguration) or Ignite.createCache(CacheConfiguration, NearCacheConfiguration) methods.
createNewFile() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Creates new file.
createPojoField(Element, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates instance of PojoField based on it's description in XML element.
createPojoField(PojoFieldAccessor) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates instance of PojoField from its field accessor.
createPojoField(PojoKeyField, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates instance of PojoField based on the other instance and java class to initialize accessor.
createPojoField(Element, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Creates instance of PojoField based on it's description in XML element.
createPojoField(PojoFieldAccessor) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Creates instance of PojoField from its field accessor.
createPojoField(F, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Creates instance of PojoField based on the other instance and java class to initialize accessor.
createPojoField(Element, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates instance of PojoField based on it's description in XML element.
createPojoField(PojoFieldAccessor) - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates instance of PojoField from its field accessor.
createPojoField(PojoValueField, Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates instance of PojoField based on the other instance and java class to initialize accessor.
createRepositoryFactory() - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactoryBean
createSimpleDataset(DatasetBuilder<K, V>, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleDataset using the specified partCtxBuilder and featureExtractor.
createSimpleDataset(Ignite, IgniteCache<K, V>, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleDataset using the specified partCtxBuilder and featureExtractor.
createSimpleDataset(DatasetBuilder<K, V>, LearningEnvironmentBuilder, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleDataset using the specified featureExtractor.
createSimpleDataset(Ignite, IgniteCache<K, V>, LearningEnvironmentBuilder, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleDataset using the specified featureExtractor.
createSimpleDataset(Ignite, IgniteCache<K, V>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleDataset using the specified featureExtractor.
createSimpleDataset(Map<K, V>, int, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of local SimpleDataset using the specified partCtxBuilder and featureExtractor.
createSimpleDataset(Map<K, V>, int, LearningEnvironmentBuilder, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of local SimpleDataset using the specified featureExtractor.
createSimpleLabeledDataset(DatasetBuilder<K, V>, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleLabeledDataset using the specified partCtxBuilder, featureExtractor and lbExtractor.
createSimpleLabeledDataset(Ignite, IgniteCache<K, V>, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleLabeledDataset using the specified partCtxBuilder, featureExtractor and lbExtractor.
createSimpleLabeledDataset(DatasetBuilder<K, V>, LearningEnvironmentBuilder, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleLabeledDataset using the specified featureExtractor and lbExtractor.
createSimpleLabeledDataset(Ignite, LearningEnvironmentBuilder, IgniteCache<K, V>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of distributed SimpleLabeledDataset using the specified featureExtractor and lbExtractor.
createSimpleLabeledDataset(Map<K, V>, int, LearningEnvironmentBuilder, PartitionContextBuilder<K, V, C>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of local SimpleLabeledDataset using the specified partCtxBuilder, featureExtractor and lbExtractor.
createSimpleLabeledDataset(Map<K, V>, LearningEnvironmentBuilder, int, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.dataset.DatasetFactory
Creates a new instance of local SimpleLabeledDataset using the specified featureExtractor and lbExtractor.
createSnapshot(Set<String>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates incremental snapshot creation.
createSnapshot(Set<String>, File, SnapshotCreateParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
createSnapshot(Set<String>, File, SnapshotCreateParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates incremental snapshot creation.
createSnapshot(Set<String>, File, SnapshotCommonParameters, SnapshotCreateParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
createSnapshot(Set<String>, File, SnapshotCommonParams, SnapshotCreateParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates incremental snapshot creation.
createSnapshot(Set<String>, Set<String>, File, SnapshotCommonParams, SnapshotCreateParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Initiates incremental snapshot creation.
createSpiAttributeName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Creates new name for the given attribute.
createTcpClient(ClusterNode, int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Establish TCP connection to remote node and returns client.
createTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets time in milliseconds at which this future was created.
createTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
createTokenBuffer(Credentials) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
Creates a ByteBuffer with serialized Credentials.
createVector(int) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Create an instance of vector.
createVector(int) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Create an instance of vector.
Credentials - Interface in org.apache.ignite.cache.store.cassandra.datasource
Provides credentials for Cassandra (instead of specifying user/password directly in Spring context XML).
credentials() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets security credentials.
credentials(SecurityCredentials) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets security credentials.
credentials() - Method in class org.apache.ignite.plugin.security.SecurityCredentialsBasicProvider
Gets security credentials.
credentials() - Method in interface org.apache.ignite.plugin.security.SecurityCredentialsProvider
Gets security credentials.
credentials() - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
Unless CertificateAuthenticator.setAlwaysAcceptServerNodes(boolean) is set to false, returns empty SecurityCredentials to be used as credentials of local node.
cross(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the cross product of this vector and the other vector.
cross(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the cross product of this vector and the other vector.
cross(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the cross product of this vector and the other vector.
CrossOverJob - Class in org.apache.ignite.ml.genetic
Responsible for performing 'crossover' genetic operation for 2 X 'parent' chromosomes.
CrossOverJob(Long, Long, double) - Constructor for class org.apache.ignite.ml.genetic.CrossOverJob
 
CrossoverStrategy - Enum in org.apache.ignite.ml.util.genetic
Represents the crossover strategy depending of locus point amount.
CrossOverTask - Class in org.apache.ignite.ml.genetic
Responsible for assigning 2 X 'parent' chromosomes to produce 2 X 'child' chromosomes.
CrossOverTask(GAConfiguration) - Constructor for class org.apache.ignite.ml.genetic.CrossOverTask
 
CrossValidation<M extends IgniteModel<Vector,L>,L,K,V> - Class in org.apache.ignite.ml.selection.cv
Cross validation score calculator.
CrossValidation() - Constructor for class org.apache.ignite.ml.selection.cv.CrossValidation
 
CrossValidationResult - Class in org.apache.ignite.ml.selection.cv
Represents the cross validation procedure result, wraps score and values of hyper parameters associated with these values.
CrossValidationResult() - Constructor for class org.apache.ignite.ml.selection.cv.CrossValidationResult
 
ctx - Variable in class org.apache.ignite.marshaller.AbstractMarshaller
Context.
CUR_COORDINATOR_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
current() - Static method in class org.apache.ignite.thread.IgniteThread
 
currentBaselineTopology() - Method in interface org.apache.ignite.IgniteCluster
Gets current baseline topology.
currentCallContext() - Method in interface org.apache.ignite.services.ServiceContext
Gets context of the current service call.
currentThreadCanRequestBinaryMetadata() - Static method in class org.apache.ignite.thread.IgniteThread
 
currentTopologySnapshot() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets current topology snapshot.
currentTopologyVersion() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets current topology version number.
curry(BiFunction<A, B, C>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Curry bi-function.
curry(IgniteBiFunction<A, B, C>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Transform bi-function of the form (a, b) -> c into a function of form a -> (b -> c).
curry(IgniteTriFunction<A, B, C, D>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Transform tri-function of the form (a, b, c) -> d into a function of form a -> (b -> (c -> d)).
cursor(byte) - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Gets cursor for the given data center ID.
cursor(byte) - Method in interface org.gridgain.grid.dr.store.DrSenderStore
Gets cursor for the given data center ID.
cursor0(byte) - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Create new cursor for specified data center.
cursor0(byte) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Create new cursor for specified data center.
cursor0(byte) - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Create new cursor for specified data center.
CustomizableThreadFactory - Class in org.apache.ignite.tensorflow.core.util
Customizable thread factory that allows to specify thread name and daemon flag for the processes created by this factory.
CustomizableThreadFactory(String, boolean) - Constructor for class org.apache.ignite.tensorflow.core.util.CustomizableThreadFactory
Constructs a new instance of customizable thread factory.
CustomMLLogger - Class in org.apache.ignite.ml.environment.logging
MLLogger implementation based on IgniteLogger.

D

data() - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
Gets underlying data, if StorageOpsMetrics.isArrayBased() returns false this method return copy of data.
data() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
Gets underlying data, if StorageOpsMetrics.isArrayBased() returns false this method return copy of data.
data() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
Gets underlying data, if StorageOpsMetrics.isArrayBased() returns false this method return copy of data.
data() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
Gets underlying data, if StorageOpsMetrics.isArrayBased() returns false this method return copy of data.
data() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
Gets underlying array if StorageOpsMetrics.isArrayBased() returns true and all values in vector are Numbers.
data() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
Gets underlying array if StorageOpsMetrics.isArrayBased() returns true and all values in vector are Numbers.
data() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
Gets underlying array if StorageOpsMetrics.isArrayBased() returns true and all values in vector are Numbers.
data() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
Gets underlying array if StorageOpsMetrics.isArrayBased() returns true and all values in vector are Numbers.
data() - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
Gets underlying array if StorageOpsMetrics.isArrayBased() returns true and all values in vector are Numbers.
data - Variable in class org.apache.ignite.ml.structures.Dataset
Data to keep.
data() - Method in class org.apache.ignite.ml.structures.Dataset
 
data() - Method in interface org.gridgain.grid.dr.store.DrSenderStoreEntry
 
dataCenterId() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets ID of initiator data center.
dataCenterId() - Method in interface org.gridgain.grid.cache.dr.CacheDrEntry
Gets ID of initiator data center.
dataCenterId() - Method in interface org.gridgain.grid.dr.DrSenderConnection
Get ID of remote data center.
dataCenterIds() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets target data center IDs.
DataPageEvictionMode - Enum in org.apache.ignite.configuration
Defines memory page eviction algorithm.
DataRegionConfiguration - Class in org.apache.ignite.configuration
This class allows defining custom data regions' configurations with various parameters for Apache Ignite page memory (see DataStorageConfiguration.
DataRegionConfiguration() - Constructor for class org.apache.ignite.configuration.DataRegionConfiguration
 
DataRegionMetrics - Interface in org.apache.ignite
Deprecated.
Use GridMetricManager instead.
dataRegionMetrics() - Method in interface org.apache.ignite.Ignite
Returns a collection of DataRegionMetrics that reflects page memory usage on this Apache Ignite node instance.
dataRegionMetrics(String) - Method in interface org.apache.ignite.Ignite
Returns the latest DataRegionMetrics snapshot for the memory region of the given name.
dataRegionMetrics() - Method in class org.apache.ignite.IgniteSpringBean
Returns a collection of DataRegionMetrics that reflects page memory usage on this Apache Ignite node instance.
dataRegionMetrics(String) - Method in class org.apache.ignite.IgniteSpringBean
Returns the latest DataRegionMetrics snapshot for the memory region of the given name.
DataRegionMetricsAdapter - Class in org.apache.ignite
Deprecated.
Use GridMetricManager instead.
DataRegionMetricsMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use GridMetricManager instead.
DataRegionMetricsProvider - Interface in org.apache.ignite
This interface provides calculated metrics for data region.
dataRegionName() - Method in class org.apache.ignite.events.PageReplacementStartEvent
Gets data region name for which page replacement started.
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
Dataset<C extends Serializable,D extends AutoCloseable> - Interface in org.apache.ignite.ml.dataset
A dataset providing an API that allows to perform generic computations on a distributed data represented as a set of partitions distributed across a cluster or placed locally.
Dataset<Row extends DatasetRow> - Class in org.apache.ignite.ml.structures
Class for set of vectors.
Dataset() - Constructor for class org.apache.ignite.ml.structures.Dataset
Default constructor (required by Externalizable).
Dataset(Row[], FeatureMetadata[]) - Constructor for class org.apache.ignite.ml.structures.Dataset
Creates new Dataset by given data.
Dataset(Row[], String[], int) - Constructor for class org.apache.ignite.ml.structures.Dataset
Creates new Dataset by given data.
Dataset(Row[], int) - Constructor for class org.apache.ignite.ml.structures.Dataset
Creates new Dataset by given data.
Dataset(Row[]) - Constructor for class org.apache.ignite.ml.structures.Dataset
Creates new Dataset by given data.
Dataset(int, int, String[], boolean) - Constructor for class org.apache.ignite.ml.structures.Dataset
Creates new Dataset and initialized with empty data structure.
DatasetAffinityFunctionWrapper - Class in org.apache.ignite.ml.dataset.impl.cache.util
Affinity function wrapper that uses key as a partition index and delegates all other functions to specified delegate.
DatasetAffinityFunctionWrapper(AffinityFunction) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.util.DatasetAffinityFunctionWrapper
Constructs a new instance of affinity function wrapper.
DatasetBuilder<K,V> - Interface in org.apache.ignite.ml.dataset
A builder constructing instances of a Dataset.
DatasetFactory - Class in org.apache.ignite.ml.dataset
Factory providing a client facing API that allows to construct basic and the most frequently used types of dataset.
DatasetFactory() - Constructor for class org.apache.ignite.ml.dataset.DatasetFactory
 
datasetMapping - Variable in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Dataset mapping.
DatasetMapping<L1,L2> - Interface in org.apache.ignite.ml.composition
This class represents dataset mapping.
DatasetRow<V extends Vector> - Class in org.apache.ignite.ml.structures
Class to keep one observation in dataset.
DatasetRow() - Constructor for class org.apache.ignite.ml.structures.DatasetRow
Default constructor (required by Externalizable).
DatasetRow(V) - Constructor for class org.apache.ignite.ml.structures.DatasetRow
 
DatasetTrainer<M extends IgniteModel,L> - Class in org.apache.ignite.ml.trainers
Interface for trainers.
DatasetTrainer() - Constructor for class org.apache.ignite.ml.trainers.DatasetTrainer
 
DatasetTrainer.EmptyDatasetException - Exception in org.apache.ignite.ml.trainers
EmptyDataset exception.
DatasetWrapper<C extends Serializable,D extends AutoCloseable> - Class in org.apache.ignite.ml.dataset.primitive
A dataset wrapper that allows to introduce new functionality based on common compute methods.
DatasetWrapper(Dataset<C, D>) - Constructor for class org.apache.ignite.ml.dataset.primitive.DatasetWrapper
Constructs a new instance of dataset wrapper that delegates compute actions to the actual delegate.
DataSource - Class in org.apache.ignite.cache.store.cassandra.datasource
Data source abstraction to specify configuration of the Cassandra session to be used.
DataSource() - Constructor for class org.apache.ignite.cache.store.cassandra.datasource.DataSource
 
dataSrc - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Data source.
DataStorageConfiguration - Class in org.apache.ignite.configuration
A durable memory configuration for an Apache Ignite node.
DataStorageConfiguration() - Constructor for class org.apache.ignite.configuration.DataStorageConfiguration
Creates valid durable memory configuration with all default values.
DataStorageMetrics - Interface in org.apache.ignite
Deprecated.
Use GridMetricManager instead.
dataStorageMetrics() - Method in interface org.apache.ignite.Ignite
 
dataStorageMetrics() - Method in class org.apache.ignite.IgniteSpringBean
DataStorageMetricsAdapter - Class in org.apache.ignite
Deprecated.
Use GridMetricManager instead.
DataStorageMetricsMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use GridMetricManager instead.
DataStorageMXBean - Interface in org.apache.ignite.mxbean
An MX bean allowing to monitor and tune persistence.
dataStreamer(String) - Method in interface org.apache.ignite.Ignite
Gets a new instance of data streamer associated with given cache name.
dataStreamer(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets a new instance of data streamer associated with given cache name.
dataStreamer(String, byte) - Method in interface org.gridgain.grid.GridGain
Gets data streamer with specified dataCenterId.
DataStreamGenerator - Interface in org.apache.ignite.ml.util.generators
Provides general interface for generation of pseudorandom vectors according to shape defined by logic of specific data stream generator.
dataTtl() - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Returns partition data time-to-live in seconds (-1 for an infinite lifetime).
DB2Dialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the IBM DB2 database.
DB2Dialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
 
dcId() - Method in class org.gridgain.grid.events.DrRemoteDcNodeEvent
Returns id of the remote data center.
dcId() - Method in class org.gridgain.grid.events.DrRemoteDcReplicationEvent
Returns id of the remote data center.
dcId() - Method in class org.gridgain.grid.events.DrStoreEvent
Returns id of the remote data center.
dcIds() - Method in class org.gridgain.grid.events.DrCacheFstEvent
Returns ids of data centers that should store the replica of the cache.
DDLGenerator - Class in org.apache.ignite.cache.store.cassandra.utils
Generates Cassandra DDL statements from persistence descriptor xml file.
DDLGenerator() - Constructor for class org.apache.ignite.cache.store.cassandra.utils.DDLGenerator
 
debug(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out debug message.
debug(String, String) - Method in interface org.apache.ignite.IgniteLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.EchoingLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out debug message.
debug(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out debug message.
debug(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out debug message.
DebugCrossValidation<M extends IgniteModel<Vector,L>,L,K,V> - Class in org.apache.ignite.ml.selection.cv
Cross validation score calculator.
DebugCrossValidation() - Constructor for class org.apache.ignite.ml.selection.cv.DebugCrossValidation
 
DecisionTree<T extends ImpurityMeasure<T>> - Class in org.apache.ignite.ml.tree
Distributed decision tree trainer that allows to fit trees using row-partitioned dataset.
DecisionTreeClassificationTrainer - Class in org.apache.ignite.ml.tree
Decision tree classifier based on distributed decision tree trainer that allows to fit trees using row-partitioned dataset.
DecisionTreeClassificationTrainer(int, double) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Constructs a new decision tree classifier with default impurity function compressor.
DecisionTreeClassificationTrainer() - Constructor for class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Constructs a new decision tree classifier with default impurity function compressor and default maxDeep = 5 and minImpurityDecrease = 0.
DecisionTreeClassificationTrainer(int, double, StepFunctionCompressor<GiniImpurityMeasure>) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Constructs a new instance of decision tree classifier.
DecisionTreeConditionalNode - Class in org.apache.ignite.ml.tree
Decision tree conditional (non-leaf) node.
DecisionTreeConditionalNode(int, double, DecisionTreeNode, DecisionTreeNode, DecisionTreeNode) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
Constructs a new instance of decision tree conditional node.
DecisionTreeData - Class in org.apache.ignite.ml.tree.data
A partition data of the containing matrix of features and vector of labels stored in heap with index on features.
DecisionTreeData(double[][], double[], boolean) - Constructor for class org.apache.ignite.ml.tree.data.DecisionTreeData
Constructs a new instance of decision tree data.
DecisionTreeDataBuilder<K,V,C extends Serializable> - Class in org.apache.ignite.ml.tree.data
A partition data builder that makes DecisionTreeData.
DecisionTreeDataBuilder(Preprocessor<K, V>, boolean) - Constructor for class org.apache.ignite.ml.tree.data.DecisionTreeDataBuilder
Constructs a new instance of decision tree data builder.
DecisionTreeLeafBuilder - Interface in org.apache.ignite.ml.tree.leaf
Base interface for decision tree leaf builders.
DecisionTreeLeafNode - Class in org.apache.ignite.ml.tree
Decision tree leaf node which contains value.
DecisionTreeLeafNode(double) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeLeafNode
Constructs a new decision tree leaf node.
DecisionTreeNode - Interface in org.apache.ignite.ml.tree
Base interface for decision tree nodes.
DecisionTreeRegressionTrainer - Class in org.apache.ignite.ml.tree
Decision tree regressor based on distributed decision tree trainer that allows to fit trees using row-partitioned dataset.
DecisionTreeRegressionTrainer(int, double) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeRegressionTrainer
Constructs a new decision tree regressor with default impurity function compressor.
DecisionTreeRegressionTrainer(int, double, StepFunctionCompressor<MSEImpurityMeasure>) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeRegressionTrainer
Constructs a new decision tree regressor.
decompress(byte[]) - Method in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
Decompresses an array of previously compressed cache data.
decrementAndGet() - Method in interface org.apache.ignite.client.ClientAtomicLong
Decrements and gets current value of atomic long.
decrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Decrements and gets current value of atomic long.
decrypt(byte[]) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionService
Decrypt the input data.
decrypt(byte[]) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
Decrypt the input data.
decrypt(byte[]) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.EncryptionService
Decrypt the input data.
decrypt(byte[]) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionService
Decrypt the input data.
decrypt(byte[], Serializable) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
decrypt(byte[], Serializable) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
decrypt(byte[], Serializable) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
decryptKey(byte[]) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptKey(byte[]) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptKey(byte[]) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
DEFAULT - Static variable in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Default instance.
DEFAULT() - Constructor for class org.apache.ignite.resources.SpringResource.DEFAULT
 
DEFAULT_CACHE_API_READ_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default cache API read configuration.
DEFAULT_CACHE_API_WRITE_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default cache API write configuration.
DEFAULT_CLUSTER_NAME - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_CLUSTER_NAME - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_COMMUNICATION_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default communication configuration.
DEFAULT_COMPRESSION - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default value for snapshot's compression option.
DEFAULT_COMPRESSION_LEVEL - Static variable in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Default compression level, as per Zstandard library.
DEFAULT_COMPRESSION_LEVEL - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot operation creation compression level.
DEFAULT_COMPRESSION_LEVEL_PARAMETER - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot operation creation compression level. -1 Means turned off by default.
DEFAULT_CONFIG - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
DEFAULT_CPU_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_DICTIONARY_SIZE - Static variable in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Default dictionary size, bytes.
DEFAULT_DISCOVERY_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default discovery configuration.
DEFAULT_EXCHANGE_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default exchange configuration.
DEFAULT_EXCHANGELESS_SNAPSHOT - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default mode for exchange triggering on snapshot creation.
DEFAULT_HTTP_SERVER_PORT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_IGNITE_CONFIG - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
DEFAULT_IGNITE_LOCAL_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_RELEASES_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_VERSION - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_IGNITE_WORK_DIR - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_IGNITE_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_IGNITE_YARN_QUEUE - Static variable in class org.apache.ignite.yarn.ClusterProperties
Ignite Yarn default Queue
DEFAULT_KEY_SIZE - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Default encryption key size;
DEFAULT_MASTER_KEY_NAME - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Default key store entry name to store Encryption master key.
DEFAULT_MEM_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
DEFAULT_MESOS_MASTER_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_MINIMUM_MEM_OVERHEAD_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
The minimum memory overhead: overhead is by default 0.1* MEMORY_PER_NODE, with a minimum of DEFAULT_MINIMUM_MEM_OVERHEAD_PER_NODE.
DEFAULT_NUMBER_OF_RETRIES - Static variable in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Default number of retries for the case when one of partitions not found on the node where loading is performed.
DEFAULT_PORT - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Default port range.
DEFAULT_PORT - Static variable in class org.apache.ignite.yarn.ApplicationMaster
Default port range.
DEFAULT_RESOURCE_MIN_CPU - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_RESOURCE_MIN_MEM - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
DEFAULT_RESTORE_OPERATION_PARALLELISM - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot restore operation parallelism level.
DEFAULT_SAMPLES_BUFFER_SIZE - Static variable in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Default samples buffer size, bytes.
DEFAULT_SNAPSHOT_OPERATION_PARALLELISM - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot operation parallelism level.
DEFAULT_SNAPSHOT_PROGRESS_THROTTLING_TIME - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot progress throttling time.
DEFAULT_SQL_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default SQL tracing configuration.
DEFAULT_TRAINER_ENV - Static variable in interface org.apache.ignite.ml.environment.LearningEnvironment
Default environment
DEFAULT_TX_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default transaction tracing configuration.
DEFAULT_VALUE - Static variable in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Object for denoting default value of feature mapping.
DEFAULT_WRITE_THROTTLING_THRESHOLD - Static variable in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Default snapshot write throttling threshold is zero - throttling is turned off.
defaultAllowAll() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Flag indicating whether to allow or deny cache and task operations if they were not explicitly specified.
defaultAllowAll() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Flag indicating whether to allow or deny cache and task operations if they were not explicitly specified.
defaultAllowAll(boolean) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append default all flag.
defaultBuilder() - Static method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
defaultColumnName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns default name for Cassandra column (if it's not specified explicitly).
defaultColumnName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns default name for Cassandra column (if it's not specified explicitly).
defaultColumnName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Returns default name for Cassandra column (if it's not specified explicitly).
DefaultCommunicationFailureResolver - Class in org.apache.ignite.configuration
Default Communication Failure Resolver.
DefaultCommunicationFailureResolver() - Constructor for class org.apache.ignite.configuration.DefaultCommunicationFailureResolver
 
DefaultLabelVectorizer(C...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.DefaultLabelVectorizer
Creates an instance of Vectorizer.
DefaultLearningEnvironmentBuilder - Class in org.apache.ignite.ml.environment
Builder for LearningEnvironment.
defaultLockTimeout() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
DefaultModelStorage - Class in org.apache.ignite.ml.inference.storage.model
Default implementation of ModelStorage that can use any ModelStorageProvider as a backend storage system.
DefaultModelStorage(ModelStorageProvider) - Constructor for class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Constructs a new instance of Ignite model storage.
DefaultParallelismStrategy - Class in org.apache.ignite.ml.environment.parallelism
All task should be processed by default thread pool.
DefaultParallelismStrategy() - Constructor for class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy
 
DefaultParallelismStrategy.FutureWrapper<T> - Class in org.apache.ignite.ml.environment.parallelism
Wrapper for future class.
defaultValue(Double) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer.Mapping
Default value for new feature values.
defaultValue() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
defaultValue() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
DefragmentationMXBean - Interface in org.apache.ignite.mxbean
JMX bean for defragmentation manager.
delayedRegister() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
delegate - Variable in class org.apache.ignite.ml.dataset.primitive.DatasetWrapper
Delegate that performs compute actions.
delegate() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
delegate() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
 
delegate() - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
 
delegate() - Method in class org.apache.ignite.springdata.proxy.IgniteProxyImpl
 
DelegatingNamedVector - Class in org.apache.ignite.ml.math.primitives.vector.impl
Delegating named vector that delegates all operations to underlying vector and adds implementation of NamedVector functionality using embedded map that maps string index on real integer index.
DelegatingNamedVector() - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
Constructs a new instance of delegating named vector.
DelegatingNamedVector(Vector, Map<String, Integer>) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
Constructs a new instance of delegating named vector.
DelegatingVector - Class in org.apache.ignite.ml.math.primitives.vector.impl
Convenient class that can be used to add decorations to an existing vector.
DelegatingVector() - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
 
DelegatingVector(Vector) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
 
delete(Object) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
delete(Object) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
delete(Object) - Method in class org.apache.ignite.cache.store.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(V) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
delete(Object) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
delete() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Deletes file.
DELETE_ALL_QUERY_STRING - Static variable in class org.apache.ignite.springdata22.repository.query.QueryUtils
The constant DELETE_ALL_QUERY_STRING.
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
deleteAll(Iterable<? extends V>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
deleteAll() - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
deleteAll(Collection<?>) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
deleteAllById(Iterable<? extends K>) - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Deletes all the entities for the provided ids.
deleteAllById(Iterable<? extends K>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Deletes all the entities for the provided ids.
deleteById(K) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
deleteDirectory(Path) - Static method in class org.apache.ignite.ml.inference.util.DirectorySerializer
Removes the specified directory.
DeleteFileVisitor - Class in org.gridgain.grid.persistentstore.snapshot.file
File visitor which recursively removes files in directory.
DeleteFileVisitor(SnapshotOperationContext, IgniteLogger) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.DeleteFileVisitor
 
deleteIfEmpty() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Deletes file/folder if empty.
DeleteMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Mutation which deletes object from Cassandra.
DeleteMutation(Object, String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Creates instance of delete mutation operation.
deleteOldFiles() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Delete old files.
deleteSnapshot(long, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Deletes snapshot from the local directory.
deleteSnapshot(long, SnapshotUpdateOperationParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
deleteSnapshot(long, SnapshotUpdateOperationParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Deletes snapshot from the local directory.
deleteSnapshot(long, SnapshotOperationContext) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
deleteSources() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
deleteSources(boolean) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets delete sources after operation flag.
deleteSources() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
deleteSources(boolean) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets delete sources after operation.
DELIM - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Delimiter char.
DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Delimiter to use between address and port tokens in file names.
DELIM - Static variable in class org.apache.ignite.yarn.ApplicationMaster
Delimiter char.
deltas - Variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Previous iteration parameters deltas.
DenseMatrix - Class in org.apache.ignite.ml.math.primitives.matrix.impl
Basic implementation for matrix.
DenseMatrix() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
 
DenseMatrix(int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
 
DenseMatrix(int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
 
DenseMatrix(double[][], int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
 
DenseMatrix(double[][]) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
 
DenseMatrix(double[], int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
 
DenseMatrix(double[], int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
Build new matrix from flat raw array.
DenseMatrixStorage - Class in org.apache.ignite.ml.math.primitives.matrix.storage
Array based MatrixStorage implementation.
DenseMatrixStorage() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseMatrixStorage(int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseMatrixStorage(int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseMatrixStorage(double[][], int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseMatrixStorage(double[][]) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseMatrixStorage(double[], int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseMatrixStorage(double[], int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
 
DenseVector - Class in org.apache.ignite.ml.math.primitives.vector.impl
Basic implementation for vector.
DenseVector(Serializable[]) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
 
DenseVector(Map<String, Object>) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
 
DenseVector() - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
 
DenseVector(int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
 
DenseVector(double[], boolean) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
 
DenseVector(double[]) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
 
DenseVectorStorage - Class in org.apache.ignite.ml.math.primitives.vector.storage
Array based VectorStorage implementation.
DenseVectorStorage() - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
IMPL NOTE required by Externalizable.
DenseVectorStorage(int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
 
DenseVectorStorage(double[]) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
 
DenseVectorStorage(Serializable[]) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
 
density(double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Calculates the density of the matrix based on supplied criteria.
density(double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Calculates the density of the matrix based on supplied criteria.
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).
DeployableObject - Interface in org.apache.ignite.ml.environment.deploy
Represents an final objects from Ignite ML library like models or preprocessors having dependencies that can be custom objects from client side.
deployAll(Collection<ServiceConfiguration>) - Method in interface org.apache.ignite.IgniteServices
Deploys multiple services described by provided configurations.
deployAllAsync(Collection<ServiceConfiguration>) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple services described by provided configurations.
deployAsync(ServiceConfiguration) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple instances of the service on the grid according to provided configuration.
deployClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
Gets top level user class being deployed.
deployClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
Gets top level user class being deployed.
deployClass(Class<?>) - Method in interface org.apache.ignite.IgniteDataStreamer
Optional deploy class for peer deployment.
deployClusterSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
Deploys a cluster-wide singleton service.
deployClusterSingletonAsync(String, Service) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys a cluster-wide singleton service.
DeployingContext - Interface in org.apache.ignite.ml.environment.deploy
Class represents user's class loading environment for specific remote job.
deployingContext() - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Returns deploy context instance.
DeployingContextImpl - Class in org.apache.ignite.ml.environment.deploy
Default implementation of DeployingContext class.
DeployingContextImpl() - Constructor for class org.apache.ignite.ml.environment.deploy.DeployingContextImpl
 
deployKeyAffinitySingleton(String, Service, String, Object) - Method in interface org.apache.ignite.IgniteServices
Deploys one instance of this service on the primary node for a given affinity key.
deployKeyAffinitySingletonAsync(String, Service, String, Object) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys one instance of this service on the primary node for a given affinity key.
DEPLOYMENT_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
DeploymentEvent - Class in org.apache.ignite.events
Grid deployment event.
DeploymentEvent() - Constructor for class org.apache.ignite.events.DeploymentEvent
No-arg constructor.
DeploymentEvent(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.DeploymentEvent
Creates deployment event with given parameters.
DeploymentListener - Interface in org.apache.ignite.spi.deployment
Listener for deployment events.
DeploymentMode - Enum in org.apache.ignite.configuration
Grid deployment mode.
DeploymentResource - Interface in org.apache.ignite.spi.deployment
Generic abstraction over deployed resource containing resource's name, class and corresponding class loader.
DeploymentResourceAdapter - Class in org.apache.ignite.spi.deployment
Simple adapter for DeploymentResource interface.
DeploymentResourceAdapter(String, Class<?>, ClassLoader) - Constructor for class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Creates resource.
DeploymentSpi - Interface in org.apache.ignite.spi.deployment
Grid deployment SPI is in charge of deploying tasks and classes from different sources.
deployMultiple(String, Service, int, int) - Method in interface org.apache.ignite.IgniteServices
Deploys multiple instances of the service on the grid.
deployMultipleAsync(String, Service, int, int) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple instances of the service on the grid.
deployNodeSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
Deploys a per-node singleton service.
deployNodeSingletonAsync(String, Service) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys a per-node singleton service.
deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in interface org.apache.ignite.client.ClientCache
Deregisters a listener, using the CacheEntryListenerConfiguration that was used to register it.
deregisterPort(int, IgnitePortProtocol, Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Deregisters closed port.
deregisterPort(int, IgnitePortProtocol) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Deregisters closed port.
deregisterPorts(Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Deregisters all closed ports.
deregisterPorts() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Deregisters all closed ports.
description() - Method in interface org.apache.ignite.maintenance.MaintenanceAction
Optional user-readable description of maintenance action.
description() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
description() - Method in interface org.apache.ignite.spi.metric.Metric
 
description() - Method in class org.apache.ignite.spi.systemview.view.SqlViewView
View description.
description() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
description() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
DescriptorFactory - Class in org.gridgain.grid.persistentstore.snapshot.file.remote.wal
Factory for SnapshotPathDescriptors.
DescriptorFactory(IgniteLogger) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.DescriptorFactory
 
deserialize() - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
deserialize(ClassLoader) - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
deserialize(ByteBuffer) - Method in class org.apache.ignite.cache.store.cassandra.serializer.JavaSerializer
Deserializes object from byte buffer.
deserialize(ByteBuffer) - Method in class org.apache.ignite.cache.store.cassandra.serializer.KryoSerializer
Deserializes object from byte buffer.
deserialize(ByteBuffer) - Method in interface org.apache.ignite.cache.store.cassandra.serializer.Serializer
Deserializes object from byte buffer.
deserialize(Path, byte[]) - Static method in class org.apache.ignite.ml.inference.util.DirectorySerializer
Deserializes directory content.
deserialize(byte[]) - Static method in class org.apache.ignite.ml.util.Utils
Deserialized object represented as a byte array.
destinationPath() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
destinationPath(SnapshotPath) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets destination path.
destinationPath() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
destinationPath(SnapshotPath) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets destination path.
destroy() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
destroy() - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
destroy() - Method in class org.apache.ignite.cache.websession.WebSessionFilter
destroy() - Method in interface org.apache.ignite.IgniteCache
Completely deletes the cache with all its data from the system on all cluster nodes.
destroy() - Method in class org.apache.ignite.IgniteSpringBean
destroy() - Method in interface org.apache.ignite.ml.math.Destroyable
Destroys object if managed outside of JVM.
destroy() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Destroys object if managed outside of JVM.
destroy() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Destroys object if managed outside of JVM.
destroy() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Destroys object if managed outside of JVM.
destroy() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Destroys object if managed outside of JVM.
destroy() - Method in class org.apache.ignite.startup.servlet.ServletStartup
destroy() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Destroys TensorFlow cluster manager and related caches.
destroy() - Method in class org.apache.ignite.tensorflow.cluster.util.ClusterPortManager
Destroys port manager and related caches.
destroy() - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowClusterResolver
Destroys TensorFlow cluster resolver.
Destroyable - Interface in org.apache.ignite.ml.math
Support for destroying objects that are managed outside of JVM.
destroyCache(String) - Method in class org.apache.ignite.cache.CacheManager
destroyCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Destroys the cache with the given name.
destroyCache(String) - Method in interface org.apache.ignite.Ignite
Destroys a cache with the given name and cleans data that was written to the cache.
destroyCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Destroys a cache with the given name and cleans data that was written to the cache.
destroyCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Destroys the cache with the given name.
destroyCaches(Collection<String>) - Method in interface org.apache.ignite.Ignite
Destroys caches with the given names and cleans data that was written to the caches.
destroyCaches(Collection<String>) - Method in class org.apache.ignite.IgniteSpringBean
Destroys caches with the given names and cleans data that was written to the caches.
destroySession(String) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
detectPojoFields(NodeList) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Extracts POJO fields from a list of corresponding XML field nodes.
detectStarvation() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
determinant() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Returns matrix determinant using Laplace theorem.
determinant() - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Return the determinant of the matrix.
determinant() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Returns matrix determinant using Laplace theorem.
DEV_ONLY - Static variable in interface org.apache.ignite.IgniteLogger
Marker for log messages that are useful in development environments, but not in production.
DFLT_ACCESS_TYPE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
DFLT_ACK_SND_THRESHOLD - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default received messages threshold (for the number of messages) for sending ack.
DFLT_ACK_SND_THRESHOLD_BYTES - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default received messages threshold (in bytes) for sending ack.
DFLT_ACK_SND_THRESHOLD_MILLIS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default received messages timeout (in millis) for sending ack.
DFLT_ACK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default timeout for receiving message acknowledgement in milliseconds (value is 5000ms).
DFLT_ACK_TIMEOUT_CLIENT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default timeout for receiving message acknowledgement in milliseconds (value is 5000ms).
DFLT_ACTIVE_JOBS_THRESHOLD - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default number of parallel jobs allowed (value is 95 which is slightly less same as default value of threads in the execution thread pool to allow some extra threads for system processing).
DFLT_ACTIVE_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
DFLT_ADDR_REQ_ATTEMPTS - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default number of attempts to send multicast address request (value is 2).
DFLT_ALL_SEG_RESOLVERS_PASS_REQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for all segmentation resolvers pass required.
DFLT_ATOMIC_SEQUENCE_RESERVE_SIZE - Static variable in class org.apache.ignite.client.ClientAtomicConfiguration
Default atomic sequence reservation size.
DFLT_ATOMIC_SEQUENCE_RESERVE_SIZE - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
Default atomic sequence reservation size.
DFLT_AUTO_ACTIVATION - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
DFLT_AUTO_UNSUBSCRIBE - Static variable in class org.apache.ignite.cache.query.AbstractContinuousQuery
Default value for automatic unsubscription flag.
DFLT_AWAIT_ACK - Static variable in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Default await acknowledge flag.
DFLT_BACKUP_SYNC_FREQUENCY - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default backup partition's DR state synchronization frequency.
DFLT_BACKUPS - Static variable in class org.apache.ignite.client.ClientAtomicConfiguration
Default number of backups.
DFLT_BACKUPS - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
 
DFLT_BACKUPS - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default number of backups.
DFLT_BATCH_QUEUE_SIZE - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Default batch queue size (max batches count to limit memory usage).
DFLT_BATCH_SIZE - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Default batch size (number of records read with CacheLoadOnlyStoreAdapter.inputIterator(Object...)
DFLT_BATCH_SIZE - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Default batch size for put and remove operations.
DFLT_BATCH_SND_FREQUENCY - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default data center replication sender cache batch send frequency.
DFLT_BATCH_SND_SIZE - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default data center replication sender cache batch send size.
DFLT_BATCH_SND_SIZE_BYTES - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default DR batch size in bytes.
DFLT_BINARY_METADATA_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default path (relative to working directory) of binary metadata folder
DFLT_BUCKET_NAME_SUFFIX - Static variable in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Suffix to use in bucket name generation.
DFLT_BUFFER_SIZE - Static variable in class org.apache.ignite.marshaller.AbstractMarshaller
Default initial buffer size for the GridByteArrayOutputStream.
DFLT_BUILD_IDX_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of index create/rebuild thread pool.
DFLT_CACHE_ATOMICITY_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default atomicity mode.
DFLT_CACHE_MODE - Static variable in class org.apache.ignite.client.ClientAtomicConfiguration
Cache mode.
DFLT_CACHE_MODE - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
 
DFLT_CACHE_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default caching mode.
DFLT_CACHE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Default cache name (value is checkpoints).
DFLT_CACHE_SANITY_CHECK_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for cache sanity check enabled flag.
DFLT_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default cache size to use with eviction policy.
DFLT_CHECKPOINT_FREQ - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_CHECKPOINT_FREQ - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default checkpoint creation frequency.
DFLT_CHECKPOINT_TABLE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint table name (value is CHECKPOINTS).
DFLT_CHECKPOINT_THREADS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default number of checkpoint threads.
DFLT_CHECKPOINT_WRITE_ORDER - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default checkpoint write order.
DFLT_CHECKPOINT_WRITE_ORDER - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default checkpoint write order.
DFLT_CHECKPOINTING_FREQ - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
DFLT_CHECKPOINTING_THREADS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default number of checkpointing threads.
DFLT_CHECKSUM_ENABLED - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default checksum enabled flag.
DFLT_CLIENT_FAILURE_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default failure detection timeout for client nodes in millis.
DFLT_COMMIT_MODE - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default write mode.
DFLT_COMPACT_BUFFER_SIZE - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default compact buffer size.
DFLT_COMPACT_FOOTER - Static variable in class org.apache.ignite.configuration.BinaryConfiguration
Default compact footer flag setting.
DFLT_CONCURRENT_LOAD_ALL_THRESHOLD - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default threshold for concurrent loading of keys from CacheStore.
DFLT_CONFIG_PATH - Static variable in class org.apache.ignite.logger.java.JavaLogger
 
DFLT_CONFLICT_RSLVR_MODE - Static variable in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Default data center replication receiver cache conflict resolver mode.
DFLT_CONN_PER_NODE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default connections per node.
DFLT_CONN_POOL_SIZE - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default hibernate.connection.pool_size property value (value is 64).
DFLT_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default connection timeout (value is 5000ms).
DFLT_CONN_TIMEOUT - Static variable in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Default value for local port.
DFLT_CONN_URL - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default connection URL (value is jdbc:gg-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:gg-h2:mem:jdbcCacheStore;DB_CLOSE_DELAY=-1).
DFLT_CONNECTION_RECOVERY_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default connection recovery timeout in ms.
DFLT_COPY_ON_READ - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'copyOnRead' flag.
DFLT_CREATE_TBL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default create table query (value is create table if not exists ENTRIES (akey binary primary key, val binary)).
DFLT_DATA_REG_DEFAULT_NAME - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
This name is assigned to default Dataregion if no user-defined default MemPlc is specified
DFLT_DATA_REGION_INITIAL_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default data region start size (256 MB).
DFLT_DATA_REGION_MAX_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default data region's size is 20% of physical memory available on current machine.
DFLT_DATA_STREAMER_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of data streamer thread pool.
DFLT_DEADLOCK_TIMEOUT - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default timeout before starting deadlock detection.
DFLT_DEFRAGMENTATION_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default defragmentation thread pool size.
DFLT_DEL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default delete entry query (value is delete from ENTRIES where akey=?
DFLT_DEPLOY_DIR - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default deployment directory where SPI will pick up packages.
DFLT_DEPLOYMENT_MODE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default deployment mode (value is DeploymentMode.SHARED).
DFLT_DIR_PATH - Static variable in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Default checkpoint directory.
DFLT_DIRECT_BUF - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default value of direct buffer allocation.
DFLT_DISCO_FAILED_CLIENT_RECONNECT_DELAY - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_DISCOVERY_METRICS_QNT_WARN - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_DISCOVERY_STARTUP_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default discovery startup delay in milliseconds (value is 60,000ms).
DFLT_DISK_PAGE_COMPRESSION - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default disk page compression algorithm.
DFLT_DR_IST_POOL_THREAD_CNT - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default size of incremental DR (Data Replication) thread pool.
DFLT_DR_MGMT_THREAD_CNT - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default size of DR (Data Replication) management thread pool.
DFLT_DR_STATE_TRANSFER_THREAD_CNT - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default size of DR (Data Replication) thread pool.
DFLT_DR_STREAMER_THREAD_CNT - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default size of DR (Data Streamer) thread pool.
DFLT_DR_THREAD_CNT - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default size of DR (Data Replication) thread pool.
DFLT_EAGER_TTL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for eager ttl flag.
DFLT_EVENTS_DISABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for events disabled flag.
DFLT_EXPIRE_AGE_MS - Static variable in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Default event time to live value in milliseconds (value is Long.MAX_VALUE).
DFLT_EXPIRE_COUNT - Static variable in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Default expire count (value is 10000).
DFLT_EXPIRE_DATE_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default expiration date field name (value is EXPIRE_DATE).
DFLT_EXPIRE_DATE_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default expiration date field type (value is DATETIME).
DFLT_FAILURE_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default failure detection timeout in millis.
DFLT_FILTER_REACHABLE_ADDRESSES - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default value for FILTER_REACHABLE_ADDRESSES socket option (value is false).
DFLT_FLUSH_FREQ - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default flush frequency DR data loader.
DFLT_FST_BATCH_SND_SIZE_BYTES - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
Default full state transfer batch size in bytes.
DFLT_FST_BUFFER_SIZE - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default full state transfer buffer size.
DFLT_FSYNC_DELAY - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default value for fsync delay in milliseconds.
DFLT_GLOBAL_STORE_DIR_NAME - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Deprecated.
DFLT_GRID_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default grid count to warm up.
DFLT_HANDSHAKE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default handshake timeout.
DFLT_HBM2DDL_AUTO - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default hibernate.hbm2ddl.auto property value (value is true).
DFLT_HEALTH_CHECK_FREQ - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default health check frequency.
DFLT_IDLE_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default idle connection timeout (value is 10min).
DFLT_IDLE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default idle timeout.
DFLT_IDLE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default REST idle timeout.
DFLT_IDLE_TIMEOUT - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default server socket idle timeout.
DFLT_INLINE_SIZE - Static variable in class org.apache.ignite.cache.QueryIndex
Default index inline size.
DFLT_INSERT_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default insert entry query (value is insert into ENTRIES (akey, val) values (?
DFLT_INVALIDATE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'invalidate' flag that indicates if this is invalidation-based cache.
DFLT_IP_ADDR - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default IP address to seek other nodes at.
DFLT_IP_FINDER_CLEAN_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default IP finder clean frequency in milliseconds (value is 60,000ms).
DFLT_ITERATION_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default iteration count per thread.
DFLT_JCACHE_DEFAULT_ISOLATED - Static variable in class org.apache.ignite.cache.CacheManager
 
DFLT_JOB_PRIORITY - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default start value for job priority (value is 0).
DFLT_JOB_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default job priority attribute key (value is grid.job.priority).
DFLT_JOIN_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default timeout for joining topology (value is 0).
DFLT_JOIN_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
DFLT_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default keep alive time for REST thread pool.
DFLT_KEEP_BINARY_FLAG - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Default keep binary flag.
DFLT_KEY_ALGORITHM - Static variable in class org.apache.ignite.ssl.SslContextFactory
Default key manager / trust manager algorithm.
DFLT_KEY_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint key field name (value is NAME).
DFLT_KEY_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint key field type (value is VARCHAR(256)).
DFLT_KEY_RANGE - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default key range.
DFLT_LATE_AFF_ASSIGNMENT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
DFLT_LAZY - Static variable in class org.apache.ignite.cache.query.SqlFieldsQuery
Lazy mode.
DFLT_LIC_FILE_NAME - Static variable in interface org.gridgain.grid.GridGain
Default License file name.
DFLT_LOAD_BALANCING_MODE - Static variable in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Default receiver hub load balancing policy.
DFLT_LOAD_PREV_VAL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for load previous value flag.
DFLT_LOAD_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default load entry query (value is select * from ENTRIES where akey=?
DFLT_LOC_PORT - Static variable in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Default value for local port.
DFLT_LOCAL_PORT - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default server port.
DFLT_LOCK_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default lock timeout.
DFLT_LOCK_WAIT_TIME - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Lock default wait time, 10 sec.
DFLT_LOCK_WAIT_TIME - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Lock default wait time, 10 sec.
DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default timeout after which long query warning will be printed.
DFLT_LOWER_CASE - Static variable in class org.apache.ignite.binary.BinaryBasicIdMapper
Default lower case flag setting.
DFLT_MAP_CAPACITY - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default map capacity.
DFLT_MAP_SEGMENTS - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default number of map segments.
DFLT_MARSHAL_LOCAL_JOBS - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default marshal local jobs flag.
DFLT_MARSHALLER_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default path (relative to working directory) of marshaller mappings folder
DFLT_MAX_ACK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Maximum ack timeout value for receiving message acknowledgement in milliseconds (value is 600,000ms).
DFLT_MAX_ACTIVE_COMPUTE_TASKS_PER_CONNECTION - Static variable in class org.apache.ignite.configuration.ThinClientConfiguration
Default limit of active compute tasks per connection.
DFLT_MAX_ACTIVE_TX_PER_CONNECTION - Static variable in class org.apache.ignite.configuration.ThinClientConfiguration
Default limit of active transactions count per connection.
DFLT_MAX_BATCHES - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default data center replication sender cache maximum amount of pending batches.
DFLT_MAX_CONCURRENT_ASYNC_OPS - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'maxConcurrentAsyncOps'.
DFLT_MAX_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default Maximum connection timeout (value is 600,000ms).
DFLT_MAX_ERRORS - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default maximum processing errors.
DFLT_MAX_FAILED_CONNECT_ATTEMPTS - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default maximum failed connect attempts.
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_FILE_SIZE - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default maximum amount of files which can be used to store data.
DFLT_MAX_FILES_CNT - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default maximum amount of files which can be used to store data.
DFLT_MAX_OPEN_CURSORS - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default max number of open cursors per connection.
DFLT_MAX_OPEN_CURSORS_PER_CONN - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default max number of open cursors per connection.
DFLT_MAX_OPEN_CURSORS_PER_CONN - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default max number of open cursors per connection.
DFLT_MAX_PARALLEL_OPS - Static variable in interface org.apache.ignite.IgniteDataStreamer
Deprecated.
Is not used anymore.
DFLT_MAX_PARAMS_CNT - Static variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Default max query parameters count.
DFLT_MAX_QUERY_ITERATOR_CNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default maximum number of query iterators that can be stored.
DFLT_MAX_QUEUE_SIZE - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default maximum amount of enqueued requests per remote receiver hub.
DFLT_MAX_RETRIES_ON_FAIL - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Default retry on fail flag value.
DFLT_MAX_SIZE - Static variable in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
 
DFLT_MAX_SPARSITY - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
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_MCAST_GROUP - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default multicast IP address (value is 228.1.2.4).
DFLT_MCAST_PORT - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default multicast port number (value is 47400).
DFLT_MEM_PLC_DEFAULT_NAME - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
This name is assigned to default DataRegion if no user-defined default MemPlc is specified
DFLT_MEMORY_POLICY_INITIAL_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Default memory policy start size (256 MB).
DFLT_MEMORY_POLICY_MAX_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Default memory policy's size is 20% of physical memory available on current machine.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default metrics enabled flag.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Default metrics enabled flag.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
DFLT_METRICS_EXPIRE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default metrics expire time.
DFLT_METRICS_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default metrics history size (value is 10000).
DFLT_METRICS_LOG_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default frequency of metrics log print out.
DFLT_METRICS_UPDATE_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default metrics update frequency.
DFLT_MGMT_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of management thread pool.
DFLT_MIN_COMPACT_SIZE - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default minimum compaction size.
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 for incoming connections.
DFLT_MSG_QUEUE_LIMIT - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default message queue limit per connection (for incoming and outgoing .
DFLT_MVCC_VACUUM_FREQUENCY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default time interval between MVCC vacuum runs in milliseconds.
DFLT_MVCC_VACUUM_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default number of MVCC vacuum threads..
DFLT_NEAR_START_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Initial default near cache size.
DFLT_NEED_CLIENT_AUTH - Static variable in class org.apache.ignite.ssl.SslContextFactory
Whether SSL needs client authentication by default.
DFLT_NETWORK_COMPRESSION - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default compression level for network messages (value is Deflater.BEST_SPEED.
DFLT_NETWORK_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default maximum timeout to wait for network responses in milliseconds (value is 5,000ms).
DFLT_NETWORK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default network timeout in milliseconds (value is 5000ms).
DFLT_NODE_IDS_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_NODE_WEIGHT - Static variable in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Default weight assigned to every node if explicit one is not provided (value is 10).
DFLT_NUMBER_OF_RETRIES - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default number of retries in case of errors (value is 2).
DFLT_P2P_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default flag for peer class loading.
DFLT_P2P_MISSED_RESOURCES_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default cache size for missed resources.
DFLT_P2P_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of peer class loading thread pool.
DFLT_PAGE_REPLACEMENT_MODE - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default page replacement mode.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.cache.query.AbstractContinuousQuery
Default page size.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.cache.query.Query
Default query page size.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default memory page size.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Default memory page size.
DFLT_PARALLEL_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Default number of parallel jobs allowed (set to number of cores times 2).
DFLT_PARALLEL_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default number of parallel jobs allowed (set to number of cores times 2).
DFLT_PARALLEL_LOAD_CACHE_MINIMUM_THRESHOLD - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Default batch size for put and remove operations.
DFLT_PARALLEL_LOAD_OPS - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default per node parallel operations for DR data loader.
DFLT_PARALLEL_OPS_MULTIPLIER - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default multiplier for data streamer pool size to get concurrent batches count for each remote node.
DFLT_PARENT_DIR_NAME - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default parent directory name for per-replica stores.
DFLT_PARTITION_COUNT - Static variable in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Default number of partitions.
DFLT_PARTITION_LOSS_POLICY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default partition loss policy.
DFLT_PATH - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Default path for discovering of local nodes (testing only).
DFLT_PER_NODE_BUF_SIZE - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default per node buffer buffer size for DR data loader.
DFLT_PER_NODE_BUFFER_SIZE - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default operations batch size to sent to remote node for loading.
DFLT_PER_THREAD_BUFFER_SIZE - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default batch size per thread to send to buffer on node.
DFLT_PESSIMISTIC_TX_LOG_LINGER - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default size of pessimistic transactions log.
DFLT_PITR_ENABLED - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot progress throttling time.
DFLT_PORT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.IgniteJdbcDriver
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default port which node sets listener to (value is 47100).
DFLT_PORT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default port to listen (value is 47500).
DFLT_PORT - Static variable in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
Default port.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default rest port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default local port range (value is 100).
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default local port range (value is 100).
DFLT_PREVENT_STARVATION_ENABLED - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default flag for preventing starvation of lower priority jobs.
DFLT_PRIORITY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default priority that will be assigned if job does not have a priority attribute set (value is 0).
DFLT_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default priority attribute key (value is grid.task.priority).
DFLT_PROG_NAME - Static variable in class org.apache.ignite.startup.cmdline.CommandLineStartup
 
DFLT_PROPS - Static variable in class org.apache.ignite.cache.CachingProvider
 
DFLT_PUBLIC_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
DFLT_QRY_DETAIL_METRICS_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default number of queries detail metrics to collect.
DFLT_QRY_TIMEOUT - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default query timeout.
DFLT_QUERY_PARALLELISM - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default query parallelism.
DFLT_QUERY_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of query thread pool.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default length of interval over which DataRegionMetrics.getAllocationRate() metric is calculated.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default length of interval over which rate-based metric is calculated.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Default length of interval over which MemoryMetrics.getAllocationRate() metric is calculated.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default length of interval over which rate-based metric is calculated.
DFLT_READ_BUF_SIZE - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default read buffer size.
DFLT_READ_BUFFER_SIZE - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default read buffer size.
DFLT_READ_FROM_BACKUP - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'readFromBackup' flag.
DFLT_READ_TIMEOUT - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default read timeout.
DFLT_REBALANCE_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default rebalance batch size in bytes (value is 512Kb).
DFLT_REBALANCE_BATCHES_PREFETCH_COUNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_BATCHES_PREFETCH_COUNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default rebalance batches prefetch count (value is 2).
DFLT_REBALANCE_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default rebalance mode for distributed cache.
DFLT_REBALANCE_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default limit of threads used for rebalance.
DFLT_REBALANCE_THROTTLE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_THROTTLE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Time to wait between rebalance messages in milliseconds to avoid overloading CPU (value is 0).
DFLT_REBALANCE_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default rebalance message timeout in milliseconds (value is 10000).
DFLT_RECONNECT_CNT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default reconnect attempts count (value is 10).
DFLT_RECONNECT_CNT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default reconnect attempts count (value is 10).
DFLT_RECONNECT_DELAY - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default delay between attempts to connect to the cluster in milliseconds (value is 2000).
DFLT_RECONNECT_ON_FAILURE_TIMEOUT - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Reconnect on error timeout.
DFLT_REENCRYPTION_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.EncryptionConfiguration
Default number of pages that is scanned during reencryption under checkpoint lock.
DFLT_REENCRYPTION_RATE_MBPS - Static variable in class org.apache.ignite.configuration.EncryptionConfiguration
Default re-encryption rate limit.
DFLT_RES_WAIT_TIME - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default time IP finder waits for reply to multicast address request (value is 500).
DFLT_REST_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default size of REST thread pool.
DFLT_REST_MAX_THREAD_CNT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default max size of REST thread pool.
DFLT_RETRIES_ON_FAIL_TIMEOUT - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Default retry on fail timeout flag value.
DFLT_ROLLING_UPGRADE_ENABLED - Static variable in class org.gridgain.grid.configuration.GridGainConfiguration
By default rolling upgrade functionality is disabled.
DFLT_ROOT_PATH - Static variable in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
DFLT_ROOT_PATH - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default root path for file storage.
DFLT_SEG_CHK_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default segment check frequency in discovery manager.
DFLT_SEG_PLC - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default segmentation policy.
DFLT_SEG_RESOLVE_ATTEMPTS - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value segmentation resolve attempts count.
DFLT_SELECTOR_CNT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default selector count.
DFLT_SELECTOR_CNT - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default quantity of NIO threads responsible for sender hub connections processing.
DFLT_SELECTORS_CNT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default count of selectors for TCP server equals to "Math.max(4, Runtime.getRuntime().availableProcessors() / 2)".
DFLT_SEND_RETRY_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default message send retries count.
DFLT_SEND_RETRY_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default interval between message send retries.
DFLT_SESSION_EXPIRATION_TIMEOUT - Static variable in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Default expiration timeout for Cassandra driver session.
DFLT_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default port which node sets listener for shared memory connections (value is 48100).
DFLT_SHOW_SQL - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default show SQL property value (value is true).
DFLT_SHUTDOWN_POLICY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default policy for node shutdown.
DFLT_SIMPLE_NAME - Static variable in class org.apache.ignite.binary.BinaryBasicNameMapper
Default use simple name flag setting.
DFLT_SNAPSHOTS_PATH - Static variable in class org.gridgain.grid.configuration.SnapshotConfiguration
Default snapshot path.
DFLT_SND_HUB_LOAD_BALANCING_MODE - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default data center replication sender cache sender hub load balancing mode.
DFLT_SO_LINGER - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default SO_LINGER to set for socket, 0 means enabled with 0 timeout.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default socket send and receive buffer size.
DFLT_SOCK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default socket operations timeout in milliseconds (value is 5000ms).
DFLT_SOCK_TIMEOUT_CLIENT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default socket operations timeout in milliseconds (value is 5000ms).
DFLT_SOCK_WRITE_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default socket write timeout.
DFLT_SPARSITY_CHECK_FREQUENCY - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default sparsity check frequency.
DFLT_SQL_INDEX_MAX_INLINE_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default maximum inline size for sql indexes.
DFLT_SQL_ONHEAP_CACHE_MAX_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default SQL on-heap cache size.
DFLT_SQL_QUERY_GLOBAL_MEMORY_QUOTA - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_SQL_QUERY_GLOBAL_MEMORY_QUOTA - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default SQL query global memory quota.
DFLT_SQL_QUERY_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_SQL_QUERY_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default SQL query history size.
DFLT_SQL_QUERY_MEMORY_QUOTA - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_SQL_QUERY_MEMORY_QUOTA - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default SQL per query memory quota.
DFLT_SQL_QUERY_OFFLOADING_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_SQL_QUERY_OFFLOADING_ENABLED - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default value for SQL offloading flag.
DFLT_SSL_PROTOCOL - Static variable in class org.apache.ignite.ssl.SslContextFactory
Default SSL protocol.
DFLT_STARVATION_INCREMENT - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default value on which job priority will be increased every time when job gets bumped down.
DFLT_STATE_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for cluster state on start.
DFLT_STATE_TRANSFER_THREADS_CNT - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default data center replication sender cache amount of worker threads responsible for full state transfer.
DFLT_STATE_TRANSFER_THROTTLE - Static variable in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Default data center replication sender cache state transfer throttle.
DFLT_STATS_PRINT_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default statistics print frequency in milliseconds (value is 0ms).
DFLT_STORE_KEEP_BINARY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for keep binary in store behavior .
DFLT_STORE_TYPE - Static variable in class org.apache.ignite.ssl.SslContextFactory
Default key / trust store type.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default amount of sub intervals to calculate DataRegionMetrics.getAllocationRate() metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default amount of sub intervals to calculate rate-based metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Default amount of sub intervals to calculate MemoryMetrics.getAllocationRate() metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default amount of sub intervals to calculate rate-based metric.
DFLT_SYNCHRONOUS_MODE - Static variable in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Default synchronous mode flag.
DFLT_SYS_REQ_TIMEOUT - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default ping timeout.
DFLT_SYS_WORKER_BLOCKED_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default system worker blocked timeout in millis.
DFLT_SYSTEM_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of system thread pool.
DFLT_TCP_DIRECT_BUF - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP direct buffer flag.
DFLT_TCP_HOST - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default TCP host.
DFLT_TCP_NO_DELAY - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default value for TCP_NODELAY socket option (value is true).
DFLT_TCP_NO_DELAY - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default value for TCP_NODELAY socket option (value is true).
DFLT_TCP_NODELAY - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP_NODELAY flag.
DFLT_TCP_NODELAY - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default value for TCP_NODELAY socket option (value is true).
DFLT_TCP_NODELAY - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default TCP_NODELAY flag value for server sockets.
DFLT_TCP_PORT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP server port.
DFLT_TCP_PORT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default TCP server port.
DFLT_TCP_PORT_FROM - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default minimum TCP port range value.
DFLT_TCP_PORT_TO - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default maximum TCP port range value.
DFLT_THREAD_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default Ignite thread keep alive time.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default size of thread pool.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default size of thread pool.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default size of thread pool.
DFLT_THREAD_PRI - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default value for thread priority (value is 10).
DFLT_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default max queue capacity of REST thread pool.
DFLT_THREADS_COUNT - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Default number of working threads (equal to the number of available processors).
DFLT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_TIME_INTERVAL - Static variable in class org.apache.ignite.cache.query.AbstractContinuousQuery
Maximum default time interval after which buffer will be flushed (if buffering is enabled).
DFLT_TIME_SERVER_PORT_BASE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default time server port base.
DFLT_TIME_SERVER_PORT_RANGE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default time server port range.
DFLT_TIMEOUT - Static variable in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Default value for timeout.
DFLT_TLB_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default thread local buffer size.
DFLT_TOP_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default size of topology snapshots history.
DFLT_TRANSACTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction timeout.
DFLT_TRANSACTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default transaction timeout.
DFLT_TTL - Static variable in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Default value for TTL.
DFLT_TX_CONCURRENCY - Static variable in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default concurrency mode.
DFLT_TX_CONCURRENCY - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default concurrency mode.
DFLT_TX_ISOLATION - Static variable in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction isolation level.
DFLT_TX_ISOLATION - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default transaction isolation level.
DFLT_TX_SERIALIZABLE_ENABLED - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default value for 'txSerializableEnabled' flag.
DFLT_UNLIMIT_TIMEOUT - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default timeout for streamer's operations.
DFLT_UPDATE_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default update entry query (value is select * from ENTRIES where akey=?
DFLT_USE_ASYNC_FILE_IO_FACTORY - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_USE_CONSISTENT_ID - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default use consistent ID for store path.
DFLT_USE_IGNITE_SSL_CTX_FACTORY - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default value of whether to use Ignite SSL context factory.
DFLT_USE_IGNITE_SSL_CTX_FACTORY - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default value of whether to use Ignite SSL context factory.
DFLT_USE_IGNITE_SSL_CTX_FACTORY - Static variable in class org.gridgain.grid.configuration.DrSenderConfiguration
Default value of whether to use Ignite SSL context factory.
DFLT_VALUE_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint value field name (value is VALUE).
DFLT_VALUE_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint value field type (value is BLOB).
DFLT_WAIT_FOR_SEG_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for wait for segment on startup flag.
DFLT_WAIT_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Default waiting jobs number.
DFLT_WAIT_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default waiting jobs number.
DFLT_WAIT_JOBS_THRESHOLD - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default threshold of waiting jobs.
DFLT_WAL_ALWAYS_WRITE_FULL_PAGES - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal always write full pages.
DFLT_WAL_ALWAYS_WRITE_FULL_PAGES - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal always write full pages.
DFLT_WAL_ARCHIVE_MAX_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default max size of WAL archive files, in bytes.
DFLT_WAL_ARCHIVE_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal archive directory.
DFLT_WAL_ARCHIVE_PATH - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal archive directory.
DFLT_WAL_BUFF_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default thread local buffer size.
DFLT_WAL_COMPACTION_ENABLED - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal compaction enabled.
DFLT_WAL_COMPACTION_LEVEL - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal compaction level.
DFLT_WAL_FLUSH_FREQ - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default Wal flush frequency.
DFLT_WAL_FLUSH_FREQ - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default Wal flush frequency.
DFLT_WAL_FSYNC_DELAY - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal fsync delay.
DFLT_WAL_FSYNC_DELAY - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal fsync delay.
DFLT_WAL_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default number of checkpoints to be kept in WAL after checkpoint is finished
DFLT_WAL_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default number of checkpoints to be kept in WAL after checkpoint is finished
DFLT_WAL_MODE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal mode.
DFLT_WAL_MODE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal mode.
DFLT_WAL_PAGE_COMPRESSION - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default compression algorithm for WAL page snapshot records.
DFLT_WAL_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal directory.
DFLT_WAL_RECORD_ITERATOR_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal record iterator buffer size.
DFLT_WAL_RECORD_ITERATOR_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal record iterator buffer size.
DFLT_WAL_SEGMENT_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default WAL file segment size, 64MBytes
DFLT_WAL_SEGMENT_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default WAL file segment size, 64MBytes
DFLT_WAL_SEGMENTS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_WAL_SEGMENTS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
DFLT_WAL_STORE_PATH - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal directory.
DFLT_WORKER_THREAD_CNT - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default number of threads responsible for sender hub requests processing.
DFLT_WRITE_ATTEMPTS - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Default value for write attempts.
DFLT_WRITE_BEHIND_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default batch size for write-behind cache store.
DFLT_WRITE_BEHIND_COALESCING - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default write coalescing for write-behind cache store.
DFLT_WRITE_BEHIND_CRITICAL_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default critical size used when flush size is not specified.
DFLT_WRITE_BEHIND_ENABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'writeBehindEnabled' flag.
DFLT_WRITE_BEHIND_FLUSH_FREQUENCY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default flush frequency for write-behind cache store in milliseconds.
DFLT_WRITE_BEHIND_FLUSH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default flush size for write-behind cache store.
DFLT_WRITE_BUFFER_SIZE - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default write buffer size.
DFLT_WRITE_DELAY - Static variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Default value for write delay in microseconds.
DFLT_WRITE_FROM_BEHIND_FLUSH_THREAD_CNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default count of flush threads for write-behind cache store.
DFLT_WRITE_THROTTLING_ENABLED - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default write throttling enabled.
DFLT_WRITE_THROTTLING_ENABLED - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default write throttling enabled.
DFLT_WRITE_TIMEOUT - Static variable in class org.gridgain.grid.configuration.DrReceiverConfiguration
Default server socket write timeout.
dht() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
dialect - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Database dialect.
DictionaryMetrics - Interface in org.gridgain.grid.cache.compress
Compression with dictionary cycling implementation metrics.
differential(double) - Method in interface org.apache.ignite.ml.math.functions.IgniteDifferentiableDoubleToDoubleFunction
Get function differential at a given point.
differential(Vector) - Method in interface org.apache.ignite.ml.math.functions.IgniteDifferentiableVectorToDoubleFunction
Get function differential at a given point.
differentiateByParameters(IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>, Matrix, Matrix) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Compose function in the following way: feed output of this model as input to second argument to loss function.
differentiateByParameters(IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>, Matrix, Matrix) - Method in interface org.apache.ignite.ml.optimization.SmoothParametrized
Compose function in the following way: feed output of this model as input to second argument to loss function.
digest() - Method in class org.gridgain.grid.persistentstore.snapshot.file.DigestByteChannelSnapshotOutputStream
digest() - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotEncryptionDigestOutputStream
DigestByteChannelSnapshotOutputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
Snapshot output stream computing digest on the go.
DigestByteChannelSnapshotOutputStream(OutputStream, MessageDigest, SnapshotOutputStreamListener) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.DigestByteChannelSnapshotOutputStream
 
DigestSnapshotInputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
Snapshot input stream with digest.
dimension() - Method in interface org.apache.ignite.ml.math.stat.Distribution
 
dimension() - Method in class org.apache.ignite.ml.math.stat.DistributionMixture
dimension() - Method in class org.apache.ignite.ml.math.stat.MultivariateGaussianDistribution
DIRECT_TYPE_SIZE - Static variable in interface org.apache.ignite.plugin.extensions.communication.Message
Direct type size in bytes.
DirectorySerializer - Class in org.apache.ignite.ml.inference.util
Utils class that helps to serialize directory content as a has map and then deserialize it.
DirectorySerializer() - Constructor for class org.apache.ignite.ml.inference.util.DirectorySerializer
 
directType() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Gets message type.
directType() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Gets message type.
DISABLE_SNAPSHOT_ON_BASELINE_CHANGE_WITH_ENABLED_PITR - Static variable in class org.gridgain.grid.GridNodeAttributes
disableAdaptiveThrottling() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Disables adaptive DR throttling.
DISABLED_CLIENT_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Client nodes might have port 0 if they have no server socket opened.
disableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Disables provided events.
disableMetrics() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Disables memory metrics collection on an Apache Ignite node.
disableMetrics() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Disables persistence metrics collection on an Apache Ignite node.
disableMetrics() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Disables memory metrics collection on an Apache Ignite node.
disableMetrics() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Disables persistence metrics collection on an Apache Ignite node.
disableStatistics() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Disable statistic collection for the cache.
disableTracing() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
disableWal(String) - Method in interface org.apache.ignite.client.ClientCluster
Disables write-ahead logging for specified cache.
disableWal(String) - Method in interface org.apache.ignite.IgniteCluster
Disables write-ahead logging for specified cache.
DISCO_METRICS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Name of the discovery metrics registry.
disconnect() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnect() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnect() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnect() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnected(SchedulerDriver) - Method in class org.apache.ignite.mesos.IgniteScheduler
DISCOVERY_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
discoveryClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Deprecated.
Since 2.8. May return incorrect value if client and server nodes shares same TcpDiscoveryIpFinder instance.
DiscoveryDataBag - Class in org.apache.ignite.spi.discovery
Provides interface for GridComponent to collect and exchange discovery data both on joining node and on cluster nodes.
DiscoveryDataBag(UUID, boolean) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
DiscoveryDataBag(UUID, Set<Integer>, boolean) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
DiscoveryDataBag.GridDiscoveryData - Interface in org.apache.ignite.spi.discovery
Facade interface representing DiscoveryDataBag object with discovery data collected in the grid.
DiscoveryDataBag.JoiningNodeDiscoveryData - Interface in org.apache.ignite.spi.discovery
Facade interface representing DiscoveryDataBag object with discovery data from joining node.
discoveryEvent() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets discovery event caused topology change.
DiscoveryEvent - Class in org.apache.ignite.events
Grid discovery event.
DiscoveryEvent() - Constructor for class org.apache.ignite.events.DiscoveryEvent
No-arg constructor.
DiscoveryEvent(ClusterNode, String, int, ClusterNode) - Constructor for class org.apache.ignite.events.DiscoveryEvent
Creates new discovery event with given parameters.
discoveryEventName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets name of discovery event that triggered this rebalancing event.
discoveryEventType() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets type of discovery event that triggered this rebalancing event.
DiscoveryMetricsProvider - Interface in org.apache.ignite.spi.discovery
Provides metrics to discovery SPI.
discoveryNode() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets shadow of the node that triggered this rebalancing event.
DiscoveryNotification - Class in org.apache.ignite.spi.discovery
Discovery notification object.
DiscoveryNotification(int, long, ClusterNode, Collection<ClusterNode>) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryNotification
 
DiscoveryNotification(int, long, ClusterNode, Collection<ClusterNode>, Map<Long, Collection<ClusterNode>>, DiscoverySpiCustomMessage, SpanContainer) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryNotification
 
DiscoverySpi - Interface in org.apache.ignite.spi.discovery
Grid discovery SPI allows to discover remote nodes in grid.
DiscoverySpiCustomMessage - Interface in org.apache.ignite.spi.discovery
Message to send across ring.
DiscoverySpiDataExchange - Interface in org.apache.ignite.spi.discovery
Handler for initial data exchange between Ignite nodes.
DiscoverySpiHistorySupport - Annotation Type in org.apache.ignite.spi.discovery
This annotation is for all implementations of DiscoverySpi that support topology snapshots history.
DiscoverySpiListener - Interface in org.apache.ignite.spi.discovery
Listener for grid node discovery events.
DiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery
Generic MBean interface to monitor DiscoverySpi subsystem.
DiscoverySpiMutableCustomMessageSupport - Annotation Type in org.apache.ignite.spi.discovery
This annotation is for all implementations of DiscoverySpi that support topology mutable DiscoverySpiCustomMessages.
DiscoverySpiNodeAuthenticator - Interface in org.apache.ignite.spi.discovery
Node authenticator.
DiscoverySpiOrderSupport - Annotation Type in org.apache.ignite.spi.discovery
This annotation is for all implementations of DiscoverySpi that support proper node ordering.
discoveryTimestamp() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets timestamp of discovery event that caused this rebalancing event.
DiscreteNaiveBayesModel - Class in org.apache.ignite.ml.naivebayes.discrete
Discrete naive Bayes model which predicts result value y belongs to a class C_k, k in [0..K] as {@code p(C_k,y) =x_1*p_k1^x *...
DiscreteNaiveBayesModel(double[][][], double[], double[], double[][], DiscreteNaiveBayesSumsHolder) - Constructor for class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
 
DiscreteNaiveBayesSumsHolder - Class in org.apache.ignite.ml.naivebayes.discrete
Service class is used to calculate amount of values which are below the threshold.
DiscreteNaiveBayesSumsHolder() - Constructor for class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesSumsHolder
 
DiscreteNaiveBayesTrainer - Class in org.apache.ignite.ml.naivebayes.discrete
Trainer for the Discrete naive Bayes classification model.
DiscreteNaiveBayesTrainer() - Constructor for class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
 
DiscreteRandomProducer - Class in org.apache.ignite.ml.util.generators.primitives.scalar
Pseudorandom producer generating values from user provided discrete distribution.
DiscreteRandomProducer(double...) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
Creates an instance of DiscreteRandomProducer.
DiscreteRandomProducer(long, double...) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
Creates an instance of DiscreteRandomProducer.
disk() - Method in class org.apache.ignite.mesos.ClusterProperties
 
DISK - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Disk.
disk - Variable in class org.apache.ignite.mesos.IgniteTask
 
disk() - Method in class org.apache.ignite.mesos.IgniteTask
 
diskAllocationCurrent() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
Returns current allocated size of data on disk.
diskAllocationMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
Returns maximum allocated size of data on disk.
diskAllocationMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
Returns maximum allocated size of data on disk.
diskAllocationMin() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
Returns minimum allocated size of data on disk.
diskAllocationTotal() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
Returns total allocated size of data on disk.
diskAllocationTotalMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
Returns maximum of total allocated size of data on disk.
diskAllocationTotalMin() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
Returns minimum of total allocated size of data on disk.
DiskPageCompression - Enum in org.apache.ignite.configuration
Disk page compression options.
diskPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
distanceMeasure() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Distance measure.
distanceMeasure - Variable in class org.apache.ignite.ml.knn.ann.KNNModelFormat
Distance measure.
distanceMeasure - Variable in class org.apache.ignite.ml.knn.KNNModel
Distance measure.
distanceMeasure - Variable in class org.apache.ignite.ml.knn.KNNTrainer
Distance measure.
distanceMeasure - Variable in class org.apache.ignite.ml.knn.NNClassificationModel
Distance measure.
DistanceMeasure - Interface in org.apache.ignite.ml.math.distances
This class is based on the corresponding class from Apache Common Math lib.
distributedJoins() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
distributedJoins() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
distributedJoins() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Specify if distributed joins are enabled for this query.
Distribution - Interface in org.apache.ignite.ml.math.stat
Interface for distributions.
DistributionComputer - Interface in org.apache.ignite.ml.dataset.feature
Interface specifies an object that can compute some discrete distribution.
distributionId() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.VectorWithDistributionId
 
DistributionMixture<C extends Distribution> - Class in org.apache.ignite.ml.math.stat
Mixture of distributions class where each component has own probability and probability of input vector can be computed as a sum of likelihoods of each component.
DistributionMixture(Vector, List<C>) - Constructor for class org.apache.ignite.ml.math.stat.DistributionMixture
Creates an instance of DistributionMixture.
distributions() - Method in class org.apache.ignite.ml.math.stat.DistributionMixture
 
div(double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns a / b.
divide(double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Divides each value in this matrix by the argument.
divide(double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Divides each value in this matrix by the argument.
divide(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing values from this vector divided by the argument.
divide(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing values from this vector divided by the argument.
divide(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing values from this vector divided by the argument.
doAfter() - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowChiefRunner
Method that should be called after starting the process.
doAfter() - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowUserScriptRunner
Method that should be called after starting the process.
doAfter() - Method in class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Method that should be called after starting the process.
doBefore() - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowChiefRunner
Method that should be called before starting the process.
doBefore() - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowUserScriptRunner
Method that should be called before starting the process.
doBefore() - Method in class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Method that should be called before starting the process.
doBegin(Object, TransactionDefinition) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doCleanupAfterCompletion(Object) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doCommit(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
doGetTransaction() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doRollback(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
dot(Vector, Vector) - Static method in class org.apache.ignite.ml.math.Blas
Returns dot product of vectors x and y.
dot(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets dot product of two vectors.
dot(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets dot product of two vectors.
dot(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets dot product of two vectors.
DOT - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
DOT - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
dotSelf() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
DOUBLE - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
DOUBLE - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
DOUBLE() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
 
DoubleArrayVectorizer<K> - Class in org.apache.ignite.ml.dataset.feature.extractor.impl
Vectorizer on arrays of doubles.
DoubleArrayVectorizer(Integer...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.impl.DoubleArrayVectorizer
Creates an instance of Vectorizer.
DoubleMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds double primitive.
DOWNLOAD_LINK - Static variable in class org.apache.ignite.yarn.IgniteProvider
 
downloadIgnite(String) - Method in class org.apache.ignite.mesos.resource.IgniteProvider
 
dr() - Method in interface org.gridgain.grid.GridGain
Gets an instance of Data Center Replication.
DrAbstractSenderStore - Class in org.gridgain.grid.dr.store
Defines common methods to DrSenderStore implementations.
DrAbstractSenderStore() - Constructor for class org.gridgain.grid.dr.store.DrAbstractSenderStore
 
drainPermits() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires and returns all permits that are immediately available.
DrCacheFstEvent - Class in org.gridgain.grid.events
Cache full state transfer event.
DrCacheFstEvent() - Constructor for class org.gridgain.grid.events.DrCacheFstEvent
No-arg constructor.
DrCacheFstEvent(ClusterNode, String, int, String, Collection<Byte>) - Constructor for class org.gridgain.grid.events.DrCacheFstEvent
Creates cache full state transfer event with given parameters.
DrCacheReplicationEvent - Class in org.gridgain.grid.events
Cache replication state changed event.
DrCacheReplicationEvent() - Constructor for class org.gridgain.grid.events.DrCacheReplicationEvent
No-arg constructor.
DrCacheReplicationEvent(ClusterNode, String, int, String, CacheDrPauseInfo) - Constructor for class org.gridgain.grid.events.DrCacheReplicationEvent
Creates cache replication event with given parameters.
driverSession() - Method in class org.apache.ignite.cache.store.cassandra.session.pool.IdleSession
Returns wrapped Cassandra driver session.
dropAllConnections() - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Drop all active connections.
dropConnection(long) - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Drops client connection by id, if exists.
DrReceiverConfiguration - Class in org.gridgain.grid.configuration
Data center replication receiver hub configuration.
DrReceiverConfiguration() - Constructor for class org.gridgain.grid.configuration.DrReceiverConfiguration
Default constructor.
DrReceiverConfiguration(DrReceiverConfiguration) - Constructor for class org.gridgain.grid.configuration.DrReceiverConfiguration
Copying constructor.
DrReceiverInCacheMetrics - Interface in org.gridgain.grid.dr
Data center replication receiver hub metrics for incoming data, i.e. data transferred from remote sender hubs to receiver hub.
DrReceiverInMetrics - Interface in org.gridgain.grid.dr
Data center replication receiver hub metrics for incoming data, i.e. data transferred from remote sender hubs to receiver hub.
DrReceiverLoadBalancingMode - Enum in org.gridgain.grid.dr
Data center replication receiver hub load balancing mode.
DrReceiverMBean - Interface in org.gridgain.grid.dr
This interface defines JMX view on data center replication receiver hub.
DrReceiverOutMetrics - Interface in org.gridgain.grid.dr
Data center replication receiver hub metrics for outgoing data, i.e. data transferred from receiver hub to receiver caches.
DrRemoteDcNodeEvent - Class in org.gridgain.grid.events
Remote replication node event.
DrRemoteDcNodeEvent() - Constructor for class org.gridgain.grid.events.DrRemoteDcNodeEvent
No-arg constructor.
DrRemoteDcNodeEvent(ClusterNode, String, int, InetSocketAddress, byte, int) - Constructor for class org.gridgain.grid.events.DrRemoteDcNodeEvent
Creates replication node event with given parameters.
DrRemoteDcReplicationEvent - Class in org.gridgain.grid.events
Remote replication dc event.
DrRemoteDcReplicationEvent() - Constructor for class org.gridgain.grid.events.DrRemoteDcReplicationEvent
No-arg constructor.
DrRemoteDcReplicationEvent(ClusterNode, String, int, byte) - Constructor for class org.gridgain.grid.events.DrRemoteDcReplicationEvent
Creates replication node event with given parameters.
DrSender - Interface in org.gridgain.grid.dr
Data center replication sender interface.
DrSenderConfiguration - Class in org.gridgain.grid.configuration
Data center replication sender hub configuration.
DrSenderConfiguration() - Constructor for class org.gridgain.grid.configuration.DrSenderConfiguration
Default constructor.
DrSenderConfiguration(DrSenderConfiguration) - Constructor for class org.gridgain.grid.configuration.DrSenderConfiguration
Copying constructor.
DrSenderConnection - Interface in org.gridgain.grid.dr
Data center replication sender connection interface.
DrSenderConnectionConfiguration - Class in org.gridgain.grid.dr
Data center replication sender hub connection configuration.
DrSenderConnectionConfiguration() - Constructor for class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Constructor.
DrSenderConnectionConfiguration(DrSenderConnectionConfiguration) - Constructor for class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Copying constructor.
DrSenderConnectionState - Enum in org.gridgain.grid.dr
Data center replication connection state.
DrSenderFsStore - Class in org.gridgain.grid.dr.store.fs
Data center replication sender hub store implementation which persists data in file system.
DrSenderFsStore() - Constructor for class org.gridgain.grid.dr.store.fs.DrSenderFsStore
 
DrSenderInMemoryStore - Class in org.gridgain.grid.dr.store.memory
Data center replication sender hub store implementation which stores data in memory.
DrSenderInMemoryStore() - Constructor for class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
 
DrSenderInMetrics - Interface in org.gridgain.grid.dr
Data center replication sender hub metrics for incoming data, i.e. data transferred from sender caches to sender hub.
DrSenderLoadBalancingMode - Enum in org.gridgain.grid.dr
Data center replication sender hub load balancing mode.
DrSenderMBean - Interface in org.gridgain.grid.dr
This interface defines JMX view on data center replication sender hub.
DrSenderOutCacheMetrics - Interface in org.gridgain.grid.dr
Data center replication sender hub metrics for outgoing data, i.e. data transferred from sender hub to remote receiver hubs.
DrSenderOutMetrics - Interface in org.gridgain.grid.dr
Data center replication sender hub metrics for outgoing data, i.e. data transferred from sender hub to remote receiver hubs.
DrSenderStore - Interface in org.gridgain.grid.dr.store
Data center replication sender hub store.
DrSenderStoreCorruptedException - Exception in org.gridgain.grid.dr.store
Exception thrown in case data center replication sender hub store was corrupted.
DrSenderStoreCorruptedException(String) - Constructor for exception org.gridgain.grid.dr.store.DrSenderStoreCorruptedException
Constructor.
DrSenderStoreCorruptedException(String, Throwable) - Constructor for exception org.gridgain.grid.dr.store.DrSenderStoreCorruptedException
 
DrSenderStoreCursor - Interface in org.gridgain.grid.dr.store
Data center replication sender hub store cursor.
DrSenderStoreCursorClosedException - Exception in org.gridgain.grid.dr.store
Exception is thrown on any cursor action when it is in closed state.
DrSenderStoreCursorClosedException(String) - Constructor for exception org.gridgain.grid.dr.store.DrSenderStoreCursorClosedException
Constructor.
DrSenderStoreEntry - Interface in org.gridgain.grid.dr.store
Data center replication sender hub store entry.
DrSenderStoreOverflowException - Exception in org.gridgain.grid.dr.store
Exception thrown when data center replication sender hub store cannot persist more entries.
DrSenderStoreOverflowException() - Constructor for exception org.gridgain.grid.dr.store.DrSenderStoreOverflowException
Constructor.
DrSenderStoreOverflowException(String) - Constructor for exception org.gridgain.grid.dr.store.DrSenderStoreOverflowException
Constructor with custom message.
DrSenderStoreOverflowException(String, Throwable) - Constructor for exception org.gridgain.grid.dr.store.DrSenderStoreOverflowException
 
DrSenderStoreOverflowMode - Enum in org.gridgain.grid.dr.store
Data center replication sender hub store overflow mode.
DrStoreEvent - Class in org.gridgain.grid.events
Sender hub store event.
DrStoreEvent() - Constructor for class org.gridgain.grid.events.DrStoreEvent
No-arg constructor.
DrStoreEvent(ClusterNode, String, int, Byte) - Constructor for class org.gridgain.grid.events.DrStoreEvent
Creates store event with given parameters.
DummyVectorizer<K> - Class in org.apache.ignite.ml.dataset.feature.extractor.impl
Vectorizer on Vector.
DummyVectorizer(Integer...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.impl.DummyVectorizer
Creates an instance of Vectorizer.
dumpDebugInfo() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Dumps debug information for the current node.
dumpDebugInfo() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Dumps debug info using configured logger.
dumpDebugInfo() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Dumps debug info using configured logger.
dumpNodeStatistics(UUID) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
dumpRingStructure() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Dumps ring structure to log.
dumpStats() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Dumps SPI per-connection stats to logs.
dumpStats() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Dumps SPI per-connection stats to logs.
duplicateIdError(TcpDiscoveryDuplicateIdMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
duplicateRandomFeatures(int) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Increase vectors of generator by increaseSize and sets to new values random selected feature values from already set components.
duplicateRandomFeatures(int, Long) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Increase vectors of generator by increaseSize and sets to new values random selected feature values from already set components.
DurableStore - Annotation Type in org.gridgain.grid.dr.store
Marker attribute for DR sender store implementation.
duration() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
duration() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
duration() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
durationMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
durationMin() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
DynamicQueryConfig - Class in org.apache.ignite.springdata22.repository.config
Runtime Dynamic query configuration.
DynamicQueryConfig() - Constructor for class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
 

E

EchoingLogger - Class in org.apache.ignite.logger
IgniteLogger wrapper that echoes log messages to arbitrary target.
EchoingLogger(IgniteLogger, Consumer<String>) - Constructor for class org.apache.ignite.logger.EchoingLogger
 
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.HandshakeFailEvent
Get the elapsed time of the handshake.
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.HandshakeSuccessEvent
Get the elapsed time of the handshake.
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.RequestFailEvent
Get the elapsed time of the request.
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.RequestSuccessEvent
Get the elapsed time of the request.
elementWiseMinus(Vector, Vector) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Performs in-place vector subtraction.
elementWiseMinus(Matrix, Matrix) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Performs in-place matrix subtraction.
elementWiseTimes(Vector, Vector) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Performs in-place vector multiplication.
elementWiseTimes(Matrix, Matrix) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Performs in-place matrix multiplication.
empty() - Static method in class org.apache.ignite.cache.QueryEntityPatch
Builder method for empty patch.
EMPTY_STRING - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
EmptyContext - Class in org.apache.ignite.ml.dataset.primitive.context
An empty partition context.
EmptyContext() - Constructor for class org.apache.ignite.ml.dataset.primitive.context.EmptyContext
 
EmptyContextBuilder<K,V> - Class in org.apache.ignite.ml.dataset.primitive.builder.context
A partition context builder that makes EmptyContext.
EmptyContextBuilder() - Constructor for class org.apache.ignite.ml.dataset.primitive.builder.context.EmptyContextBuilder
 
emptyDataPages() - Method in interface org.apache.ignite.DataRegionMetricsProvider
Calculates empty data pages count for region.
EmptyDatasetException() - Constructor for exception org.apache.ignite.ml.trainers.DatasetTrainer.EmptyDatasetException
Constructs an instance of EmptyDatasetException.
EmptyFileException - Exception in org.apache.ignite.ml.math.exceptions.knn
Shows empty filename.
EmptyFileException(String) - Constructor for exception org.apache.ignite.ml.math.exceptions.knn.EmptyFileException
Creates new exception.
emptyVector(int, boolean) - Static method in class org.apache.ignite.ml.structures.LabeledVectorSet
 
enableAdaptiveThrottling() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Enables adaptive DR throttling.
enabled() - Method in class org.gridgain.grid.ru.GridRollingUpgradeStatus
Returns true if Rolling Upgrade is enabled and is in progress.
enabledEvents() - Method in interface org.apache.ignite.IgniteEvents
Gets types of enabled events.
EnableIgniteRepositories - Annotation Type in org.apache.ignite.springdata22.repository.config
Annotation to activate Apache Ignite repositories.
enableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Enables provided events.
enableManagement(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
enableMetrics() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Enables memory metrics collection on an Apache Ignite node.
enableMetrics() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Enables persistence metrics collection on an Apache Ignite node.
enableMetrics() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Enables memory metrics collection on an Apache Ignite node.
enableMetrics() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Enables persistence metrics collection on an Apache Ignite node.
enableStatistics(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
enableStatistics(boolean) - Method in interface org.apache.ignite.IgniteCache
Sets statistics enabled flag cluster wide for this cache.
enableStatistics(Collection<String>, boolean) - Method in interface org.apache.ignite.IgniteCluster
Enables/disables statistics for caches cluster wide.
enableStatistics() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Enable statistic collection for the cache.
enableTracing() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
enableWal(String) - Method in interface org.apache.ignite.client.ClientCluster
Enables write-ahead logging for specified cache.
enableWal(String) - Method in interface org.apache.ignite.IgniteCluster
Enables write-ahead logging for specified cache.
encode(ClientConnectionContext, BinaryRawWriterEx) - Method in class org.apache.ignite.ml.inference.storage.model.thinclient.FileRespose
Encodes the response data.
encode(ClientConnectionContext, BinaryRawWriterEx) - Method in class org.apache.ignite.ml.inference.storage.model.thinclient.FilesListResponse
Encodes the response data.
encode(ClientConnectionContext, BinaryRawWriterEx) - Method in class org.apache.ignite.ml.inference.storage.model.thinclient.FileStatResponse
Encodes the response data.
EncoderPartitionData - Class in org.apache.ignite.ml.preprocessing.encoding
Partition data used in Encoder preprocessor.
EncoderPartitionData() - Constructor for class org.apache.ignite.ml.preprocessing.encoding.EncoderPartitionData
Constructs a new instance of String Encoder partition data.
EncoderPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.encoding
Preprocessing function that makes encoding.
EncoderPreprocessor(Map<String, Integer>[], Preprocessor<K, V>, Set<Integer>) - Constructor for class org.apache.ignite.ml.preprocessing.encoding.EncoderPreprocessor
Constructs a new instance of String Encoder preprocessor.
EncoderSortingStrategy - Enum in org.apache.ignite.ml.preprocessing.encoding
Describes Encoder sorting strategy to define mapping of integer values to values of categorical feature .
EncoderTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.encoding
Trainer of the String Encoder and One-Hot Encoder preprocessors.
EncoderTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.encoding.EncoderTrainer
 
EncoderType - Enum in org.apache.ignite.ml.preprocessing.encoding
Describes Encoder preprocessor types to define resulting model in EncoderTrainer.
encodingValues - Variable in class org.apache.ignite.ml.preprocessing.encoding.EncoderPreprocessor
Filling values.
encrypt(byte[]) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionService
Encrypt the input data.
encrypt(byte[]) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
Encrypt the input data.
encrypt(byte[]) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.EncryptionService
Encrypt the input data.
encrypt(byte[]) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionService
Encrypt the input data.
encrypt(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts data.
encrypt(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts data.
encrypt(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts data.
encryptedSize(int) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
 
encryptedSize(int) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
encryptedSize(int) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
encryptedSizeNoPadding(int) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
 
encryptedSizeNoPadding(int) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
encryptedSizeNoPadding(int) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
encryption() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteEncryption interface.
encryption() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteEncryption interface.
EncryptionConfiguration - Class in org.apache.ignite.configuration
Encryption configuration.
EncryptionConfiguration() - Constructor for class org.apache.ignite.configuration.EncryptionConfiguration
Creates valid encryption configuration with all default values.
EncryptionConfiguration(EncryptionConfiguration) - Constructor for class org.apache.ignite.configuration.EncryptionConfiguration
Constructs the copy of the configuration.
EncryptionMXBean - Interface in org.apache.ignite.mxbean
Encryption features MBean.
EncryptionService - Interface in org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt
A implementation of this interface should provide feature to encrypt/decrypt the data.
EncryptionSpi - Interface in org.apache.ignite.spi.encryption
SPI provides encryption features for an Ignite.
encryptKey(Serializable) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts key.
encryptKey(Serializable, String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts a key with the master key specified by name.
encryptKey(Serializable) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts key.
encryptKey(Serializable, String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts a key with the master key specified by name.
encryptKey(Serializable) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts key.
encryptKey(Serializable, String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts a key with the master key specified by name.
encryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts data without padding info.
encryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts data without padding info.
encryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts data without padding info.
end(Connection, Statement) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes allocated resources depending on transaction status.
end() - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Ends span.
end() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Ends span.
end() - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Ends span.
endTime() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
 
endTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
enforceJoinOrder() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
enforceJoinOrder() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
enforceJoinOrder() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets flag to enforce join order of tables in the query.
enhance(T) - Static method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringEnhancer
Enhances the object on load.
enrichFields(List<F>) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Sets accessor for the given src fields.
ensured(TcpDiscoveryAbstractMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
ensureDirectory(SnapshotPath, String, IgniteLogger) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathOperationsHelper
Ensures that this is a directory.
enterRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
enterRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
enterRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
enterRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
enterRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
enterRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
enterXgHeader(XGBoostModelParser.XgHeaderContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Enter a parse tree produced by XGBoostModelParser.xgHeader().
enterXgLeaf(XGBoostModelParser.XgLeafContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Enter a parse tree produced by XGBoostModelParser.xgLeaf().
enterXgModel(XGBoostModelParser.XgModelContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Enter a parse tree produced by XGBoostModelParser.xgModel().
enterXgNode(XGBoostModelParser.XgNodeContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Enter a parse tree produced by XGBoostModelParser.xgNode().
enterXgTree(XGBoostModelParser.XgTreeContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Enter a parse tree produced by XGBoostModelParser.xgTree().
enterXgValue(XGBoostModelParser.XgValueContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Enter a parse tree produced by XGBoostModelParser.xgValue().
entriesAcked() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of sent entries acknowledged by sender hub.
entriesAcked() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets amount of cache entries stored in receiver caches.
entriesAcked() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets amount of sent entries with received acknowledgement from receiver hubs.
entriesFiltered() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of filtered cache entries.
entriesReceived() - Method in interface org.gridgain.grid.cache.dr.CacheDrReceiverMetrics
Gets total amount of cache entries received from receiver hub.
entriesReceived() - Method in interface org.gridgain.grid.dr.DrReceiverInCacheMetrics
Gets the number of cache entries received from remote sender hubs.
entriesReceived() - Method in interface org.gridgain.grid.dr.DrSenderInMetrics
Gets amount of cache entries received from sender caches.
entriesSent() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets total amount of entries sent to sender hubs.
entriesSent() - Method in interface org.gridgain.grid.dr.DrReceiverOutMetrics
Gets amount of entries waiting to be stored in receiver caches.
entriesSent() - Method in interface org.gridgain.grid.dr.DrSenderOutCacheMetrics
Gets amount of bytes sent to receiver hubs.
EntryCompressionConfiguration - Interface in org.apache.ignite.configuration
Cache entry compression configuration marker interface.
entryExpired(V) - Method in interface org.apache.ignite.ml.util.LRUCacheExpirationListener
Handles entry expiration, is called before value is moved from cache.
EntryMapping(String, JdbcDialect, JdbcType, CacheAbstractJdbcStore.TypeKind, CacheAbstractJdbcStore.TypeKind, boolean) - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
entrySet() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets set of all entries cached on this node.
entrySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
enumName() - Method in interface org.apache.ignite.binary.BinaryObject
Get name for this enum object.
enumOrdinal() - Method in interface org.apache.ignite.binary.BinaryObject
Get ordinal for this enum object.
enumValues() - Method in interface org.apache.ignite.binary.BinaryType
 
envBuilder - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Learning environment builder.
envBuilder - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Learning environment builder.
envBuilder - Variable in class org.apache.ignite.ml.trainers.DatasetTrainer
Learning environment builder.
environment - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Learning Environment.
environment - Variable in class org.apache.ignite.ml.trainers.DatasetTrainer
Learning Environment.
EOF() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
eq(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Equal To.
EQ - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
EQ - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
EQ() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
 
EQ() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
EQ(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
equals(Object) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
equals(Object) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
equals(Object) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Equality check which delegates to the underlying key equality.
equals(Object) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
equals(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateKeyWrapper
equals(Object) - Method in class org.apache.ignite.cache.QueryEntity
equals(Object) - Method in class org.apache.ignite.cache.QueryIndex
equals(Object) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
equals(Object) - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
equals(Object) - Method in class org.apache.ignite.events.EventAdapter
equals(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
equals(Object) - Method in class org.apache.ignite.lang.IgniteProductVersion
equals(Object) - Method in class org.apache.ignite.lang.IgniteUuid
equals(Object) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
equals(Object) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModelFormat
equals(Object) - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedVector
equals(Object) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
equals(Object) - Method in class org.apache.ignite.ml.knn.ann.ANNModelFormat
equals(Object) - Method in class org.apache.ignite.ml.knn.ann.KNNModelFormat
equals(Object) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
equals(Object) - Method in class org.apache.ignite.ml.math.distances.EuclideanDistance
equals(Object) - Method in class org.apache.ignite.ml.math.distances.HammingDistance
equals(Object) - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
We ignore guid's for comparisons.
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
equals(Object) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
equals(Object) - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
equals(Object) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
equals(Object) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
equals(Object) - Method in class org.apache.ignite.ml.structures.Dataset
equals(Object) - Method in class org.apache.ignite.ml.structures.DatasetRow
equals(Object) - Method in class org.apache.ignite.ml.structures.FeatureMetadata
equals(Object) - Method in class org.apache.ignite.ml.structures.LabeledVector
equals(Object) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
equals(Object) - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeId
equals(Object) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
equals(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
equals(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
equals(Object) - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
equals(Object) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
equals(Object) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
equals(Object) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
equals(Object) - Method in class org.gridgain.grid.cache.compress.GzipCompressionConfiguration
equals(Object) - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
equals(Object) - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
equalsIgnoreNodeFilter(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
Checks if configurations are equal ignoring the node filter.
ERR_MSG - Static variable in exception org.apache.ignite.cache.query.QueryCancelledException
Error message.
error() - Method in class org.apache.ignite.failure.FailureContext
 
error(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out error message.
error(String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs error message with optional exception.
error(String, String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs error message with optional exception.
error(String, Throwable) - Method in class org.apache.ignite.logger.EchoingLogger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs error message with optional exception.
error(String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs error message with optional exception.
error(String, String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.NullLogger
Logs error message with optional exception.
error(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs error message with optional exception.
error(String, String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs error message with optional exception.
error(SchedulerDriver, String) - Method in class org.apache.ignite.mesos.IgniteScheduler
error(long, double, double) - Method in class org.apache.ignite.ml.composition.boosting.loss.LogLoss
Error value for model answer.
error(long, double, double) - Method in interface org.apache.ignite.ml.composition.boosting.loss.Loss
Error value for model answer.
error(long, double, double) - Method in class org.apache.ignite.ml.composition.boosting.loss.SquaredError
Error value for model answer.
error() - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
Gets error description.
error() - Method in class org.gridgain.grid.events.SnapshotEvent
Returns error, if snapshot operation that triggered event, has failed, and null if it has succeeded.
escape(String) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
escape(String) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
 
escape(String) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
escape(String) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
estimateRebalancingFinishTime() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
EuclideanDistance - Class in org.apache.ignite.ml.math.distances
Calculates the L2 (Euclidean) distance between two points.
EuclideanDistance() - Constructor for class org.apache.ignite.ml.math.distances.EuclideanDistance
 
evaluate(List<Gene>) - Method in interface org.apache.ignite.ml.genetic.IFitnessFunction
 
evaluate(IgniteCache<K, V>, IgniteModel<Vector, L>, Preprocessor<K, V>, Metric<L>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metric on the given cache.
evaluate(Map<K, V>, IgniteModel<Vector, L>, Preprocessor<K, V>, Metric<L>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metric on the given cache.
evaluate(IgniteCache<K, V>, IgniteBiPredicate<K, V>, IgniteModel<Vector, L>, Preprocessor<K, V>, Metric<L>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metric on the given cache.
evaluate(Map<K, V>, IgniteBiPredicate<K, V>, IgniteModel<Vector, L>, Preprocessor<K, V>, Metric<L>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metric on the given cache.
evaluate(IgniteCache<K, V>, IgniteModel<Vector, Double>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metrics on the given cache.
evaluate(Map<K, V>, IgniteModel<Vector, Double>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metrics on the given cache.
evaluate(IgniteCache<K, V>, IgniteBiPredicate<K, V>, IgniteModel<Vector, Double>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metrics on the given cache.
evaluate(Map<K, V>, IgniteBiPredicate<K, V>, IgniteModel<Vector, Double>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the given metrics on the given cache.
evaluateRegression(IgniteCache<K, V>, IgniteBiPredicate<K, V>, IgniteModel<Vector, Double>, Preprocessor<K, V>) - Static method in class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
Computes the regression metrics on the given cache.
Evaluator - Class in org.apache.ignite.ml.selection.scoring.evaluator
Evaluator that computes metrics from predictions and ground truth values.
Evaluator() - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.Evaluator
 
Event - Interface in org.apache.ignite.events
Grid events are used for notification about what happens within the grid.
EventAdapter - Class in org.apache.ignite.events
Base adapter for the events.
EventAdapter() - Constructor for class org.apache.ignite.events.EventAdapter
No-arg constructor.
EventAdapter(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.EventAdapter
Creates event based with given parameters.
eventNode() - Method in class org.apache.ignite.events.CacheEvent
Gets node which initiated cache operation or null if that node is not available.
eventNode(ClusterNode) - Method in class org.apache.ignite.events.DiscoveryEvent
Sets node this event is referring to.
eventNode() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets node that caused this event to be generated.
events() - Method in interface org.apache.ignite.Ignite
Gets events facade over all cluster nodes.
events(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets events facade over nodes within the cluster group.
events() - Method in class org.apache.ignite.IgniteSpringBean
Gets events facade over all cluster nodes.
events(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets events facade over nodes within the cluster group.
EventStorageSpi - Interface in org.apache.ignite.spi.eventstorage
This SPI provides local node events storage.
EventType - Interface in org.apache.ignite.events
Contains event type constants.
EventType - Class in org.gridgain.grid.events
Contains event type constants.
EventType() - Constructor for class org.gridgain.grid.events.EventType
 
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(Ignite, HibernateCacheProxy, Object) - Static method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove object from cache without regard to transaction.
evict(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Evicts entry associated with given key from cache.
evict(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
evict(Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
EvictableEntry<K,V> - Interface in org.apache.ignite.cache.eviction
Evictable cache entry passed into EvictionPolicy.
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove all data from cache without regard to transaction.
evictAll(IgniteInternalCache<Object, Object>) - Static method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called to remove all data from cache without regard to transaction.
evictAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Attempts to evict all entries associated with keys.
evictAll() - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
evictAll() - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
evictAllowed(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.eviction.EvictionFilter
Checks if entry may be evicted from cache.
EvictionFilter<K,V> - Interface in org.apache.ignite.cache.eviction
Eviction filter to specify which entries should not be evicted.
evictionFilter() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
EvictionPolicy<K,V> - Interface in org.apache.ignite.cache.eviction
Pluggable cache eviction policy.
evictionPolicyFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
EvolutionOptimizationStrategy - Class in org.apache.ignite.ml.selection.paramgrid
Represents the Genetic algorithms usage for finding the best set of hyper-parameters.
EvolutionOptimizationStrategy() - Constructor for class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
evolve() - Method in class org.apache.ignite.ml.genetic.GAGrid
Evolve the population
EVT_AUTHENTICATION_FAILED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: authentication failed.
EVT_AUTHENTICATION_SUCCEEDED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: authentication succeed.
EVT_AUTHORIZATION_FAILED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: authorization failed.
EVT_AUTHORIZATION_SUCCEEDED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: authorization succeed.
EVT_BASELINE_AUTO_ADJUST_AWAITING_TIME_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: baseline auto-adjust timeout has been changed by user request.
EVT_BASELINE_AUTO_ADJUST_ENABLED_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: baseline auto-adjust "enabled" flag has been changed by user request.
EVT_BASELINE_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: baseline topology has been changed by either user request or auto-adjust timeout event.
EVT_CACHE_ENTRY_CREATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: entry created.
EVT_CACHE_ENTRY_DESTROYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: entry destroyed.
EVT_CACHE_ENTRY_EVICTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: entry evicted.
EVT_CACHE_NODES_LEFT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache nodes left.
EVT_CACHE_OBJECT_EXPIRED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object was expired when reading it.
EVT_CACHE_OBJECT_LOCKED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object locked.
EVT_CACHE_OBJECT_PUT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object put.
EVT_CACHE_OBJECT_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object read.
EVT_CACHE_OBJECT_REMOVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object removed.
EVT_CACHE_OBJECT_UNLOCKED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object unlocked.
EVT_CACHE_QUERY_EXECUTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: query executed.
EVT_CACHE_QUERY_OBJECT_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: query entry read.
EVT_CACHE_REBALANCE_OBJECT_LOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache entry rebalanced.
EVT_CACHE_REBALANCE_OBJECT_UNLOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache entry unloaded.
EVT_CACHE_REBALANCE_PART_DATA_LOST - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: all nodes that hold partition left topology.
EVT_CACHE_REBALANCE_PART_LOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition loaded.
EVT_CACHE_REBALANCE_PART_MISSED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition was not sent to remote node.
EVT_CACHE_REBALANCE_PART_SUPPLIED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition was fully sent to remote node.
EVT_CACHE_REBALANCE_PART_UNLOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition unloaded.
EVT_CACHE_REBALANCE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache rebalance started.
EVT_CACHE_REBALANCE_STOPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache rebalance stopped.
EVT_CACHE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache started.
EVT_CACHE_STOPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache started.
EVT_CHECKPOINT_LOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: intermediate state of a job or task, so-called checkpoint, was loaded.
EVT_CHECKPOINT_REMOVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: intermediate state of a job or task, so-called checkpoint, was removed.
EVT_CHECKPOINT_SAVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: intermediate state of a job or task, so-called checkpoint, was saved.
EVT_CLASS_DEPLOY_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: non-task class deployment failed.
EVT_CLASS_DEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: non-task class deployed.
EVT_CLASS_UNDEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: non-task class undeployed.
EVT_CLIENT_NODE_DISCONNECTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: client node disconnected.
EVT_CLIENT_NODE_RECONNECTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: client node reconnected.
EVT_CLUSTER_ACTIVATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster activation state changed.
EVT_CLUSTER_DEACTIVATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster activation state changed.
EVT_CLUSTER_ID_UPDATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cluster ID has been changed by user request.
EVT_CLUSTER_STATE_CHANGE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster state change initiated.
EVT_CLUSTER_STATE_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster state changed.
EVT_CLUSTER_TAG_UPDATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cluster tag has been changed by user request.
EVT_DR_CACHE_FST_FAILED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: full state transfer failed for the cache.
EVT_DR_CACHE_FST_FINISHED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: full state transfer finished for the cache.
EVT_DR_CACHE_FST_STARTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: full state transfer started for the cache.
EVT_DR_CACHE_REPLICATION_STARTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: cache replication started for cache.
EVT_DR_CACHE_REPLICATION_STOPPED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: cache replication stopped for cache.
EVT_DR_DC_REPLICATION_PAUSED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: remote dc replication is paused on sender.
EVT_DR_DC_REPLICATION_RESUMED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: remote dc replication is resumed on sender.
EVT_DR_REMOTE_DC_NODE_CONNECTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: remote replication node connected.
EVT_DR_REMOTE_DC_NODE_DISCONNECTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: remote replication node disconnected.
EVT_DR_STORE_CORRUPTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: store is corrupted.
EVT_DR_STORE_OVERFLOW - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: store is overflowed.
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_LIC_CLEARED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: license violation cleared.
EVT_LIC_GRACE_EXPIRED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: license violation grace period is expired.
EVT_LIC_VIOLATION - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: license violation detected.
EVT_MANAGEMENT_TASK_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Visor or Web Console management task started.
EVT_NODE_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node failed.
EVT_NODE_JOINED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node joined topology.
EVT_NODE_LEFT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node has normally left topology.
EVT_NODE_METRICS_UPDATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node metrics updated.
EVT_NODE_SEGMENTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: local node segmented.
EVT_PAGE_REPLACEMENT_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: page replacement started in one of the data regions.
EVT_SERVICE_METHOD_EXECUTION_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: is raised in case of a service method execution failed.
EVT_SERVICE_METHOD_EXECUTION_FINISHED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: is raised right after a service method execution finished.
EVT_SERVICE_METHOD_EXECUTION_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: is raised right before a service method execution started.
EVT_SNAPSHOT_CHECK_FINISHED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot check finished.
EVT_SNAPSHOT_CHECK_STARTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot check started.
EVT_SNAPSHOT_COPYING_FINISHED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot copying finished.
EVT_SNAPSHOT_COPYING_STARTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot copying started.
EVT_SNAPSHOT_CREATION_FINISHED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot creation finished.
EVT_SNAPSHOT_CREATION_STARTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot creation started.
EVT_SNAPSHOT_DELETION_FINISHED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot deletion finished.
EVT_SNAPSHOT_DELETION_STARTED - Static variable in class org.gridgain.grid.events.EventType
Built-in event type: snapshot deletion started.
EVT_STORAGE_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
EVT_TASK_DEPLOY_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task deployment failed.
EVT_TASK_DEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task deployed.
EVT_TASK_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task failed.
EVT_TASK_FINISHED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task finished.
EVT_TASK_REDUCED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task reduced.
EVT_TASK_SESSION_ATTR_SET - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task session attribute set.
EVT_TASK_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task started.
EVT_TASK_TIMEDOUT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task timed out.
EVT_TASK_UNDEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task undeployed.
EVT_TX_COMMITTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been committed.
EVT_TX_RESUMED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been resumed.
EVT_TX_ROLLED_BACK - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been rolled back.
EVT_TX_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been started.
EVT_TX_SUSPENDED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been suspended.
EVT_WAL_SEGMENT_ARCHIVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: WAL segment movement to archive folder completed Fired for each completed WAL segment which was moved to archive NOTE: all types in range from 1 to 1000 are reserved for internal Ignite events and should not be used by user-defined events.
EVT_WAL_SEGMENT_COMPACTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: WAL archive segment compaction is completed.
EVTS_ALL - Static variable in interface org.apache.ignite.events.EventType
All Ignite events (including metric update event).
EVTS_ALL_MINUS_METRIC_UPDATE - Static variable in interface org.apache.ignite.events.EventType
All Ignite events (excluding metric update event).
EVTS_AUTHENTICATION - Static variable in class org.gridgain.grid.events.EventType
All authentication events.
EVTS_AUTHORIZATION - Static variable in class org.gridgain.grid.events.EventType
All authorization events.
EVTS_CACHE - Static variable in interface org.apache.ignite.events.EventType
All cache events.
EVTS_CACHE_LIFECYCLE - Static variable in interface org.apache.ignite.events.EventType
All cache lifecycle events.
EVTS_CACHE_QUERY - Static variable in interface org.apache.ignite.events.EventType
All cache query events.
EVTS_CACHE_REBALANCE - Static variable in interface org.apache.ignite.events.EventType
All cache rebalance events.
EVTS_CHECKPOINT - Static variable in interface org.apache.ignite.events.EventType
All checkpoint events.
EVTS_CLUSTER_ACTIVATION - Static variable in interface org.apache.ignite.events.EventType
All cluster activation events.
EVTS_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_DR - Static variable in class org.gridgain.grid.events.EventType
All dr events.
EVTS_ERROR - Static variable in interface org.apache.ignite.events.EventType
All events indicating an error or failure condition.
EVTS_JOB_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
All grid job execution events.
EVTS_LICENSE - Static variable in class org.gridgain.grid.events.EventType
All license events.
EVTS_SERVICE_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
All grid service execution events.
EVTS_SNAPSHOT - Static variable in class org.gridgain.grid.events.EventType
All snapshot events.
EVTS_TASK_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
All grid task execution events.
EVTS_TX - Static variable in interface org.apache.ignite.events.EventType
All Transaction events.
exception() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the connection exception that caused current retry iteration.
exchange - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Data exchange.
exchangelessSnapshot() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Exchangeless snapshot.
exclude(C...) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Exclude these coordinates from result vector.
excludedCacheNames() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Excluded cache names to check.
excludedCacheNames(Set<String>) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets excluded cache names from checking.
excludedCacheNames() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Collection of cache names excluded from this snapshot.
excludedCacheNames(Set<String>) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets collection of cache names excluded from this snapshot.
excludeNode(String) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Exclude node from discovery.
execName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
execute(ExecutionAssistant<V>) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Execute single synchronous operation against Cassandra database.
execute(BatchExecutionAssistant<R, V>, Iterable<? extends V>) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Executes batch asynchronous operation against Cassandra database.
execute(BatchLoaderAssistant) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Executes batch asynchronous operation to load bunch of records specified by CQL statement from Cassandra database
execute(List<Mutation>) - Method in interface org.apache.ignite.cache.store.cassandra.session.CassandraSession
Executes all the mutations performed withing Ignite transaction against Cassandra database.
execute(ExecutionAssistant<V>) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Execute single synchronous operation against Cassandra database.
execute(BatchExecutionAssistant<R, V>, Iterable<? extends V>) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Executes batch asynchronous operation against Cassandra database.
execute(BatchLoaderAssistant) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Executes batch asynchronous operation to load bunch of records specified by CQL statement from Cassandra database
execute(List<Mutation>) - Method in class org.apache.ignite.cache.store.cassandra.session.CassandraSessionImpl
Executes all the mutations performed withing Ignite transaction against Cassandra database.
execute(String, T) - Method in interface org.apache.ignite.client.ClientCompute
Executes given task within the cluster group.
execute() - Method in interface org.apache.ignite.compute.ComputeJob
Executes this job.
execute(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(Class<? extends ComputeTask<T, R>>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task on within the cluster group.
execute(ComputeTask<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task within the cluster group.
execute(String, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task within the cluster group.
execute() - Method in interface org.apache.ignite.maintenance.MaintenanceAction
Executes operations of current maintenance action and returns results.
execute() - Method in class org.apache.ignite.ml.genetic.CrossOverJob
Executes this job.
execute() - Method in class org.apache.ignite.ml.genetic.FitnessJob
Executes this job.
execute() - Method in class org.apache.ignite.ml.genetic.MutateJob
Executes this job.
execute() - Method in class org.apache.ignite.ml.genetic.RouletteWheelSelectionJob
Perform Roulette Wheel selection
execute() - Method in class org.apache.ignite.ml.genetic.TruncateSelectionJob
Executes this job.
execute(ServiceContext) - Method in interface org.apache.ignite.services.Service
Starts execution of this service.
execute(Object[]) - Method in class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery
@param values the values
execute(ServiceContext) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterMaintainer
Starts execution of this service.
execute(Runnable, int) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
Executes the given command at some time in the future.
execute(Runnable) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
executeAsync(String, T) - Method in interface org.apache.ignite.client.ClientCompute
Deprecated.
Use ClientCompute.executeAsync2(String, Object) instead. This method calls ClientCompute.executeAsync2(String, Object) internally, but returns a more limited Future interface.
executeAsync(Class<? extends ComputeTask<T, R>>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task asynchronously on within the cluster group.
executeAsync(ComputeTask<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task asynchronously within the cluster group.
executeAsync(String, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task asynchronously within the cluster group.
executeAsync2(String, T) - Method in interface org.apache.ignite.client.ClientCompute
Executes given task asynchronously within the cluster group.
executeTask(String, String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
A shortcut method that executes given task assuming single java.lang.String argument and java.lang.String return type.
ExecutionAssistant<R> - Interface in org.apache.ignite.cache.store.cassandra.session
Provides information for single operations (load, delete, write) of Ignite cache backed by CassandraCacheStore.
executionId() - Method in interface org.apache.ignite.services.ServiceContext
Gets service execution ID.
executions() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets total number execution of query.
executions() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets total number execution of query.
executions() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
executor() - Method in interface org.apache.ignite.plugin.extensions.communication.IoPool
Gets the Executor for this Pool.
EXECUTOR_SRVC_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ExecutorConfiguration - Class in org.apache.ignite.configuration
Custom thread pool configuration for compute tasks.
ExecutorConfiguration() - Constructor for class org.apache.ignite.configuration.ExecutorConfiguration
Default constructor.
ExecutorConfiguration(String) - Constructor for class org.apache.ignite.configuration.ExecutorConfiguration
Constructor.
ExecutorConfiguration(ExecutorConfiguration) - Constructor for class org.apache.ignite.configuration.ExecutorConfiguration
Copying constructor.
executorLost(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, int) - Method in class org.apache.ignite.mesos.IgniteScheduler
executorName() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
executorService() - Method in interface org.apache.ignite.Ignite
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on all cluster nodes.
executorService(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on nodes in the specified cluster group.
executorService() - Method in class org.apache.ignite.IgniteSpringBean
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on all cluster nodes.
executorService(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on nodes in the specified cluster group.
exists(BinaryObject) - Method in interface org.apache.ignite.binary.BinaryField
Check whether field exists in the object.
exists(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Returns true if a regular file or directory exist, otherwise false.
exists(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Returns true if a regular file or directory exist, otherwise false.
exists() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Checks that file exists.
existsById(K) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
exitRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
exitRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
exitRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
exitRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
exitRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
exitRule(ParseTreeListener) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
exitXgHeader(XGBoostModelParser.XgHeaderContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Exit a parse tree produced by XGBoostModelParser.xgHeader().
exitXgLeaf(XGBoostModelParser.XgLeafContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Exit a parse tree produced by XGBoostModelParser.xgLeaf().
exitXgModel(XGBoostModelParser.XgModelContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Exit a parse tree produced by XGBoostModelParser.xgModel().
exitXgNode(XGBoostModelParser.XgNodeContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Exit a parse tree produced by XGBoostModelParser.xgNode().
exitXgTree(XGBoostModelParser.XgTreeContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Exit a parse tree produced by XGBoostModelParser.xgTree().
exitXgValue(XGBoostModelParser.XgValueContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelListener
Exit a parse tree produced by XGBoostModelParser.xgValue().
EXP - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
EXP - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
expired() - Method in class org.apache.ignite.cache.store.cassandra.session.pool.IdleSession
Checks if Cassandra driver session expired.
expireDate() - Method in interface org.gridgain.grid.product.ProductLicense
Gets expire date.
expireTime() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's expire time.
expiry() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
expiryPolicyFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
ExponentialBackoffTimeoutStrategy - Class in org.apache.ignite.spi
Strategy which incorporates retriable network operation, handling of totalTimeout logic.
ExponentialBackoffTimeoutStrategy(long, long, long) - Constructor for class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
 
export() - Method in class org.apache.ignite.spi.metric.log.LogExporterSpi
Callback to do the export of metrics info.
export() - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Callback to do the export of metrics info.
Exportable<D> - Interface in org.apache.ignite.ml
Interface for exportable models(IgniteModel).
Exporter<D,P> - Interface in org.apache.ignite.ml
Exporter for models, D - model representation object, P - path to resources.
Extension - Interface in org.apache.ignite.plugin
Marker interface for extensions.
ExtensionRegistry - Interface in org.apache.ignite.plugin
Context that allows to register extensions.
externalizableAttributes() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
externalLabelToInternal(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBBinaryClassifierTrainer
Maps external representation of label to internal.
externalLabelToInternal(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBRegressionTrainer
Maps external representation of label to internal.
externalLabelToInternal(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Maps external representation of label to internal.
externalLbToInternalMapping - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
External label to internal mapping.
extract(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Extract LabeledVector from key and value.
extract(K, V) - Method in interface org.apache.ignite.ml.trainers.FeatureLabelExtractor
Extract LabeledVector from key and value.
extract(T) - Method in interface org.apache.ignite.stream.StreamMultipleTupleExtractor
Extracts a set of key-values from a message.
extract(T) - Method in interface org.apache.ignite.stream.StreamSingleTupleExtractor
Extracts a key-value tuple from a message.
extractFeatures(K, V) - Method in interface org.apache.ignite.ml.trainers.FeatureLabelExtractor
Extract features from key and value.
extractIdFromSnapshotDirName(String) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Get snapshot id from directory name.
ExtractionUtils - Class in org.apache.ignite.ml.dataset.feature.extractor
Class aggregates helper classes and shortcut-classes with default types and behaviour for Vectorizers.
ExtractionUtils() - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils
 
ExtractionUtils.ArrayLikeVectorizer<K,V> - Class in org.apache.ignite.ml.dataset.feature.extractor
Vectorizer extracting vectors from array-like structure with finite size and integer coordinates.
ExtractionUtils.DefaultLabelVectorizer<K,V,C extends Serializable> - Class in org.apache.ignite.ml.dataset.feature.extractor
Vectorizer with double-label containing on same level as feature values.
ExtractionUtils.IntCoordVectorizer<K,V> - Class in org.apache.ignite.ml.dataset.feature.extractor
Vectorizer with integer coordinates.
ExtractionUtils.StringCoordVectorizer<K,V> - Class in org.apache.ignite.ml.dataset.feature.extractor
Vectorizer with String-coordinates.
extractLabel(K, V) - Method in interface org.apache.ignite.ml.trainers.FeatureLabelExtractor
Extract label from key and value.
extractParameter(String, String, CacheAbstractJdbcStore.TypeKind, String, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get field value from object for use as query parameter.
extractParameter(String, String, CacheAbstractJdbcStore.TypeKind, String, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Get field value from object for use as query parameter.

F

f1Score() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns F1-Score is the harmonic mean of Precision and Sensitivity.
factory(MLLogger.VerboseLevel) - Static method in class org.apache.ignite.ml.environment.logging.ConsoleLogger
Returns an instance of ConsoleLogger factory.
factory(IgniteLogger) - Static method in class org.apache.ignite.ml.environment.logging.CustomMLLogger
Returns factory for OnIgniteLogger instantiating.
factory() - Static method in class org.apache.ignite.ml.environment.logging.NoOpLogger
Returns NoOpLogger factory.
FAILED_NODE_LIST_ATTR - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Name of job context attribute containing all nodes a job failed on.
failedKeys() - Method in exception org.apache.ignite.cache.CachePartialUpdateException
Gets collection of failed keys.
failNode(UUID, String) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
failover(FailoverContext, List<ClusterNode>) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
failover(FailoverContext, List<ClusterNode>) - Method in interface org.apache.ignite.spi.failover.FailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
failover(FailoverContext, List<ClusterNode>) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
failover(FailoverContext, List<ClusterNode>) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
FAILOVER_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
FailoverContext - Interface in org.apache.ignite.spi.failover
This interface defines a set of operations available to failover SPI one a given failed job.
failoverSafe() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
failoverSafe() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
FailoverSpi - Interface in org.apache.ignite.spi.failover
Failover SPI provides developer with ability to supply custom logic for handling failed execution of a grid job.
fails() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets total number of times a query execution failed.
FailureContext - Class in org.apache.ignite.failure
Failure context contains information about failure type and exception if applicable.
FailureContext(FailureType, Throwable) - Constructor for class org.apache.ignite.failure.FailureContext
Creates instance of FailureContext.
failureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns failure detection timeout set to use for network related operations.
failureDetectionTimeoutEnabled(boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Enables or disables failure detection timeout.
failureDetectionTimeoutEnabled() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Checks whether failure detection timeout is enabled for this IgniteSpi.
FailureHandler - Interface in org.apache.ignite.failure
Provides facility to handle failures by custom user implementations, which can be configured by IgniteConfiguration.setFailureHandler(FailureHandler) method.
FailureHandlingMxBean - Interface in org.apache.ignite.mxbean
MBean that controls critical failure handling.
failures() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets number of times a query execution failed.
failures() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
FailureType - Enum in org.apache.ignite.failure
Types of failures.
fair() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
fallOut() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Fall-out or False Positive Rate (FPR).
fdr() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns False Discovery Rate (FDR).
feature(String, K, BinaryObject) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Extracts feature value by given coordinate.
feature(Integer, K, double[]) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.DoubleArrayVectorizer
Extracts feature value by given coordinate.
feature(Integer, K, Vector) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.DummyVectorizer
Extracts feature value by given coordinate.
feature(Integer, K, LabeledVector<L>) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.LabeledDummyVectorizer
Extracts feature value by given coordinate.
feature(C, K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Extracts feature value by given coordinate.
feature(C, K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.VectorizerAdapter
Extracts feature value by given coordinate.
featureId - Variable in class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.BootstrappedVectorsHistogram
Feature id.
featureId - Variable in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogram
Feature id.
featureInSortedOrder(int, int) - Method in class org.apache.ignite.ml.tree.data.TreeDataIndex
Returns feature value for kth order statistic for target feature.
FeatureLabelExtractor<K,V,L> - Interface in org.apache.ignite.ml.trainers
Class fro extracting features and vectors from upstream.
FeatureMatrixWithLabelsOnHeapData - Class in org.apache.ignite.ml.dataset.primitive
A partition data of the containing matrix of features and vector of labels stored in heap.
FeatureMatrixWithLabelsOnHeapData(double[][], double[]) - Constructor for class org.apache.ignite.ml.dataset.primitive.FeatureMatrixWithLabelsOnHeapData
Constructs an instance of FeatureMatrixWithLabelsOnHeapData.
FeatureMatrixWithLabelsOnHeapDataBuilder<K,V,C extends Serializable,CO extends Serializable> - Class in org.apache.ignite.ml.dataset.primitive
A partition data builder that makes DecisionTreeData.
FeatureMatrixWithLabelsOnHeapDataBuilder(Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.dataset.primitive.FeatureMatrixWithLabelsOnHeapDataBuilder
Constructs a new instance of decision tree data builder.
FeatureMeta - Class in org.apache.ignite.ml.dataset.feature
Feature meta class.
FeatureMeta(String, int, boolean) - Constructor for class org.apache.ignite.ml.dataset.feature.FeatureMeta
Create an instance of Feature meta.
FeatureMetadata - Class in org.apache.ignite.ml.structures
Class for feature metadata.
FeatureMetadata() - Constructor for class org.apache.ignite.ml.structures.FeatureMetadata
Default constructor (required by Externalizable).
FeatureMetadata(String) - Constructor for class org.apache.ignite.ml.structures.FeatureMetadata
Creates an instance of Feature Metadata class.
features(int) - Method in class org.apache.ignite.ml.structures.Dataset
Get the features.
features() - Method in class org.apache.ignite.ml.structures.DatasetRow
Get the vector.
FeaturesCountSelectionStrategies - Class in org.apache.ignite.ml.tree.randomforest.data
Class contains a default implementations of some features count selection strategies for random forest.
FeaturesCountSelectionStrategies() - Constructor for class org.apache.ignite.ml.tree.randomforest.data.FeaturesCountSelectionStrategies
 
featuresInSortedOrder(int, int) - Method in class org.apache.ignite.ml.tree.data.TreeDataIndex
Returns vector of original features for kth order statistic for target feature.
fetchSize - Variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Fetch size.
field(String) - Method in interface org.apache.ignite.binary.BinaryObject
Gets field value.
field(String) - Method in interface org.apache.ignite.binary.BinaryType
Get BinaryField for the given field name.
field() - Method in interface org.apache.ignite.cache.query.IndexQueryCriterion
 
fieldId(int, String) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Get field ID.
fieldId(int, String) - Method in interface org.apache.ignite.binary.BinaryIdMapper
Gets ID for provided field name.
fieldName(String) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Gets field name.
fieldName(String) - Method in interface org.apache.ignite.binary.BinaryNameMapper
Gets field name.
fieldNames() - Method in interface org.apache.ignite.binary.BinaryType
Gets collection of all field names for this binary type.
fieldsCount() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Gets fields count.
FieldsQueryCursor<T> - Interface in org.apache.ignite.cache.query
SQL query result cursor.
fieldTypeName(String) - Method in interface org.apache.ignite.binary.BinaryType
Gets name of the field type for a given field.
FifoEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.fifo
Eviction policy based on First In First Out (FIFO) algorithm and supports batch eviction.
FifoEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Constructs FIFO eviction policy with all defaults.
FifoEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Constructs FIFO eviction policy with maximum size.
FifoEvictionPolicy(int, int) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Constructs FIFO eviction policy with maximum size and given batch size.
FifoEvictionPolicyFactory<K,V> - Class in org.apache.ignite.cache.eviction.fifo
Factory class for FifoEvictionPolicy.
FifoEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
Constructor.
FifoEvictionPolicyFactory(int) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
Constructor.
FifoEvictionPolicyFactory(int, int, long) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
 
FifoEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.fifo
MBean for FIFO eviction policy.
FifoQueueCollisionSpi - Class in org.apache.ignite.spi.collision.fifoqueue
This class provides implementation for Collision SPI based on FIFO queue.
FifoQueueCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
 
FifoQueueCollisionSpiMBean - Interface in org.apache.ignite.spi.collision.fifoqueue
Management bean that provides access to the FIFO queue collision SPI configuration.
file() - Static method in class org.gridgain.grid.persistentstore.SnapshotPath
 
FileDatabaseSnapshotSpi - Class in org.gridgain.grid.persistentstore.snapshot.file
File-based database snapshot SPI.
FileDatabaseSnapshotSpi() - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Default constructor.
FileExporter<D> - Class in org.apache.ignite.ml
Implementation of exporter to/from file.
FileExporter() - Constructor for class org.apache.ignite.ml.FileExporter
 
FileIndexMissingException - Exception in org.gridgain.grid.persistentstore.snapshot.file
The exception is used to inform about missing index in file snapshot.
FileIndexMissingException() - Constructor for exception org.gridgain.grid.persistentstore.snapshot.file.FileIndexMissingException
 
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.EchoingLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.java.JavaLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Returns current log file.
fileName() - Method in class org.apache.ignite.logger.jcl.JclLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.NullLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Gets name of the file being logged to if one is configured or null otherwise.
FileOrDirectory - Interface in org.apache.ignite.ml.inference.storage.model
Base interface for file or directory ModelStorageProvider works with.
FileParsingException - Exception in org.apache.ignite.ml.math.exceptions.knn
Shows non-parsed data in specific row by given file path.
FileParsingException(String, int, Path) - Constructor for exception org.apache.ignite.ml.math.exceptions.knn.FileParsingException
Creates new exception.
FileRespose - Class in org.apache.ignite.ml.inference.storage.model.thinclient
Response with file's data.
FileRespose(long, byte[]) - Constructor for class org.apache.ignite.ml.inference.storage.model.thinclient.FileRespose
Creates an instance of file response.
FilesListResponse - Class in org.apache.ignite.ml.inference.storage.model.thinclient
Response with list of files in directory.
FilesListResponse(long, Set<String>) - Constructor for class org.apache.ignite.ml.inference.storage.model.thinclient.FilesListResponse
Creates an instance of files list response.
FileSnapshot - Class in org.gridgain.grid.persistentstore.snapshot.file
NOTE: Not thread safe.
FileSnapshot(IgniteConfiguration, FileDatabaseSnapshotSpi, long, SnapshotPath, Collection<SnapshotPath>, IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>, boolean, boolean, SnapshotSecurityLevel, MessageDigestFactory, SnapshotRegistryTransformer, GridCacheSharedContext) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
 
FileSnapshotInputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
File-based snapshot input stream.
FileSnapshotOutputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
NIO FileChannel based SnapshotOutputStream.
FileSnapshotSession - Class in org.gridgain.grid.persistentstore.snapshot.file
File-based snapshot session.
filesNum() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
 
FileStat - Class in org.apache.ignite.ml.inference.storage.model
File statistics aggregator.
FileStat(boolean, long, int) - Constructor for class org.apache.ignite.ml.inference.storage.model.FileStat
Creates an instance of stat file.
FileStatResponse - Class in org.apache.ignite.ml.inference.storage.model.thinclient
File statistics repsponse.
FileStatResponse(long, FileStat) - Constructor for class org.apache.ignite.ml.inference.storage.model.thinclient.FileStatResponse
Create an instance of file statistics.
FileSystemModelReader - Class in org.apache.ignite.ml.inference.reader
Model reader that reads directory or file and serializes it using DirectorySerializer.
FileSystemModelReader(String) - Constructor for class org.apache.ignite.ml.inference.reader.FileSystemModelReader
Constructs a new instance of directory model reader.
fill(double, int) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Create new vector of specified size n with specified value.
FILL_CACHE_BATCH_SIZE - Static variable in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Size of batch for IgniteCache.putAll(Map).
fillCacheWith(double[][]) - Method in class org.apache.ignite.ml.util.SandboxMLCache
Fills cache with data and returns it.
fillCacheWith(MLSandboxDatasets) - Method in class org.apache.ignite.ml.util.SandboxMLCache
Fills cache with data and returns it.
fillCacheWithCustomKey(int, IgniteCache<K, LabeledVector<Double>>, Function<LabeledVector<Double>, K>) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Fills given cache with labeled vectors from this generator and user defined mapper from vectors to keys.
fillCacheWithVecHashAsKey(int, IgniteCache<Integer, LabeledVector<Double>>) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Fills given cache with labeled vectors from this generator as values and their hashcodes as keys.
fillCacheWithVecUUIDAsKey(int, IgniteCache<UUID, LabeledVector<Double>>) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Fills given cache with labeled vectors from this generator as values and random UUIDs as keys
fillKeyParameters(PreparedStatement, int, CacheAbstractJdbcStore.EntryMapping, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
fillKeyParameters(PreparedStatement, CacheAbstractJdbcStore.EntryMapping, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
fillParameter(PreparedStatement, int, JdbcTypeField, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets the value of the designated parameter using the given object.
fillValueParameters(PreparedStatement, int, CacheAbstractJdbcStore.EntryMapping, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
filter - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Filter.
filter(TreeFilter) - Method in class org.apache.ignite.ml.tree.data.DecisionTreeData
Filters objects and returns only data that passed filter.
filter(TreeFilter) - Method in class org.apache.ignite.ml.tree.data.TreeDataIndex
Creates projection of current index in according to TreeFilter.
filter(IgnitePredicate<Vector>) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Filters values of vector generator using predicate.
filter() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
filtrableAttributes() - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
 
FiltrableSystemView<R> - Interface in org.apache.ignite.spi.systemview.view
System view with filtering capabilities.
findAll() - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
findAllById(Iterable<K>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
findBestSplit() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
Returns best split point computed on histogram if it exists.
findBestSplit() - Method in interface org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityComputer
Returns best split point computed on histogram if it exists.
findBestSplit() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer.NodeImpurityHistograms
Find best split point, based on feature statistics.
findBestSplit() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
Returns best split point computed on histogram if it exists.
findById(K) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
findCurNodeSnapshotDir(T, long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
findKClosest(int, Vector) - Method in class org.apache.ignite.ml.knn.KNNModel
Finds k closest elements to the specified point.
findKClosest(int, Vector) - Method in class org.apache.ignite.ml.knn.utils.indices.ArraySpatialIndex
Finds k closest elements to the specified point.
findKClosest(int, Vector) - Method in class org.apache.ignite.ml.knn.utils.indices.BallTreeSpatialIndex
Finds k closest elements to the specified point.
findKClosest(int, Vector) - Method in class org.apache.ignite.ml.knn.utils.indices.KDTreeSpatialIndex
Finds k closest elements to the specified point.
findKClosest(int, Vector) - Method in interface org.apache.ignite.ml.knn.utils.indices.SpatialIndex
Finds k closest elements to the specified point.
findKeyType() - Method in class org.apache.ignite.cache.QueryEntity
Attempts to get key type from fields in case it was not set directly.
findLocalCurNodeSnapshotDir(long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
findLocalSnapshotDir(long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
findManager(Ignite) - Method in class org.apache.ignite.cache.CachingProvider
 
findMetric(String) - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricRegistry
 
findPropertyDescriptor(List<PropertyDescriptor>, String) - Static method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Extracts property descriptor from the descriptors list by its name.
findResource(String) - Method in 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.
findSnapshotDir(T, long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
findValueType() - Method in class org.apache.ignite.cache.QueryEntity
Attempts to get value type from fields in case it was not set directly.
finish() - Method in interface org.gridgain.grid.ru.GridGainRollingUpgrade
Disables rolling upgrade mode.
finish() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Allows disable rolling upgrade mode.
finishCopy(long, SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Removes copy marker file to indicate the end of copy operation.
finishTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
firstModel() - Method in class org.apache.ignite.ml.composition.combinators.sequential.ModelsSequentialComposition
Get first model.
fit(Ignite, IgniteCache<K, V>) - Method in class org.apache.ignite.ml.pipeline.Pipeline
Fits the pipeline to the input cache.
fit(Map<K, V>, int) - Method in class org.apache.ignite.ml.pipeline.Pipeline
Fits the pipeline to the input mock data.
fit(DatasetBuilder) - Method in class org.apache.ignite.ml.pipeline.Pipeline
Fits the pipeline to the input dataset builder.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.binarization.BinarizationTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.normalization.NormalizationTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Fits preprocessor.
fit(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Fits preprocessor.
fit(Ignite, IgniteCache<K, V>, Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, Ignite, IgniteCache<K, V>, Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, Map<K, V>, int, Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Fits preprocessor.
fit(Map<K, V>, int, Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Fits preprocessor.
fit(LearningEnvironmentBuilder, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerTrainer
Fits preprocessor.
fit(DatasetBuilder<Object, BinaryObject>, String, String, String) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Fits prediction model on a data storen in binary format.
fit(DatasetBuilder<K, ? extends ObjectSubjectRatingTriplet<O, S>>) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Fits prediction model.
fit(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fit(DatasetBuilder<K, V>, Preprocessor<K, V>, LearningEnvironment) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fit(Ignite, IgniteCache<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fit(Ignite, IgniteCache<K, V>, IgniteBiPredicate<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fit(Map<K, V>, int, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fit(Map<K, V>, IgniteBiPredicate<K, V>, int, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fit(Dataset<EmptyContext, DecisionTreeData>) - Method in class org.apache.ignite.ml.tree.DecisionTree
 
FitnessJob - Class in org.apache.ignite.ml.genetic
Responsible for performing fitness evaluation on an individual chromosome
FitnessJob(Long, IFitnessFunction) - Constructor for class org.apache.ignite.ml.genetic.FitnessJob
 
FitnessTask - Class in org.apache.ignite.ml.genetic
Responsible for fitness operation
FitnessTask(GAConfiguration) - Constructor for class org.apache.ignite.ml.genetic.FitnessTask
 
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.bagging.BaggedTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.combinators.parallel.TrainersParallelComposition
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.multiclass.OneVsRestTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionLSQRTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.tree.DecisionTree
Trains model based on the specified data.
fitWithInitializedDeployingContext(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Trains model based on the specified data.
flatten(double[][], int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
 
flush() - Method in interface org.apache.ignite.IgniteDataStreamer
Streams any remaining data, but doesn't close the streamer.
flush() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
flush() - Method in class org.apache.ignite.logger.log4j2.Log4jBridgeHandler
flush(String) - Method in interface org.gridgain.grid.GridDr
Flushes DR updates.
Fmeasure<L> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
F-measure calculator.
Fmeasure(L) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.Fmeasure
The class of interest or positive class.
fn() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
 
foldColumns(IgniteFunction<Vector, Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Collects the results of applying a given function to all columns in this matrix.
foldColumns(IgniteFunction<Vector, Double>) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Collects the results of applying a given function to all columns in this matrix.
foldMap(IgniteBiFunction<T, Double, T>, IgniteDoubleFunction<Double>, T) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Folds this matrix into a single value.
foldMap(IgniteBiFunction<T, Double, T>, IgniteDoubleFunction<Double>, T) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Folds this matrix into a single value.
foldMap(IgniteBiFunction<T, Double, T>, IgniteDoubleFunction<Double>, T) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Folds this vector into a single value.
foldMap(Vector, IgniteBiFunction<T, Double, T>, IgniteBiFunction<Double, Double, Double>, T) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Combines & maps two vector and folds them into a single value.
foldMap(IgniteBiFunction<T, Double, T>, IgniteDoubleFunction<Double>, T) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Folds this vector into a single value.
foldMap(Vector, IgniteBiFunction<T, Double, T>, IgniteBiFunction<Double, Double, Double>, T) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Combines & maps two vector and folds them into a single value.
foldMap(IgniteBiFunction<T, Double, T>, IgniteDoubleFunction<Double>, T) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Folds this vector into a single value.
foldMap(Vector, IgniteBiFunction<T, Double, T>, IgniteBiFunction<Double, Double, Double>, T) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Combines & maps two vector and folds them into a single value.
foldRows(IgniteFunction<Vector, Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Collects the results of applying a given function to all rows in this matrix.
foldRows(IgniteFunction<Vector, Double>) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Collects the results of applying a given function to all rows in this matrix.
forAttribute(String, Object) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a new cluster group for nodes containing given name and value specified in user attributes.
forAttribute(String, Object) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a new cluster group for nodes containing given name and value specified in user attributes.
forCache(String) - Method in interface org.apache.ignite.spi.indexing.IndexingQueryFilter
Creates optional predicate for cache.
forCache(String) - Method in class org.apache.ignite.spi.indexing.IndexingQueryFilterImpl
Creates optional predicate for cache.
forCacheNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for all nodes that have cache with specified name, either in client or server modes.
force() - Method in interface org.gridgain.grid.ru.GridGainRollingUpgrade
Enables forced mode of rolling upgrade.
force() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Allows enable force rolling upgrade mode.
forceCancelSnapshotOperation(IgniteUuid, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Tries to cancel an ongoing snapshot operation.
forceClientToServerConnections() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
forceDeleteSnapshot(long, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Deprecated.
forcedModeEnabled() - Method in class org.gridgain.grid.ru.GridRollingUpgradeStatus
 
forceFieldsQuery() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Force SqlFieldsQuery type, deactivating auto-detection based on SELECT statement.
forceMoveSnapshot(long, File, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Deprecated.
forceRestore() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
forceRestore(boolean) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets check snapshot for force restore or not, default is false.
forceRestore() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
forceRestore(boolean) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets flag indicating restore force: if newly created cache in group may be destroyed by this restore, default is false.
forClientNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for all client nodes that access cache with the specified name.
forClients() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group of nodes started in client mode.
forClients() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group of nodes started in client mode.
forDaemons() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a cluster group consisting from the daemon nodes.
forDataNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for all data nodes that have the cache with the specified name running.
forHost(ClusterNode) - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets cluster group consisting from the nodes in this cluster group residing on the same host (with the same MAC address) as the given node.
forHost(String, String...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets cluster group consisting from the nodes running on the hosts specified.
forHost(ClusterNode) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets cluster group consisting from the nodes in this cluster group residing on the same host as the given node.
forHost(String, String...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets cluster group consisting from the nodes running on the hosts specified.
forLocal() - Method in interface org.apache.ignite.IgniteCluster
Gets a cluster group consisting from the local node.
format(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFormatter
format(Ignite) - Method in class org.apache.ignite.tensorflow.cluster.spec.TensorFlowClusterSpec
Formats cluster specification so that TensorFlow accepts it.
format(Ignite) - Method in class org.apache.ignite.tensorflow.cluster.spec.TensorFlowServerAddressSpec
Formats Server Address specification so that TensorFlow accepts it.
format(TensorFlowServer, boolean, Ignite) - Method in class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServerScriptFormatter
Formats TensorFlow server specification so that it's available to be passed into а python script.
forNode(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for the given node.
forNode(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for the given node.
forNodeId(UUID, UUID...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for a node with the specified ID.
forNodeId(UUID, UUID...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for a node with the specified ID.
forNodeIds(Collection<UUID>) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group over nodes with specified node IDs.
forNodeIds(Collection<UUID>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group over nodes with specified node IDs.
forNodes(Collection<? extends ClusterNode>) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group over a given set of nodes.
forNodes(Collection<? extends ClusterNode>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group over a given set of nodes.
forOldest() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group with one oldest node from the current cluster group.
forOldest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one oldest node from the current cluster group.
forOthers(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for nodes other than the given nodes.
forOthers(ClientClusterGroup) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for nodes not included into the given cluster group.
forOthers(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for nodes other than the given nodes.
forOthers(ClusterGroup) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for nodes not included into the given cluster group.
forPredicate(Predicate<ClusterNode>) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a new cluster group which includes all nodes that pass the given predicate filter.
forPredicate(IgnitePredicate<ClusterNode>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a new cluster group which includes all nodes that pass the given predicate filter.
forRandom() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group with one random node from the current cluster group.
forRandom() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one random node from the current cluster group.
forRemotes() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets cluster group consisting from the nodes in this cluster group excluding the local node.
forServers() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group of nodes started in server mode.
forServers() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group of nodes started in server mode.
forSubjectId(UUID) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Creates projection for specified subject ID.
forwardPass(Matrix, MLPState, boolean) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Perform forward pass and if needed write state of outputs of each layer.
forYoungest() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group with one youngest node in the current cluster group.
forYoungest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one youngest node in the current cluster group.
fp() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
 
frameworkMessage(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, byte[]) - Method in class org.apache.ignite.mesos.IgniteScheduler
freeMemory(long) - Method in interface org.apache.ignite.mem.MemoryAllocator
Deallocates memory.
from(String) - Static method in class org.apache.ignite.mesos.ClusterProperties
 
from(CacheEntryProcessor<K, V, Object>) - Static method in class org.apache.ignite.stream.StreamTransformer
Creates a new transformer based on instance of CacheEntryProcessor.
from(IgniteBiInClosure<IgniteCache<K, V>, Map.Entry<K, V>>) - Static method in class org.apache.ignite.stream.StreamVisitor
Creates a new visitor based on instance of IgniteBiInClosure.
from(String) - Static method in class org.apache.ignite.yarn.ClusterProperties
 
from() - Static method in class org.apache.ignite.yarn.ClusterProperties
 
fromBytes(byte[]) - Method in class org.apache.ignite.cache.store.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.
fromDefaultAllow(boolean) - Static method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Static factory method for create new permission builder with specified defaultAllow permission
fromIndex(short) - Static method in enum org.apache.ignite.spi.tracing.Scope
Created Scope from it's index.
fromList(List<Vector>, boolean) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
 
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.cache.CachePeekMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheRebalanceMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheWriteSynchronizationMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.cache.PartitionLossPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.QueryIndexType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cluster.ClusterState
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.compute.ComputeJobResultPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.compute.ComputeTaskSessionScope
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.CheckpointWriteOrder
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.DataPageEvictionMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.DeploymentMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.DiskPageCompression
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.PageReplacementMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.WALMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.IgniteState
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.lifecycle.LifecycleEventType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.plugin.security.SecurityPermission
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.plugin.security.SecuritySubjectType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.plugin.segmentation.SegmentationPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.ShutdownPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.spi.IgnitePortProtocol
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.transactions.TransactionConcurrency
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.transactions.TransactionIsolation
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.transactions.TransactionState
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.cache.conflict.CacheConflictMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.cache.dr.CacheDrPauseReason
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.dr.DrReceiverLoadBalancingMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.dr.DrSenderConnectionState
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.dr.DrSenderLoadBalancingMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.dr.store.DrSenderStoreOverflowMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.persistentstore.SnapshotChainMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.persistentstore.SnapshotOperationType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.gridgain.grid.persistentstore.SnapshotSecurityLevel
Efficiently gets enumerated value from its ordinal.
fromQueryAnnotation(Query) - Static method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
From Query annotation.
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.
fromString(String) - Method in enum org.apache.ignite.ShutdownPolicy
Return shutdown policy matching to string.
fromUuid(UUID) - Static method in class org.apache.ignite.lang.IgniteUuid
Constructs new GridUuid based on global and local ID portions.
fstThrottlingMilliseconds() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets current amount of milliseconds the node waited during full state transfer due to load throttling.
FULL_VER_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
fullSnapshot() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Returns a flag indicating whether this snapshot was full.
fullTableName() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Get full table name.
Functions - Class in org.apache.ignite.ml.math.functions
Compatibility with Apache Mahout.
Functions() - Constructor for class org.apache.ignite.ml.math.functions.Functions
 
future() - Method in interface org.apache.ignite.IgniteCompute
Deprecated.
future() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets future for this streaming process.
future() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Deprecated.
since 2.0. Please use new specialized async method e.g.
     IgniteFuture f = cache.getAsync();
 
instead of old-style async API:
     IgniteCache asyncCache = cache.withAsync();
     asyncCache.get(key);
     IgniteFuture fut = asyncCache.future();
 
FutureWrapper(Future<T>) - Constructor for class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy.FutureWrapper
Create an instance of FutureWrapper.

G

GAConfiguration - Class in org.apache.ignite.ml.genetic.parameter
Maintains configuration parameters to be used in genetic algorithm
NOTE: Default selectionMethod is SELECTION_METHOD_TRUNCATION Default truncateRate is .10 More selectionMethods will be introduced in future releases.
GAConfiguration() - Constructor for class org.apache.ignite.ml.genetic.parameter.GAConfiguration
 
GAGrid - Class in org.apache.ignite.ml.genetic
Central class responsible for orchestrating distributive Genetic Algorithm.
GAGrid(GAConfiguration, Ignite) - Constructor for class org.apache.ignite.ml.genetic.GAGrid
 
GAGridConstants - Interface in org.apache.ignite.ml.genetic.parameter
GAGridConstants
GAGridConstants.SELECTION_METHOD - Enum in org.apache.ignite.ml.genetic.parameter
Selection Method type
GAGridFunction - Class in org.apache.ignite.ml.genetic.functions
Responsible for providing custom SQL functions to retrieve optimization results.
GAGridFunction() - Constructor for class org.apache.ignite.ml.genetic.functions.GAGridFunction
 
GAGridUtils - Class in org.apache.ignite.ml.genetic.utils
GA Grid Helper routines
GAGridUtils() - Constructor for class org.apache.ignite.ml.genetic.utils.GAGridUtils
 
gauss(Vector, Vector, Long) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of vectors from multidimension gauss distribution.
gauss(Vector, Vector) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of vectors from multidimension gauss distribution.
GaussianMixtureDataStream - Class in org.apache.ignite.ml.util.generators.standard
Data stream generator representing gaussian mixture.
GaussianMixtureDataStream.Builder - Class in org.apache.ignite.ml.util.generators.standard
Builder for gaussian mixture.
GaussianNaiveBayesModel - Class in org.apache.ignite.ml.naivebayes.gaussian
Simple naive Bayes model which predicts result value y belongs to a class C_k, k in [0..K] as {@code p(C_k,y) = p(C_k)*p(y_1,C_k) *...
GaussianNaiveBayesModel(double[][], double[][], double[], double[], GaussianNaiveBayesSumsHolder) - Constructor for class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
 
GaussianNaiveBayesTrainer - Class in org.apache.ignite.ml.naivebayes.gaussian
Trainer for the naive Bayes classification model.
GaussianNaiveBayesTrainer() - Constructor for class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
 
GaussRandomProducer - Class in org.apache.ignite.ml.util.generators.primitives.scalar
Pseudorandom producer generating values from gauss distribution.
GaussRandomProducer() - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.GaussRandomProducer
Creates an instance of GaussRandomProducer with mean = 0 and variance = 1.0.
GaussRandomProducer(long) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.GaussRandomProducer
Creates an instance of GaussRandomProducer with mean = 0 and variance = 1.0.
GaussRandomProducer(double, double) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.GaussRandomProducer
Creates an instance of GaussRandomProducer.
GaussRandomProducer(double, double, long) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.GaussRandomProducer
Creates an instance of GaussRandomProducer.
GDBBinaryClassifierOnTreesTrainer - Class in org.apache.ignite.ml.tree.boosting
Implementation of Gradient Boosting Classifier Trainer on trees.
GDBBinaryClassifierOnTreesTrainer(double, Integer, int, double) - Constructor for class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Constructs instance of GDBBinaryClassifierOnTreesTrainer.
GDBBinaryClassifierTrainer - Class in org.apache.ignite.ml.composition.boosting
Trainer for binary classifier using Gradient Boosting.
GDBBinaryClassifierTrainer(double, Integer) - Constructor for class org.apache.ignite.ml.composition.boosting.GDBBinaryClassifierTrainer
Constructs instance of GDBBinaryClassifierTrainer.
GDBBinaryClassifierTrainer(double, Integer, Loss) - Constructor for class org.apache.ignite.ml.composition.boosting.GDBBinaryClassifierTrainer
Constructs instance of GDBBinaryClassifierTrainer.
GDBLearningStrategy - Class in org.apache.ignite.ml.composition.boosting
Learning strategy for gradient boosting.
GDBLearningStrategy() - Constructor for class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
 
GDBModel(List<? extends IgniteModel<Vector, Double>>, WeightedPredictionsAggregator, IgniteFunction<Double, Double>) - Constructor for class org.apache.ignite.ml.composition.boosting.GDBTrainer.GDBModel
Creates an instance of GDBModel.
GDBOnTreesLearningStrategy - Class in org.apache.ignite.ml.tree.boosting
Gradient boosting on trees specific learning strategy reusing learning dataset with index between several learning iterations.
GDBOnTreesLearningStrategy(boolean) - Constructor for class org.apache.ignite.ml.tree.boosting.GDBOnTreesLearningStrategy
Create an instance of learning strategy.
GDBRegressionOnTreesTrainer - Class in org.apache.ignite.ml.tree.boosting
Implementation of Gradient Boosting Regression Trainer on trees.
GDBRegressionOnTreesTrainer(double, Integer, int, double) - Constructor for class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Constructs instance of GDBRegressionOnTreesTrainer.
GDBRegressionTrainer - Class in org.apache.ignite.ml.composition.boosting
Trainer for regressor using Gradient Boosting.
GDBRegressionTrainer(double, Integer) - Constructor for class org.apache.ignite.ml.composition.boosting.GDBRegressionTrainer
Constructs instance of GDBRegressionTrainer.
GDBTrainer - Class in org.apache.ignite.ml.composition.boosting
Abstract Gradient Boosting trainer.
GDBTrainer(double, Integer, Loss) - Constructor for class org.apache.ignite.ml.composition.boosting.GDBTrainer
Constructs GDBTrainer instance.
GDBTrainer.GDBModel - Class in org.apache.ignite.ml.composition.boosting
GDB model.
gemm(double, Matrix, Matrix, double, Matrix) - Static method in class org.apache.ignite.ml.math.Blas
For the moment we have no flags indicating if matrix is transposed or not.
gemv(double, Matrix, Vector, double, Vector) - Static method in class org.apache.ignite.ml.math.Blas
y := alpha * A * x + beta * y.
Gene - Class in org.apache.ignite.ml.genetic
Represents the discrete parts of a potential solution (ie: Chromosome) Gene is a container for a POJO that developer will implement.
Gene(Object) - Constructor for class org.apache.ignite.ml.genetic.Gene
object Object parameter.
GENE_CACHE - Static variable in interface org.apache.ignite.ml.genetic.parameter.GAGridConstants
populationCache constant
geneCache() - Static method in class org.apache.ignite.ml.genetic.cache.GeneCacheConfig
 
GeneCacheConfig - Class in org.apache.ignite.ml.genetic.cache
Cache configuration for GAGridConstants.GENE_CACHE cache maintains full population of genes.
GeneCacheConfig() - Constructor for class org.apache.ignite.ml.genetic.cache.GeneCacheConfig
 
generate() - Method in class org.apache.ignite.ml.selection.paramgrid.ParameterSetGenerator
Returns the list of tuples presented as arrays.
generateCacheKey(Object, CollectionPersister, SessionFactoryImplementor, String) - Method in class org.apache.ignite.cache.hibernate.IgniteCollectionDataAccess
 
generateCacheKey(Object, EntityPersister, SessionFactoryImplementor, String) - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
generateCacheKey(Object[], EntityPersister, SharedSessionContractImplementor) - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
generateCollectionAccess(CollectionDataCachingConfig) - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
generateCurNodeSnapshotFolderPath(long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
generateCurNodeSnapshotFolderPathWithLabel(T, long, String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Generate path with label for snapshot.
generateEntityAccess(EntityDataCachingConfig) - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
generateFeatureNames() - Method in class org.apache.ignite.ml.structures.Dataset
 
generateNaturalIdAccess(NaturalIdDataCachingConfig) - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
generateSnapshotDirName(long, String) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
!!!
generateSnapshotFolderPath(T, long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
generateSql(Method, RepositoryMetadata) - Static method in class org.apache.ignite.springdata22.repository.query.IgniteQueryGenerator
 
GenericBatchExecutionAssistant<R,V> - Class in org.apache.ignite.cache.store.cassandra.session
Implementation of the BatchExecutionAssistant.
GenericBatchExecutionAssistant() - Constructor for class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
 
GeneticAlgorithm - Class in org.apache.ignite.ml.util.genetic
This class is an entry point to use Genetic Algorithm to solve optimization problem.
GeneticAlgorithm(List<Double[]>) - Constructor for class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
get(SessionImplementor, Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves value mapped to the specified key from cache.
get(SessionImplementor, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
get(SharedSessionContractImplementor, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
get(CassandraSessionImpl) - Static method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
Extracts Cassandra driver session from pool.
get() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets current value of atomic long.
get(K) - Method in interface org.apache.ignite.client.ClientCache
Gets an entry from the cache.
get() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Synchronously waits for completion of the computation and returns computation result.
get(long, TimeUnit) - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long.
get() - Method in interface org.apache.ignite.IgniteAtomicReference
Gets current value of an atomic reference.
get() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets current value of atomic sequence.
get() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets both current value and current stamp of atomic stamped.
get(K) - Method in interface org.apache.ignite.IgniteCache
get(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
get() - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation and returns computation result.
get(long) - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get(long, TimeUnit) - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get() - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy.FutureWrapper
get(long, TimeUnit) - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy.FutureWrapper
get() - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy.Stub
get(long, TimeUnit) - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy.Stub
get(String) - Method in class org.apache.ignite.ml.inference.storage.descriptor.IgniteModelDescriptorStorage
Returns model descriptor saved for the specified model identifier.
get(String) - Method in class org.apache.ignite.ml.inference.storage.descriptor.LocalModelDescriptorStorage
Returns model descriptor saved for the specified model identifier.
get(String) - Method in interface org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorage
Returns model descriptor saved for the specified model identifier.
get(String) - Method in class org.apache.ignite.ml.inference.storage.model.IgniteModelStorageProvider
Returns file or directory associated with the specified path.
get(String) - Method in class org.apache.ignite.ml.inference.storage.model.LocalModelStorageProvider
Returns file or directory associated with the specified path.
get(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorageProvider
Returns file or directory associated with the specified path.
get(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the matrix value at the provided location.
get() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix.Element
Gets element's value.
get(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the matrix value at the provided location.
get(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
 
get(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
get(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
get(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
get(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the value at specified index.
get(String) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
Returns element with specified string index.
get(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the value at specified index.
get(String) - Method in interface org.apache.ignite.ml.math.primitives.vector.NamedVector
Returns element with specified string index.
get(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
Gets element from vector by index and cast it to double.
get(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
Gets element from vector by index and cast it to double.
get(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
Gets element from vector by index and cast it to double.
get(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
Gets element from vector by index and cast it to double.
get() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector.Element
Gets element's value.
get(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the value at specified index.
get(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
Gets element from vector by index and cast it to double.
get(int) - Method in class org.apache.ignite.ml.structures.DatasetRow
Gets the value at specified index.
get() - Method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
get() - Method in class org.apache.ignite.ml.util.generators.primitives.scalar.GaussRandomProducer
get() - Method in class org.apache.ignite.ml.util.generators.primitives.scalar.UniformRandomProducer
get() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.ParametricVectorGenerator
get() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily
get() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Waits for the completion of the next scheduled execution and returns its result.
get(long, TimeUnit) - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Waits for the completion of the next scheduled execution for specified amount of time and returns its result.
get(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets object from cache.
get(TracingConfigurationCoordinates) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Get the most specific tracing parameters for the specified tracing coordinates (scope, label, etc.).
get(K) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Gets an entry from the cache.
get(K) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Gets an entry from the cache.
get(K) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Gets an entry from the cache.
get() - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowProcessBuilderSupplier
get() - Method in class org.apache.ignite.tensorflow.core.util.PythonProcessBuilderSupplier
get1() - Method in class org.apache.ignite.lang.IgniteBiTuple
Gets first value.
get2() - Method in class org.apache.ignite.lang.IgniteBiTuple
Gets second value.
getAbsolutePath() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Gets absolute path.
getAbsWalSegmentIdx() - Method in class org.apache.ignite.events.WalSegmentArchivedEvent
 
getAccessKey() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets S3 access key.
getAccessKey() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
getAccessType() - Method in class org.apache.ignite.cache.hibernate.IgniteCollectionDataAccess
 
getAccessType() - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
getAccessType() - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
getAccountToken() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Get Kubernetes account token.
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.
getAckSendThresholdBytes() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets accrued size of received messages per connection to node after which acknowledgment message is sent.
getAckSendThresholdMillis() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets number of milliseconds after which acknowledgment is sent (if there are unacked messages).
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.
getAcond() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getActiveBaselineNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of active baseline nodes.
getActiveCount() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getActiveCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the approximate number of threads that are actively executing tasks.
getActiveEntriesCount() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets sum of Cursor.active.size() for all Cursors created for this Store.
getActiveJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getActiveJobsThreshold() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets number of jobs that can be executed in parallel.
getActiveTransactions(Long, Integer, String, String, String, String, Integer, String, boolean, boolean) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
 
getAddresses() - Method in interface org.apache.ignite.client.ClientAddressFinder
Get addresses of Ignite server nodes within a cluster.
getAddresses() - Method in class org.apache.ignite.client.ThinClientKubernetesAddressFinder
Get addresses of Ignite server nodes within a cluster.
getAddresses() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getAddresses() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getAddressesFinder() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getAddressRequestAttempts() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets number of attempts to send multicast address request.
getAddressResolver() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets address resolver for addresses mapping determination.
getAddressResolver() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets address resolver.
getAffinity() - Method in class org.apache.ignite.configuration.AtomicConfiguration
Gets atomic cache affinity function.
getAffinity() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets key topology resolver to provide mapping from keys to nodes.
getAffinityBackupFilter() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets optional backup filter.
getAffinityKey() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets affinity key used for key-to-node affinity calculation.
getAffinityKeyFieldName() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
Gets affinity key field name.
getAffinityKeyFieldName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getAffinityMapper() - Method in class org.apache.ignite.configuration.CacheConfiguration
Affinity key mapper used to provide custom affinity key for any given key.
getAffinityPartitionsAssignmentMap() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets affinity partitions assignment map.
getAlgorithmCode() - Method in interface org.gridgain.grid.persistentstore.MessageDigestFactory
 
getAlias() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets table alias for type.
getAliases() - Method in class org.apache.ignite.cache.QueryEntity
Gets aliases map.
getAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves values mapped to the specified keys from cache.
getAll() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Gets all query results and stores them in the collection.
getAll() - Method in interface org.apache.ignite.cache.query.QueryCursor
Gets all query results and stores them in the collection.
getAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Gets a collection of entries from the ClientCache, returning them as Map of the values associated with the set of keys requested.
getAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets a collection of entries from the Cache, returning them as Map of the values associated with the set of keys requested.
getAll(Scope) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
List all pairs of tracing configuration coordinates and tracing configuration parameters or list all pairs of tracing configuration and parameters for the specific scope.
getAll(Set<? extends K>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Gets a collection of entries from the Ignite cache, returning them as Map of the values associated with the set of keys requested.
getAll(Set<? extends K>) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Gets a collection of entries from the Ignite cache, returning them as Map of the values associated with the set of keys requested.
getAll(Set<? extends K>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Gets a collection of entries from the Ignite cache, returning them as Map of the values associated with the set of keys requested.
getAll() - Method in class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery.QueryCursorWrapper
Gets all query results and stores them in the collection.
getAllAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves values mapped to the specified keys from cache.
getAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Gets a collection of entries from the ClientCache, returning them as Map of the values associated with the set of keys requested.
getAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets a collection of entries from the Cache, returning them as Map of the values associated with the set of keys requested.
getAllClusters() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Returns list of maintained TensorFlow clusters.
getAllocationRate() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets pages allocation rate of a memory region.
getAllOutTx(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets values from cache.
getAllOutTx(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets values from cache.
getAllOutTxAsync(Set) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets values from cache.
getAllOutTxAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets values from cache.
getAllOwnerTransactions() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
All near transactions
getAllOwnerTransactions() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets a map of all transactions for which the local node is the originating node.
getAmountOfClusters() - Method in interface org.apache.ignite.ml.clustering.kmeans.ClusterizationModel
Gets the clusters count.
getAmountOfClusters() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Gets the clusters count.
getAmountOfClusters() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Gets the amount of clusters.
getAmountOfEliteChromosomes() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getAmountOfGenerations() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getAmountOfIterations() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Get the amount of outer iterations of SCDA algorithm.
getAmountOfLocIterations() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Get the amount of local iterations of SCDA algorithm.
getAndAdd(long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets current value of atomic long and adds l.
getAndAdd(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long and adds l.
getAndAdd(long) - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets current value of atomic sequence and adds l elements.
getAndDecrement() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets and decrements current value of atomic long.
getAndDecrement() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets and decrements current value of atomic long.
getAndIncrement() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets and increments current value of atomic long.
getAndIncrement() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets and increments current value of atomic long.
getAndIncrement() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets and increments current value of atomic sequence.
getAndPut(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache.
getAndPut(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in this cache, returning an existing value if one existed.
getAndPut(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndPutAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache.
getAndPutAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in this cache, returning an existing value if one existed.
getAndPutAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified value with the specified key in this cache, returning an existing value if one existed as the future result.
getAndPutIfAbsent(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if cache had no previous mapping for it.
getAndPutIfAbsent(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
getAndPutIfAbsent(K, V) - Method in interface org.apache.ignite.IgniteCache
Stores given key-value pair in cache only if cache had no previous mapping for it.
getAndPutIfAbsentAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
getAndPutIfAbsentAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
getAndPutIfAbsentAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
getAndRemove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mapping from cache.
getAndRemove(K) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the entry for a key only if currently mapped to some value.
getAndRemove(K) - Method in interface org.apache.ignite.IgniteCache
getAndRemoveAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mapping from cache.
getAndRemoveAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the entry for a key only if currently mapped to some value.
getAndRemoveAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the entry for a key only if currently mapped to some value.
getAndReplace(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if there is a previous mapping for it.
getAndReplace(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the value for a given key if and only if there is a value currently mapped by the key.
getAndReplace(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndReplaceAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if there is a previous mapping for it.
getAndReplaceAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the value for a given key if and only if there is a value currently mapped by the key.
getAndReplaceAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously replaces the value for a given key if and only if there is a value currently mapped by the key.
getAndSet(long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets current value of atomic long and sets new value l of atomic long.
getAndSet(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long and sets new value l of atomic long.
getAnnotation(Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Returns POJO field annotation.
getAnnotation(Class) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns POJO field annotation.
getAnnotation() - Method in class org.apache.ignite.springdata22.repository.config.IgniteRepositoriesRegistar
getAnorm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getApplicationContext() - Method in class org.apache.ignite.IgniteSpringBean
Gets the spring application context this Ignite runs in.
getArchiveFile() - Method in class org.apache.ignite.events.WalSegmentArchivedEvent
 
getArchSupplier() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the multilayer perceptron architecture supplier that defines layers and activators.
getArgs() - Method in class org.apache.ignite.cache.query.SpiQuery
Gets SQL arguments.
getArgs() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets SQL arguments.
getArgs() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets SQL arguments.
getArnorm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getAssemblies() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
getAsString() - Method in interface org.apache.ignite.spi.metric.BooleanMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.DoubleMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.IntMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.LongMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.Metric
 
getAsString() - Method in interface org.apache.ignite.spi.metric.ObjectMetric
getAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves value mapped to the specified key from cache.
getAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Gets an entry from the cache asynchronously.
getAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets an entry from the cache.
getAsyncCallbackPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing asynchronous callbacks.
getAsyncContinuationExecutor() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the async continuation executor.
getAsyncContinuationExecutor() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets the continuation executor for cache async APIs.
getAsyncModel(Ignite, String, AsyncModelBuilder) - Static method in class org.apache.ignite.ml.inference.IgniteModelStorageUtil
Retrieves Ignite model by name using asynchronous model builder.
getATN() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getATN() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
getAtomicConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache atomicity mode.
getAtomicityMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getAtomicSequenceReserveSize() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets default number of sequence values reserved for IgniteAtomicSequence instances.
getAtomicSequenceReserveSize() - Method in class org.apache.ignite.configuration.AtomicConfiguration
Gets default number of sequence values reserved for IgniteAtomicSequence instances.
getAttribute(K) - Method in interface org.apache.ignite.compute.ComputeJobContext
Gets attribute from this job context.
getAttribute(K) - Method in interface org.apache.ignite.compute.ComputeTaskSession
getAttribute(String) - Method in interface org.apache.ignite.ml.math.MetaAttributes
Gets meta attribute with given name.
getAttribute(String) - Method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
getAttributeNames() - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
Gets attribute names.
getAttributes() - Method in interface org.apache.ignite.compute.ComputeJobContext
Gets all attributes present in this job context.
getAttributes() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets all attributes.
getAttributes(String[]) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
getAuthenticator() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getAuthenticator() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Should return fully configured authentication implementation.
getAutoAdjustmentTimeout() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
getAvailableSnapshotMetrics() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets the number of recorded snapshot metrics.
getAverageActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of active jobs concurrently executing on the node.
getAverageActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of active jobs concurrently executing on the node.
getAverageCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of cancelled jobs this node ever had running concurrently.
getAverageCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of cancelled jobs this node ever had running concurrently.
getAverageCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average of CPU load values over all metrics kept in the history.
getAverageCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average of CPU load values over all metrics kept in the history.
getAverageFitness() - Method in class org.apache.ignite.ml.util.genetic.Population
Returns the average fitness of population or Double.NaN if not all fitnesses are calculated for all chromosomes.
getAverageGetTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute gets.
getAverageGetTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The mean time to execute gets.
getAverageJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average time a job takes to execute on the node.
getAverageJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average time a job takes to execute on the node.
getAverageJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average time jobs spend waiting in the queue to be executed.
getAverageJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average time jobs spend waiting in the queue to be executed.
getAveragePutTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute puts.
getAveragePutTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The mean time to execute puts.
getAverageRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of jobs this node rejects during collision resolution operations.
getAverageRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of jobs this node rejects during collision resolution operations.
getAverageRemoveTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute removes.
getAverageRemoveTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
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
Deprecated.
The mean time to execute tx rollbacks.
getAverageWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of waiting jobs this node had queued.
getAverageWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of waiting jobs this node had queued.
getAvgMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets avg message processing time.
getAvgMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets avg message processing time.
getBackupFilter() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets optional backup filter.
getBackups() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets the number of backup nodes.
getBackups() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getBackups() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getBackups() - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
getBackups() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets number of nodes used to back up single partition for CacheMode.PARTITIONED cache.
getBackups() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getBackups() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of backups configured for this cache group.
getBackupSyncFrequency() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets backup part's DR state synchronization frequency.
getBalancedNode(ComputeJob, Collection<ClusterNode>) - Method in interface org.apache.ignite.compute.ComputeLoadBalancer
Gets the next balanced node according to the underlying load balancing policy.
getBalancedNode(List<ClusterNode>) - Method in interface org.apache.ignite.spi.failover.FailoverContext
Gets the next balanced node for failed job.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Gets balanced node for specified job within given task session.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in interface org.apache.ignite.spi.loadbalancing.LoadBalancingSpi
Gets balanced node for specified job within given task session.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Gets balanced node for specified job within given task session.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Gets balanced node for specified job within given task session.
getBasePath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
getBatchQueueSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns batch queue size.
getBatchSendFrequency() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets batch send frequency.
getBatchSendSize() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
getBatchSendSizeBytes() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets batch send size in bytes.
getBatchSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets batch size.
getBatchSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Gets batch size.
getBatchSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets batch size.
getBatchSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets batch size.
getBatchSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets batch size.
getBatchSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns batch size.
getBatchSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get maximum batch size for delete and delete operations.
getBatchSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Get maximum batch size for delete and delete operations.
getBatchSize() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the batch size (per every partition).
getBatchSize() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Get the batch size.
getBatchSize() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Get the batch size.
getBatchSize() - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
getBest(String) - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
Gets the best value for the specific hyper parameter.
getBestAvgScore() - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
Gets the the average value of best score array.
getBestHyperParams() - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
Gets the best hyper parameters set.
getBestScore() - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
Gets the best score for the specific hyper parameter.
getBias() - Method in class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
 
getBinaryConfiguration() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getBinaryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configuration for Ignite Binary objects.
getBinaryConfiguration() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
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.
getBucketEndpoint() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets S3 bucket endpoint to use.
getBucketEndpoint() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
getBucketId(Double) - Method in class org.apache.ignite.ml.dataset.feature.BucketMeta
Returns bucket id for feature value.
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.
getBucketThresholds() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
 
getBuildIndexThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool for create/rebuild index.
getBusyTimePercentage() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets percentage of time this node is busy executing jobs vs. idling.
getBusyTimePercentage() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets percentage of time this node is busy executing jobs vs. idling.
getBytesWritten() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Total size of all pages in bytes during snapshot creation (before/without compression).
getBytesWritten(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Total size of bytes during snapshot creation.
getCache(String, Class<K>, Class<V>) - Method in class org.apache.ignite.cache.CacheManager
getCache(String) - Method in class org.apache.ignite.cache.CacheManager
getCache(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
getCacheConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configuration (descriptors) for all caches.
getCacheDataDescription() - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
getCacheEntryListenerConfigurations() - Method in class org.apache.ignite.configuration.CacheConfiguration
getCacheEvictions() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of evictions from the cache.
getCacheEvictions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
The total number of requests to the cache.
getCacheGroupLogicalReads(String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of logical page reads for given cache group.
getCacheGroupPhysicalReads(String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of physical page reads for given cache group.
getCacheGroupStatistics(String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets string presentation of cache group IO statistics for given cache group.
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
Deprecated.
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
Deprecated.
The number of get requests that were satisfied by the cache.
getCacheKeyConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets cache key configuration.
getCacheKeyId(Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCollectionDataAccess
 
getCacheKeyId(Object) - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
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
Deprecated.
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
Deprecated.
Returns the percentage of cache accesses that did not find a requested entry in the cache.
getCacheMode() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets the cache mode.
getCacheMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getCacheMode() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getCacheMode() - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
getCacheMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets caching mode to use.
getCacheMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getCacheName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets associated cache name.
getCacheName() - Method in class org.apache.ignite.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..
getCacheName() - Method in class org.gridgain.grid.persistentstore.SnapshotIssue
 
getCacheNames() - Method in class org.apache.ignite.cache.CacheManager
getCacheNames() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
getCacheNames() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Deprecated.
getCacheNames() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets cache names this sender hub works with.
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
Deprecated.
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
Deprecated.
The total number of removals from the cache.
getCaches() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets list of cache names of this cache group.
getCacheSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Cache size.
getCacheSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Cache size.
getCacheStoreFactory() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets factory for underlying persistent storage for read-through and write-through operations.
getCacheStoreSessionListenerFactories() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache store session listener factories.
getCacheStoreSessionListenerFactories() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets cache store session listener factories.
getCacheTxCommits() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets total number of transaction commits.
getCacheTxCommits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
Gets total number of transaction rollbacks.
getCachingProvider() - Method in class org.apache.ignite.cache.CacheManager
getCallbackHandlerFactoryFormatted() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Gets JAAS-authentication callback handler factory name.
getCallbackHandlerFactoryFormatted() - Method in interface org.gridgain.grid.security.jaas.JaasAuthenticatorMBean
Gets JAAS-authentication callback handler factory name.
getCandidates() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
 
getCandidates() - Method in class org.apache.ignite.ml.knn.ann.ANNModelFormat
 
getCassandraColumnValue(Row, String, Class, Serializer) - Static method in class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
Returns value of specific column in the row returned by CQL statement.
getCassandraType(Class) - Static method in class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
Maps Cassandra type to specified Java type.
getCause(Class<T>) - Method in exception org.apache.ignite.IgniteCheckedException
Gets first exception of given class from 'cause' hierarchy if any.
getCause(Class<T>) - Method in exception org.apache.ignite.IgniteException
Gets first exception of given class from 'cause' hierarchy if any.
getCause(Class<T>) - Method in exception org.apache.ignite.IgniteIllegalStateException
Gets first exception of given class from 'cause' hierarchy if any.
getCenters() - Method in interface org.apache.ignite.ml.clustering.kmeans.ClusterizationModel
Get cluster centers.
getCenters() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Get cluster centers.
getCenters() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModelFormat
 
getCentroidStat() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer.TotalCostAndCounts
 
getCentroindsStat() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
 
getChannelNames() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getCheckpointBufferSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets checkpoint buffer size in bytes.
getCheckpointBufferSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Checkpoint buffer size in bytes.
getCheckpointBufferSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets checkpoint buffer size in bytes.
getCheckpointBufferSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Checkpoint buffer size in bytes.
getCheckpointFrequency() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets checkpoint frequency.
getCheckpointFrequency() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets checkpoint creation frequency.
getCheckpointingFrequency() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets checkpointing frequency.
getCheckpointingPageBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets amount of memory allocated for a checkpointing temporary buffer.
getCheckpointingThreads() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a number of threads to use for the checkpointing purposes.
getCheckpointPageBufferSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets amount of memory allocated for a checkpoint temporary buffer.
getCheckpointReadLockTimeout() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Returns timeout for checkpoint read lock acquisition.
getCheckpointReadLockTimeout() - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
getCheckpointSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured checkpoint SPI implementation.
getCheckpointSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getCheckpointTableName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets checkpoint table name.
getCheckpointTableName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets checkpoint table name.
getCheckpointThreads() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a number of threads to use for the checkpoint purposes.
getCheckpointTotalTime() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Total checkpoint time from last restart.
getCheckpointTotalTime() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Total checkpoint time from last restart.
getCheckpointWriteOrder() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property defines order of writing pages to disk storage during checkpoint.
getCheckpointWriteOrder() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property defines order of writing pages to disk storage during checkpoint.
getChiefException(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Returns an exception that happened during execution or null if there is no exception.
getChromosome(int) - Method in class org.apache.ignite.ml.util.genetic.Population
Returns an individual chromosome.
getChromosome(Integer) - Method in class org.apache.ignite.ml.util.genetic.Population
Returns the chromosome by given index.
getChromosomeCriteria() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
retrieve the ChromosomeCriteria
getChromosomeLen() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve the chromosome length
getChromosomes(Ignite, String) - Static method in class org.apache.ignite.ml.genetic.utils.GAGridUtils
Retrieve chromosomes
getCipherSuites() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets cipher suites.
getCipherSuites() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets enabled cipher suites.
getClass(int, ClassLoader) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Gets class for provided type ID.
getClassFilter() - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
getClassLoader() - Method in class org.apache.ignite.cache.CacheManager
getClassLoader() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets class loader responsible for loading all classes within task.
getClassLoader() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getClassLoader() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource class loader.
getClassLoader() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource class loader.
getClassName() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Gets class name to use.
getClassName(byte, int) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Gets class name for provided (platformId, typeId) pair.
getClassProbabilities() - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
 
getClassVoteForVector(boolean, double) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
 
getClassWithMaxVotes(Map<Double, Double>) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
 
getClientConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets client connector configuration.
getClientFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns failure detection timeout for client nodes used by TcpDiscoverySpi and TcpCommunicationSpi.
getClsProbabilities() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
 
getCluster(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGatewayManager
Subscribes on changes of the specified cluster.
getCluster(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Returns cluster by identifier.
getClusteringDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns Cassandra DDL for cluster key.
getClusterMovingPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of partitions with state MOVING for this cache group in the entire cluster.
getClusterOwningPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of partitions with state OWNING for this cache group in the entire cluster.
getClusterSpec() - Method in class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
 
getClusterState() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Checks cluster state.
getClusterStateOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets state of cluster on start.
getCntOfValues() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.MeanValueStatistic
 
getCodecRegistry() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getCol(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Get a specific row from matrix.
getCol(int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Get a specific row from matrix.
getCol() - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
getCollisionSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured collision SPI implementation.
getCollisionSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getColumn() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns Cassandra table column name where object should be persisted in case of using BLOB or PRIMITIVE persistence strategy.
getColumn() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
 
getColumnDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
 
getColumnDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
getColumns() - Method in class org.apache.ignite.ml.math.isolve.lsqr.AbstractLSQR
 
getColumns() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQROnHeap
Returns number of columns in dataset.
getColumnsCount() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Gets number of columns in a row.
getColumnsCount() - Method in interface org.apache.ignite.cache.query.FieldsQueryCursor
Gets number of columns in a row.
getColumnValue(ResultSet, int, Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer
Retrieves the value of the designated column in the current row of this ResultSet object and will convert to the requested Java data type.
getColumnValue(ResultSet, int, Class<?>) - Method in interface org.apache.ignite.cache.store.jdbc.JdbcTypesTransformer
Retrieves the value of the designated column in the current row of this ResultSet object and will convert to the requested Java data type.
getCommands() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowJobArchive
 
getCommErrorProcNum() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets number of communication resolver called.
getCommunicationFailureResolver() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getCommunicationSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured SPI communication implementation.
getCommunicationSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getComp() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
Gets entries comparator.
getCompactBufferSize() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets compact buffer size.
getCompletedTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the approximate total number of tasks that have completed execution.
getComponentClass() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
getCompositionWeights() - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
 
getCompressionLevel() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Returns compression level, as per Zstandard library.
getCompressionLevel() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Compression level.
getCompressionOption() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
getConcurrencyLevel() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Returns the number of concurrent segments in Ignite internal page mapping tables.
getConcurrencyLevel() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Returns the number of concurrent segments in Ignite internal page mapping tables.
getConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets configuration bean.
getConfiguration() - Method in interface org.apache.ignite.client.ClientCache
 
getConfiguration(Class<C>) - Method in interface org.apache.ignite.IgniteCache
getConfiguration() - Method in class org.apache.ignite.IgniteSpringBean
Gets the configuration of this Ignite instance.
getConfiguration() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets configuration bean.
getConfiguration() - Method in interface org.gridgain.grid.dr.DrSender
Get sender configuration.
getConfiguration() - Method in interface org.gridgain.grid.dr.DrSenderConnection
Get connection configuration.
getConfigurationAsync() - Method in interface org.apache.ignite.client.ClientCache
Gets the cache configuration asynchronously.
getConfigurationPath() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets configuration file path.
getConfigurationPath() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets configuration file path.
getConflictResolver() - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Gets conflict resolver.
getConflictResolverMode() - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Gets conflict resolver mode.
getConflictsMessage() - Method in class org.apache.ignite.cache.QueryEntityPatch
 
getConnection() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getConnection(String, String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getConnectionCheckInterval() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets connection check interval in ms.
getConnectionConfiguration() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Get remote data center connection configurations.
getConnectionRecoveryTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets timeout that defines how long server node would try to recovery connection.
getConnections() - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Returns list of active connections.
getConnectionsPerNode() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets number of connections to each remote node. if TcpCommunicationSpiMBean.isUsePairedConnections() is true then number of connections is doubled and half is used for incoming and half for outgoing messages.
getConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getConnectTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets connect timeout used when establishing connection with remote nodes.
getConnectTimeout() - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Gets connect timeout.
getConsistencyLevel() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentId() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets consistent globally unique node ID which survives node restarts.
getContainers() - Method in class org.apache.ignite.yarn.ApplicationMaster
Deprecated.
getContext() - Method in class org.apache.ignite.marshaller.AbstractMarshaller
 
getContext(Ignite, String, int) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Extracts partition context from the Ignite Cache.
getCoordinator() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
getCoordinator() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets current coordinator.
getCoordinator() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets current coordinator.
getCoordinatorNodeFormatted() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets current coordinator node formatted as a string.
getCoordinatorSinceTimestamp() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets time local node has been coordinator since.
getCoordinatorSinceTimestamp() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets time local node has been coordinator since.
getCopiedOriginalLabels() - Method in class org.apache.ignite.ml.tree.data.DecisionTreeData
 
getCopyright() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getCorePoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the core number of threads.
getCriteria() - Method in class org.apache.ignite.cache.query.IndexQuery
Index query criteria.
getCriteria() - Method in class org.apache.ignite.ml.genetic.parameter.ChromosomeCriteria
Retrieve criteria
getCrossingoverProbability() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getCrossOverRate() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve the cross over rate
getCrossoverStgy() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getCtx() - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDataset
 
getCurrentActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of currently active jobs concurrently executing on the node.
getCurrentActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of currently active jobs concurrently executing on the node.
getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets current number of jobs that are active, i.e.
getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets current number of jobs that are active, i.e.
getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets current number of jobs that are being executed.
getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets current number of jobs that are being executed.
getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets current number of jobs that are active, i.e.
getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets current number of jobs that are active, i.e.
getCurrentCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of cancelled jobs that are still running.
getCurrentCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of cancelled jobs that are still running.
getCurrentCoordinatorFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getCurrentCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the CPU usage in [0, 1] range.
getCurrentCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the CPU usage in [0, 1] range.
getCurrentDaemonThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current number of live daemon threads.
getCurrentDaemonThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current number of live daemon threads.
getCurrentDirectoryPath() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Gets path to the directory where all checkpoints are saved.
getCurrentDirectoryPath() - Method in interface org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpiMBean
Gets path to the directory where all checkpoints are saved.
getCurrentGcCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns average time spent in CG since the last update.
getCurrentGcCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns average time spent in CG since the last update.
getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets number of currently 'held' jobs.
getCurrentIdleTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets time this node spend idling since executing last job.
getCurrentIdleTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets time this node spend idling since executing last job.
getCurrentJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets longest time a current job has been executing for.
getCurrentJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets longest time a current job has been executing for.
getCurrentJobsToStealNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets current number of jobs to be stolen.
getCurrentJobsToStealNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets current number of jobs to be stolen.
getCurrentJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets current time an oldest jobs has spent waiting to be executed.
getCurrentJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets current time an oldest jobs has spent waiting to be executed.
getCurrentMemorySize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets current queue size in bytes.
getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets current queue size in bytes.
getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets current queue size in bytes.
getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets current sorted entries queue size in bytes.
getCurrentPmeDuration() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets execution duration for current partition map exchange in milliseconds.
getCurrentPmeDuration() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets execution duration for current partition map exchange in milliseconds.
getCurrentRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of jobs rejected after more recent collision resolution operation.
getCurrentRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of jobs rejected after more recent collision resolution operation.
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
 
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets number of currently running (not 'held) jobs.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets current queue size.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets current queue size.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets current size.
getCurrentThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current number of live threads including both daemon and non-daemon threads.
getCurrentThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current number of live threads including both daemon and non-daemon threads.
getCurrentTopologyVersion() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Current topology version.
getCurrentWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of queued jobs currently waiting to be executed.
getCurrentWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of queued jobs currently waiting to be executed.
getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets current number of jobs that wait for the execution.
getCustomMsgData() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getData() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets data returned by remote job if it didn't fail.
getData(Ignite, String, IgniteBiPredicate<K, V>, UpstreamTransformerBuilder, String, UUID, PartitionDataBuilder<K, V, C, D>, LearningEnvironment, boolean) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Extracts partition data from the local storage, if it's not found in local storage recovers this data from a partition upstream and context.
getData() - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDataset
 
getData() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowJobArchive
 
getDatabaseFieldName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getDatabaseFieldType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getDatabaseSchema() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets database schema name.
getDatabaseTable() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets table name in database.
getDataCenterId() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets data center ID of the grid.
getDataCenterId() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets ID of remote data center.
getDataRegionConfigurations() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets an array of all data regions configured.
getDataRegionName() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getDataRegionName() - Method in class org.apache.ignite.configuration.CacheConfiguration
 
getDatasetCache() - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDataset
 
getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Gets data source.
getDataSource() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Gets data source.
getDataSourceBean() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets name of the data source bean.
getDataSourceFactory() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets factory for underlying datasource.
getDataSourceInfo() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets data source description.
getDataSourceInfo() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets data source description.
getDataStorageConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets page memory configuration.
getDataStreamerThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing data stream messages.
getDeadlockTimeout() - Method in class org.apache.ignite.configuration.TransactionConfiguration
This is an experimental feature.
getDeclaringClass() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Return declared class of field.
getDefaultAccessType() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
getDefaultClassLoader() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultDataRegionConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getDefaultFieldValues() - Method in class org.apache.ignite.cache.QueryEntity
Gets fields default values.
getDefaultIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultLockTimeout() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets default lock acquisition timeout.
getDefaultLockTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets default lock acquisition timeout.
getDefaultMemoryPolicyName() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Gets a name of default memory policy.
getDefaultMemoryPolicySize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Gets a size for default memory policy overridden by user.
getDefaultNameMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultPermissions() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Gets default permissions for users without principals.
getDefaultPermissionSet() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Gets default permission set.
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.SqlConfiguration
Deprecated.
Since 8.7.26. Please use distributed default query timeout.
getDefaultSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultTxConcurrency() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction concurrency to use when one is not explicitly specified.
getDefaultTxConcurrency() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Default cache transaction concurrency to use when one is not explicitly specified.
getDefaultTxIsolation() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction isolation to use when one is not explicitly specified.
getDefaultTxIsolation() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Default cache transaction isolation to use when one is not explicitly specified.
getDefaultTxTimeout() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Gets default transaction timeout.
getDefaultTxTimeout() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets default transaction timeout.
getDefaultURI() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultWarmUpConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets default warm-up configuration.
getDefragmentationThreadPoolSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Maximum number of partitions which can be defragmented at the same time.
getDeleteStatement(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns CQL statement to delete row from Cassandra table.
getDependencies() - Method in class org.apache.ignite.ml.clustering.gmm.GmmModel
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.composition.bagging.BaggedModel
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.composition.ModelsComposition
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.DoubleArrayVectorizer
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.DummyVectorizer
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.LabeledDummyVectorizer
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in interface org.apache.ignite.ml.environment.deploy.DeployableObject
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.binarization.BinarizationPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.developer.MappedPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.developer.PatchedPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.encoding.onehotencoder.OneHotEncoderPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.encoding.stringencoder.StringEncoderPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.normalization.NormalizationPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDependencies() - Method in class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerPreprocessor
Returns dependencies of this object that can be object with class defined by client side and unknown for server.
getDeploymentMode() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets deployment mode for deploying tasks and other classes on this node.
getDeploymentSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured deployment SPI implementation.
getDeploymentSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getDepth() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
getDesc() - Method in class org.apache.ignite.ml.inference.ModelDescriptor
 
getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets current size of evict queue used to batch up evictions.
getDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get database dialect.
getDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Get database dialect.
getDict() - Method in class org.apache.ignite.ml.xgboost.XGModelComposition
 
getDictionarySize() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Returns dictionary size, in bytes.
getDirectoryPath() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets directory path where persistent store data is to be saved.
getDirectoryPaths() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Gets collection of all configured paths where checkpoints can be saved.
getDirectoryPaths() - Method in interface org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpiMBean
Gets collection of all configured paths where checkpoints can be saved.
getDirtyPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Total dirty pages for the next checkpoint.
getDirtyPages() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Total dirty pages for the next checkpoint.
getDirtyPages() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDisabledTrustManager() - Static method in class org.apache.ignite.ssl.SslContextFactory
Returns an instance of trust manager that will always succeed regardless of certificate provided.
getDiscoveryPort() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getDiscoveryPort() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets discovery port for warmup.
getDiscoverySpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured discovery SPI implementation.
getDiscoverySpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getDiscoveryStartupDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Not used any more.
getDistance() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModelFormat
 
getDistance() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Gets the distance.
getDistance() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Gets the distance.
getDistance() - Method in class org.apache.ignite.ml.knn.utils.PointWithDistance
 
getDistanceMeasure() - Method in class org.apache.ignite.ml.knn.ann.KNNModelFormat
Gets distance measure.
getDistanceMeasure() - Method in class org.apache.ignite.ml.knn.NNClassificationModel
 
getDistances(Vector, LabeledVectorSet<LabeledVector<Double>>) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Computes distances between given vector and each vector in training dataset.
getDistanceSquared(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Get the square of the distance between this vector and the argument vector.
getDistanceSquared(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Get the square of the distance between this vector and the argument vector.
getDistanceSquared(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Get the square of the distance between this vector and the argument vector.
getDouble(String, double) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getDrBackupQueueSize() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets size of data center replication backup queue.
getDrBatchWaitingAcknowledgeCount() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets count of data center replication batches awaiting acknowledge from sender hub.
getDrBatchWaitingSendCount() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets count of data center replication batches awaiting to be send.
getDrManagementThreadPoolSize() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Size of thread pool that is in charge of executing internal DR tasks.
getDrQueuedKeysCount() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets count of keys enqueued for data center replication.
getDrReceiverConfiguration() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set data center receiver hub configuration.
getDrSenderConfiguration() - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Gets data center replication send configuration.
getDrSenderConfiguration() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Get data center sender hub configuration.
getDrSenderGroup() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets sender group for this cache.
getDrSenderHubsCount() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets count of available data center replication sender hubs.
getDrStateTransferThreadPoolSize() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Size of thread pool that is in charge of executing partition scan tasks for full-state transfer purposes.
getDrStatus() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets current status of data center replication.
getDrStreamerThreadPoolSize() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Size of thread pool that is in charge of processing DR (Data Replication) Streamer messages.
getDrThreadPoolSize() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Size of thread pool that is in charge of processing DR (Data Replication) messages.
getDynamicCacheConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets dynamic cache configuration template.
getDynamicNearCacheConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets dynamic near cache configuration template.
getEffectiveSocketTimeout(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets effective or resulting socket timeout with considering failure detection timeout
getElement(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the matrix's element at the given coordinates.
getElement(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the matrix's element at the given coordinates.
getElement(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets element at the given index.
getElement(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets element at the given index.
getElement(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets element at the given index.
getElementCountInMemory() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getElementCountInMemory() - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
getElementCountOnDisk() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getElementCountOnDisk() - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
getElitismCnt() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve the elitism count
getElseNode() - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
getEmptyPagesPoolSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Specifies the minimal number of empty pages to be present in reuse lists for this data region.
getEmptyPagesPoolSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Specifies the minimal number of empty pages to be present in reuse lists for this memory policy.
getEnabledFeatures() - Method in interface org.gridgain.grid.product.ProductLicense
 
getEncryptionConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets encryyption configuration.
getEncryptionSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured encryption SPI implementations.
getEndpointAddress() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Get ODBC endpoint address.
getEndTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets end of computation time for the task.
getEntityInformation(Class<T>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
getEntries(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves values mapped to the specified keys from cache.
getEntries(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets a collection of entries from the Cache.
getEntries() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Gets files and folders in this folder.
getEntriesAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves values mapped to the specified keys from cache.
getEntriesAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets a collection of entries from the Cache.
getEntry(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Retrieves value mapped to the specified key from cache.
getEntry(K) - Method in interface org.apache.ignite.IgniteCache
Gets an entry from the cache.
getEntryAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously retrieves value mapped to the specified key from cache.
getEntryAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets an entry from the cache.
getEntryCompressionConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets compression configuration used to compress entries, null when compression is not used.
getEntryFilter() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets entry filter.
getEntryProcessorAverageInvocationTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute cache invokes.
getEntryProcessorAverageInvocationTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The mean time to execute cache invokes.
getEntryProcessorHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
The percentage of invocations on keys, which exist in cache.
getEntryProcessorHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The percentage of invocations on keys, which exist in cache.
getEntryProcessorHits() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of invocations on keys, which exist in cache.
getEntryProcessorHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of invocations on keys, which exist in cache.
getEntryProcessorInvocations() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations.
getEntryProcessorInvocations() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of cache invocations.
getEntryProcessorMaxInvocationTime() - Method in interface org.apache.ignite.cache.CacheMetrics
So far, the maximum time to execute cache invokes.
getEntryProcessorMaxInvocationTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
So far, the maximum time to execute cache invokes.
getEntryProcessorMinInvocationTime() - Method in interface org.apache.ignite.cache.CacheMetrics
So far, the minimum time to execute cache invokes.
getEntryProcessorMinInvocationTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
So far, the minimum time to execute cache invokes.
getEntryProcessorMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of invocations on keys, which don't exist in cache.
getEntryProcessorMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of invocations on keys, which don't exist in cache.
getEntryProcessorMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
The percentage of invocations on keys, which don't exist in cache.
getEntryProcessorMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The percentage of invocations on keys, which don't exist in cache.
getEntryProcessorPuts() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations, caused update.
getEntryProcessorPuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of cache invocations, caused update.
getEntryProcessorReadOnlyInvocations() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations, caused no updates.
getEntryProcessorReadOnlyInvocations() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of cache invocations, caused no updates.
getEntryProcessorRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations, caused removal.
getEntryProcessorRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of cache invocations, caused removal.
getEnum(Class<E>, String) - Static method in class org.apache.ignite.IgniteSystemProperties
 
getEnum(String, E) - Static method in class org.apache.ignite.IgniteSystemProperties
 
getEnumValues() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
 
getEpsilon() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Gets the epsilon.
getEpsilon() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Gets the epsilon.
getError() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets error message if any.
getEstimatedRebalancingFinishTime() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getEstimatedRebalancingFinishTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getEstimatedRebalancingKeys() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getEstimatedRebalancingKeys() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getEventListeners() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getEventStorageSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured event SPI implementation.
getEventStorageSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getEvictionFilter() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets eviction filter to specify which entries should not be evicted (except explicit evict by calling IgniteCache.localEvict(Collection)).
getEvictionPolicy() - Method in class org.apache.ignite.configuration.CacheConfiguration
getEvictionPolicyFactory() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache eviction policy factory.
getEvictionRate() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets eviction rate of a given memory region.
getEvictionRate() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets eviction rate of a given memory region.
getEvictionRate() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets eviction rate of a given memory region.
getEvictionRate() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets eviction rate of a given memory region.
getEvictionRate() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets eviction rate of a given memory region.
getEvictionThreshold() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets a threshold for memory pages eviction initiation.
getEvictionThreshold() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets a threshold for memory pages eviction initiation.
getException() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets exception produced by execution of remote job, or null if remote execution finished normally and did not produce any exceptions.
getException() - Method in class org.apache.ignite.tensorflow.core.longrunning.task.util.LongRunningProcessStatus
 
getException() - Method in class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Returns an exception that happened during execution or null if there is no exception.
getExceptionRegistry() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets Exception registry.
getExecutorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets custom executors for user compute tasks.
getExecutorServiceFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getExistsQueryString(String, String, Iterable<String>) - Static method in class org.apache.ignite.springdata22.repository.query.QueryUtils
Returns the query string to execute an exists query for the given id attributes.
getExpireAgeMs() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
getExpireAgeMs() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Gets event time-to-live value.
getExpireCount() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
getExpireCount() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Gets maximum event queue size.
getExpireDateFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets expiration date field name for checkpoint table.
getExpireDateFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets expiration date field name for checkpoint table.
getExpireDateFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets expiration date field type for checkpoint table.
getExpireDateFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets expiration date field type for checkpoint table.
getExpiryPolicy() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getExtension() - Method in class org.apache.ignite.springdata22.repository.config.IgniteRepositoriesRegistar
getExternalAddresses(InetSocketAddress) - Method in interface org.apache.ignite.configuration.AddressResolver
Maps internal address to a collection of external addresses.
getExternalAddresses(InetSocketAddress) - Method in class org.apache.ignite.configuration.BasicAddressResolver
Maps internal address to a collection of external addresses.
getFailedConfigurations() - Method in exception org.apache.ignite.services.ServiceDeploymentException
 
getFailoverSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured failover SPI implementation.
getFailoverSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns failure detection timeout used by TcpDiscoverySpi and TcpCommunicationSpi.
getFailureHandler() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets failure handler.
getFeatureId() - Method in class org.apache.ignite.ml.dataset.feature.FeatureMeta
 
getFeatureMeta() - Method in class org.apache.ignite.ml.dataset.feature.BucketMeta
 
getFeatureName(int) - Method in class org.apache.ignite.ml.structures.Dataset
Returns feature name for column with given index.
getFeatures() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleDatasetData
 
getFeatures() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleLabeledDatasetData
 
getFeatures() - Method in class org.apache.ignite.ml.dataset.primitive.FeatureMatrixWithLabelsOnHeapData
 
getFeaturesMapping() - Method in class org.apache.ignite.ml.composition.ModelOnFeaturesSubspace
Returns features mapping.
getFeatureValue(DecisionTreeData, TreeDataIndex, int, int) - Method in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Returns feature value in according to kth order statistic.
getFeatureValues(DecisionTreeData, TreeDataIndex, int, int) - Method in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Returns feature value in according to kth order statistic.
getFetchSize() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Gives the JDBC driver a hint how many rows should be fetched from the database when more rows are needed.
getFetchSize() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Gives the JDBC driver a hint how many rows should be fetched from the database when more rows are needed.
getField(String) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Returns value assigned to the specified field.
getFieldByColumn(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns POJO field by Cassandra table column name.
getFieldName(int) - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Gets field name.
getFieldName(int) - Method in interface org.apache.ignite.cache.query.FieldsQueryCursor
Gets field name.
getFieldNames() - Method in class org.apache.ignite.cache.QueryIndex
 
getFields() - Method in class org.apache.ignite.cache.QueryEntity
Gets query fields for this query pair.
getFields() - Method in class org.apache.ignite.cache.QueryIndex
Gets fields included in the index.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns a list of POJO fields to be persisted.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns list of POJO fields to be mapped to Cassandra table columns.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns a list of POJO fields to be persisted.
getFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
 
getFieldsPrecision() - Method in class org.apache.ignite.cache.QueryEntity
 
getFieldsScale() - Method in class org.apache.ignite.cache.QueryEntity
 
getFieldType() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns field type.
getFile(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Returns file content.
getFile(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Returns file content.
getFileIOFactory() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Factory to provide implementation of FileIO interface which is used for data storage files read/write operations
getFileIOFactory() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Factory to provide implementation of FileIO interface which is used for any file read/write operations
getFileName() - Method in enum org.apache.ignite.ml.util.MLSandboxDatasets
 
getFileStat(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Returns statistics for file.
getFileStat(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Returns statistics for file.
getFilter() - Method in class org.apache.ignite.cache.query.IndexQuery
Gets remote cache entries filter.
getFilter() - Method in class org.apache.ignite.cache.query.ScanQuery
Gets filter.
getFilter() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Gets filter for events to be recorded.
getFinishTime() - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
Get finish time for current stage of snapshot operation on node or 0.
getFitness() - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Returns the fitness value.
getFitnessFunction() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve IFitnessFunction
getFitnessScore() - Method in class org.apache.ignite.ml.genetic.Chromosome
Gets the fitnessScore
getFloat(String, float) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getFlushFrequency() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets data flush frequency.
getFlushFrequency() - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
getFlushFrequency() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets data center replication data loader flush frequency.
getForcePrimary(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets value from cache.
getForcePrimaryAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously gets value from cache.
getFrameworkInfo() - Method in class org.apache.ignite.mesos.IgniteFramework
 
getFreeSpace() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets free space in default configured snapshot directory (in bytes).
getFromCache(Object, SharedSessionContractImplementor) - Method in class org.apache.ignite.cache.hibernate.IgniteGeneralDataRegion
getFsyncDelay() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets maximum delay in milliseconds after which fsync will be issued after a write to a file.
getFullStateTransferBufferSize() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets global DR full state transfer buffer size.
getFullVersion() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getFunc() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets the inner func.
getGain() - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeSplit
 
getGene(int) - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Returns the gene value by index.
getGenePool() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve the gene pool
getGenes() - Method in class org.apache.ignite.ml.genetic.Chromosome
Gets the gene keys (ie: primary keys) for this chromosome
getGenesInOrderForChromosome(Ignite, Chromosome) - Static method in class org.apache.ignite.ml.genetic.utils.GAGridUtils
Retrieve genes in order
getGrammarFileName() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getGrammarFileName() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
getGridCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets number of grids to start and run warmup.
getGridLogger() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return an instance of logger to use in grid.
getGridLoggerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getGridName() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
getGridName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getGridName() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
getGridStartTime() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets start time of the very first node in the grid.
getGridStartTime() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets start time of the very first node in the grid.
getGridStartTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets start time of the very first node in the grid.
getGridStartTime() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets start time of the very first node in the grid.
getGroupId() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets cache group id.
getGroupName() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets the cache group name.
getGroupName() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets the cache group name.
getGroupName() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getGroupName() - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
getGroupName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets the cache group name.
getGroupName() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getGroupName() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets cache group name.
getHandshakeTimeout() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets handshake timeout for client connections.
getHasher() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets hash code calculator.
getHasher() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets hash code calculator.
getHealthCheckFrequency() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets health check frequency.
getHealthCheckFrequency() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets health check frequency in milliseconds.
getHeapEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the number of cache entries in heap memory, including entries held by active transactions, entries in onheap cache and near entries.
getHeapEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets the number of cache entries in heap memory, including entries held by active transactions, entries in onheap cache and near entries.
getHeapMemoryCommitted() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of heap memory in bytes that is committed for the JVM to use.
getHeapMemoryCommitted() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of heap memory in bytes that is committed for the JVM to use.
getHeapMemoryInitialized() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of heap memory in bytes that the JVM initially requests from the operating system for memory management.
getHeapMemoryInitialized() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of heap memory in bytes that the JVM initially requests from the operating system for memory management.
getHeapMemoryMaximum() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the maximum amount of heap memory in bytes that can be used for memory management.
getHeapMemoryMaximum() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the maximum amount of heap memory in bytes that can be used for memory management.
getHeapMemoryTotal() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the total amount of heap memory in bytes.
getHeapMemoryTotal() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the total amount of heap memory in bytes.
getHeapMemoryUsed() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current heap size that is used for object allocation.
getHeapMemoryUsed() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current heap size that is used for object allocation.
getHeartbeatInterval() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the heartbeat message interval, in milliseconds.
getHibernateConfigurationPath() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
Gets hibernate configuration path.
getHoldCount() - Method in interface org.apache.ignite.IgniteLock
Queries the number of holds on this lock by the current thread.
getHost() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get host.
getHost() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets host for TCP binary protocol server.
getHost() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get host.
getHostName() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets host name.
getHyperParameterTuningStrategy() - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
Returns the Hyper-parameter tuning strategy.
getId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets session ID of the task being executed.
getId() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
getId() - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Gets cluster ID.
getIdentifyingTypes() - Method in class org.apache.ignite.springdata22.repository.config.IgniteRepositoryConfigurationExtension
getIdleConnectionTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum idle connection time upon which idle connections will be closed.
getIdleQueryCursorCheckFrequency() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets idle query cursors check frequency.
getIdleQueryCursorTimeout() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets idle query cursors timeout in milliseconds.
getIdleTimeout() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets idle timeout for client connections.
getIdleTimeout() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets idle timeout for REST server.
getIdleTimeout() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets idle timeout for receiver hub's TCP server connection.
getIdleTimeout() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets idle timeout for sender hub socket connection.
getIdleTimePercentage() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets percentage of time this node is idling vs. executing jobs.
getIdleTimePercentage() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets percentage of time this node is idling vs. executing jobs.
getIdMapper() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets ID mapper.
getIdMapper() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets ID mapper.
getIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getIgnite(String) - Method in class org.apache.ignite.mesos.resource.IgniteProvider
 
getIgnite() - Method in class org.apache.ignite.stream.StreamAdapter
 
getIgnite() - Method in class org.apache.ignite.tensorflow.submitter.command.AbstractCommand
Returns Ignite instance based on configuration specified in AbstractCommand.cfg field.
getIgnite() - Method in class org.apache.ignite.yarn.IgniteProvider
 
getIgnite(String) - Method in class org.apache.ignite.yarn.IgniteProvider
 
getIgniteHome() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return Ignite installation home folder.
getIgniteHome() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getIgniteHome() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets Ignite installation home folder (i.e.
getIgniteHome() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets Ignite installation home folder (i.e.
getIgniteInstanceName() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets Ignite instance name.
getIgniteInstanceName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets optional node name.
getIgniteInstanceName() - Method in class org.apache.ignite.thread.IgniteThread
Gets name of the Ignite instance this thread belongs to.
getIgniteInstanceName() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets Ignite instance name.
getIgnoredDataCenterIds() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets IDs of data centers updates from which will not be replicated to this remote data center.
getIgnoredFailureTypes() - Method in class org.apache.ignite.failure.AbstractFailureHandler
Returns unmodifiable set of ignored failure types.
getImpurity() - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeSplit
 
getImpurity() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
getImpurityMeasureCalculator(Dataset<EmptyContext, DecisionTreeData>) - Method in class org.apache.ignite.ml.tree.DecisionTree
Returns impurity measure calculator.
getImpurityMeasureCalculator(Dataset<EmptyContext, DecisionTreeData>) - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Returns impurity measure calculator.
getImpurityMeasureCalculator(Dataset<EmptyContext, DecisionTreeData>) - Method in class org.apache.ignite.ml.tree.DecisionTreeRegressionTrainer
Returns impurity measure calculator.
getIncludeEventTypes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets array of event types, which will be recorded.
getIncludeNotReadyAddresses() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Get flag include not ready addresses.
getIncludeProperties() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets array of system or environment properties to include into node attributes.
getIncomingPayload() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getIncrementalDrPoolSize() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Size of thread pool that is in charge of executing partition scan tasks for incremental replication purposes.
getIndexBuildCountPartitionsLeft() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
 
getIndexDDL(String, String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Returns DDL for the field secondary index.
getIndexDDLStatements(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns DDL statements to create Cassandra table secondary indexes.
getIndexedTypes() - Method in class org.apache.ignite.configuration.CacheConfiguration
Array of key and value type pairs to be indexed (thus array length must be always even).
getIndexes() - Method in class org.apache.ignite.cache.QueryEntity
Gets a collection of index entities.
getIndexingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured indexing SPI implementations.
getIndexInnerLogicalReads(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of logical inner index's page reads for given cache group and index.
getIndexInnerPhysicalReads(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of physical inner index's page reads for given cache group and index.
getIndexLeafLogicalReads(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of logical leaf index's page reads for given cache group and index.
getIndexLeafPhysicalReads(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of physical leaf index's page reads for given cache group and index.
getIndexLogicalReads(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of logical index page reads for given cache group and index.
getIndexName() - Method in class org.apache.ignite.cache.query.IndexQuery
Index name.
getIndexPhysicalReads(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets number of physical index page reads for given cache group and index.
getIndexRebuildKeysProcessed() - Method in interface org.apache.ignite.cache.CacheMetrics
Return number of keys processed during index rebuilding.
getIndexRebuildKeysProcessed() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Return number of keys processed during index rebuilding.
getIndexStatistics(String, String) - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Gets string presentation of index IO statistics for given cache group and index.
getIndexType() - Method in class org.apache.ignite.cache.QueryIndex
Gets index type.
getInitialContextEnvironment() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Gets initial context environment map.
getInitialNodes() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Returns a list of alive nodes in the cluster that are not updated yet.
getInitialQuery() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets initial query.
getInitialSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets initial memory region size defined by this data region.
getInitialSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets initial memory region size defined by this memory policy.
getInitialSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets initial memory region size defined by its DataRegionConfiguration.
getInitialSize() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets initial memory region size defined by its MemoryPolicyConfiguration.
getInitialVersion() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Returns the version that is used as starting point for Rolling Upgrade.
getInlineSize() - Method in class org.apache.ignite.cache.QueryIndex
Gets index inline size in bytes.
getInputMsg() - Method in class org.apache.ignite.ml.inference.ModelSignature
 
getInstanceName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getInt() - Method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
 
getInteger(String, int) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getIntercept() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
 
getInterceptor() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache interceptor.
getInternalMdl() - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
 
getInteropConfiguration() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets interop configuration.
getIpFinder() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets IP finder for IP addresses sharing and storing.
getIpFinderCleanFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets frequency with which coordinator cleans IP finder and keeps it in the correct state, unregistering addresses of the nodes that have left the topology.
getIpFinderCleanFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets frequency with which coordinator cleans IP finder and keeps it in the correct state, unregistering addresses of the nodes that have left the topology.
getIpFinderFormatted() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets TcpDiscoveryIpFinder (string representation).
getIpFinderFormatted() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets TcpDiscoveryIpFinder (string representation).
getIsstop() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getIssue() - Method in class org.gridgain.grid.persistentstore.SnapshotIssue
 
getIterationCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets iteration count for warmup.
getIterations() - Method in class org.apache.ignite.ml.math.isolve.IterativeSolverResult
 
getJavaClass() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns java class of the object to be persisted.
getJavaClass() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Returns java class of the field.
getJavaFieldName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getJavaFieldType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getJdkInformation() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getJettyPath() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets path, either absolute or relative to IGNITE_HOME, to Jetty XML configuration file.
getJndiNames() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Gets a list of JNDI names.
getJndiNames() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
Gets a list of JNDI names.
getJob() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets local instance of remote job returned by ComputeTask.map(List, Object) method.
getJob() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Job for this context.
getJobContext() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets job context.
getJobContext() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Gets job context.
getJobId() - Method in interface org.apache.ignite.compute.ComputeJobContext
Gets ID of the job this context belongs to.
getJobId() - Method in interface org.apache.ignite.compute.ComputeJobSibling
Gets ID of this grid job sibling.
getJobName() - Method in class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
 
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.
getJobs() - Method in class org.apache.ignite.tensorflow.cluster.spec.TensorFlowClusterSpec
 
getJobSibling(IgniteUuid) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets job sibling for a given ID.
getJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets a collection of all grid job siblings.
getJoinTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Get join timeout, in milliseconds.
getJoinTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
The join timeout, in milliseconds.
getJoinTimeout() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getK() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Gets the amount of clusters.
getK() - Method in class org.apache.ignite.ml.knn.ann.KNNModelFormat
Gets amount of nearest neighbors.
getKClosestVectors(LabeledVectorSet<LabeledVector>, TreeMap<Double, Set<Integer>>) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Iterates along entries in distance map and fill the resulting k-element array.
getKeepAliveTime() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the thread keep-alive time, which is the amount of time which threads in excess of the core pool size may remain idle before being terminated.
getKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Gets keep deserialized flag.
getKey() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
getKey() - Method in class org.apache.ignite.lang.IgniteBiTuple
getKey() - Method in class org.apache.ignite.ml.dataset.UpstreamEntry
 
getKeyAlgorithm() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets algorithm that will be used to create a key manager.
getKeyConfiguration() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getKeyConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache key configuration.
getKeyFieldName() - Method in class org.apache.ignite.cache.QueryEntity
Gets key field name.
getKeyFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets key field name for checkpoint table.
getKeyFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets key field name for checkpoint table.
getKeyFields() - Method in class org.apache.ignite.cache.QueryEntity
Gets query fields for this query pair that belongs to the key.
getKeyFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns list of Ignite cache key POJO fields to be mapped to Cassandra table columns.
getKeyFields() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets optional persistent key fields (needed only if CacheJdbcPojoStore is used).
getKeyFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets key field type for checkpoint table.
getKeyFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets key field type for checkpoint table.
getKeyPath() - Method in class org.gridgain.grid.configuration.SftpConfiguration
 
getKeyPersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns persistence settings for Ignite cache keys.
getKeyRange() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets key range.
getKeys() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
Returns list of string indexes used in this vector.
getKeys() - Method in interface org.apache.ignite.ml.math.primitives.vector.NamedVector
Returns list of string indexes used in this vector.
getKeySize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
Can overflow. Use CacheMetrics.getCacheSize() instead.
getKeySize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets number of keys in the cache, possibly with null values.
getKeySize() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets encryption key size.
getKeyspace() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns Cassandra keyspace to use.
getKeyspaceDDLStatement() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns DDL statement to create Cassandra keyspace.
getKeysToRebalanceLeft() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getKeysToRebalanceLeft() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getKeyStoreFilePath() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets path to the key store file.
getKeyStorePassword() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets key store password.
getKeyStorePath() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets path to jdk keyStore that stores master key.
getKeyStorePwd() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets key store password.
getKeyStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets key store type used for context creation.
getKeyType() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines the required type of keys for this Cache, if any.
getKeyType() - Method in class org.apache.ignite.cache.QueryEntity
Gets key type for this query pair.
getKeyType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets key type.
getKeyType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Determines the required type of keys for this Cache, if any.
getKeyTypeName() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Gets fully-qualified platform type name of the cache key used for the local map.
getL() - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Returns the matrix L of the decomposition.
getLabel() - Method in class org.apache.ignite.ml.util.MnistUtils.MnistLabeledImage
 
getLabels() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleLabeledDatasetData
 
getLabels() - Method in class org.apache.ignite.ml.dataset.primitive.FeatureMatrixWithLabelsOnHeapData
 
getLabelValue(DecisionTreeData, TreeDataIndex, int, int) - Method in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Returns label value in according to kth order statistic.
getLambda() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Get the regularization lambda.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargestPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the largest number of threads that have ever simultaneously been in the pool.
getLastCheckpointCopiedOnWritePagesNumber() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointCopiedOnWritePagesNumber() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointCopiedOnWritePagesNumber() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointCopiedOnWritePagesNumber() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointCopiedOnWritePagesNumber() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the number of data pages written during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the number of data pages written during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the number of data pages written during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the number of data pages written during the last checkpoint.
getLastCheckpointDataPagesNumber() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the number of data pages written during the last checkpoint.
getLastCheckpointDuration() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointDuration() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointFsyncDuration() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointFsyncDuration() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointFsyncDuration() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointFsyncDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointFsyncDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
getLastCheckpointingDuration() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointingDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointingDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
getLastCheckpointLockWaitDuration() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointLockWaitDuration() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointLockWaitDuration() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointLockWaitDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointLockWaitDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
getLastCheckpointMarkDuration() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointMarkDuration() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointMarkDuration() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointMarkDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointMarkDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointPagesWriteDuration() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
getLastCheckpointStarted() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Returns time when the last checkpoint was started.
getLastCheckpointStarted() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Returns time when the last checkpoint was started.
getLastCheckpointTotalPagesNumber() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the total number of pages written during the last checkpoint.
getLastCheckpointTotalPagesNumber() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the total number of pages written during the last checkpoint.
getLastCheckpointTotalPagesNumber() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the total number of pages written during the last checkpoint.
getLastCheckpointTotalPagesNumber() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the total number of pages written during the last checkpoint.
getLastCheckpointTotalPagesNumber() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the total number of pages written during the last checkpoint.
getLastDataVersion() - Method in interface org.apache.ignite.cluster.ClusterMetrics
In-Memory Data Grid assigns incremental versions to all cache operations.
getLastDataVersion() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
In-Memory Data Grid assigns incremental versions to all cache operations.
getLastSnapshotFinishTime() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets the last snapshot finish time.
getLastSnapshotId() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets the last snapshot IDs
getLastSnapshotOperation() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets the last snapshot operation type.
getLastSnapshotStartTime() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets the last snapshot start time.
getLastTrainedModelOrThrowEmptyDatasetException(M) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Used on update phase when given dataset is empty.
getLastUpdateTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets last update time of this node metrics.
getLastUpdateTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets last update time of this node metrics.
getLeafs() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeRoot
 
getLearningEnvironment(Ignite, UUID, int, LearningEnvironmentBuilder) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Gets learning environment for given partition.
getLearningStrategy() - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Returns learning strategy.
getLearningStrategy() - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Returns learning strategy.
getLearningStrategy() - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Returns learning strategy.
getLeft() - Method in class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasure
 
getLeft() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
getLeftCnt() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
 
getLeftY() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
 
getLeftY2() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
 
getLengthSquared() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the sum of squares of all elements in this vector.
getLengthSquared() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the sum of squares of all elements in this vector.
getLengthSquared() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the sum of squares of all elements in this vector.
getLicenseUrl() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets custom license file URL to be used instead of default license file location.
getLifecycleBeans() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns a collection of life-cycle beans.
getLifecycleBeansFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getLimit() - Method in class org.apache.ignite.cache.query.IndexQuery
Gets limit to response records count.
getListener() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
getLivenessCheckEnabled() - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Calculates load value for a given node.
getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Calculates load value for a given node.
getLoad(ClusterNode, int) - Method in interface org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadProbe
Calculates load value for a given node.
getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Calculates load value for a given node.
getLoadBalancingMode() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets sender hub load balancing mode.
getLoadBalancingMode() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets remote receiver hub load balancing policy.
getLoadBalancingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured load balancing SPI implementation.
getLoadBalancingSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getLoadProbeFormatted() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Gets text description of current load probing implementation used.
getLoadProbeFormatted() - Method in interface org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpiMBean
Gets text description of current load probing implementation used.
getLoadStatement(String, boolean) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns CQL statement to select key/value fields from Cassandra table.
getLocalAddress() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets local host address for socket binding.
getLocalAddress() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets local address that multicast IP finder uses.
getLocalAddress() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local address that was set to SPI with TcpDiscoverySpi.setLocalAddress(String) method.
getLocalEventListeners() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets map of pre-configured local event listeners.
getLocalHost() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets system-wide local address or host for all Ignite components to bind to.
getLocalInboundHost() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets local host name receiver hub TCP server is bound to.
getLocalInboundHost() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets local host name receiving hub server is bound to.
getLocalInboundPort() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets local port receiver hub TCP server is bound to.
getLocalInboundPort() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets local port receiver hub is bound to.
getLocalListener() - Method in class org.apache.ignite.cache.query.ContinuousQuery
 
getLocalListener() - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Gets local transformed event listener
getLocalNode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
getLocalNodeFormatted() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets local node formatted as a string.
getLocalNodeId() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getLocalNodeId() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets ID of the local node.
getLocalNodeId() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets ID of the local node.
getLocalNodeId() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets ID of the local node.
getLocalNodeMovingPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of partitions with state MOVING for this cache group located on this node.
getLocalNodeOwningPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of partitions with state OWNING for this cache group located on this node.
getLocalNodeRentingEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of entries remains to evict in RENTING partitions located on this node for this cache group.
getLocalNodeRentingPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of partitions with state RENTING for this cache group located on this node.
getLocalOutboundAddress() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets local outbound address.
getLocalOutboundHost() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
getLocalPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets local port for socket binding.
getLocalPort() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local TCP port SPI listens to.
getLocalPort() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets local TCP port SPI listens to.
getLocalPortRange() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of local ports tried if all previously tried ports are occupied.
getLocalPortRange() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local TCP port range.
getLocalPortRange() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets local TCP port range.
getLocIterations() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the maximal number of local iterations before synchronization.
getLocIterations() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Get the amount of local iterations.
getLocIterations() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Get the amount of local iterations.
getLockedKeysNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of keys locked on the node.
getLockedKeysNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of keys locked on the node.
getLocksCount() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Gets locks count.
getLockWaitTime() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Timeout in milliseconds to wait when acquiring persistence store lock file before failing the local node.
getLockWaitTime() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Time out in milliseonds to wait when acquiring persistence store lock file before failing the local node.
getLocNodeAttrs() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getLogger() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the logger.
getLogger(Object) - Method in interface org.apache.ignite.IgniteLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.EchoingLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.java.JavaLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.jcl.JclLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Gets IgniteLogger wrapper around log4j logger for the given category.
getLogger(Object) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Gets IgniteLogger wrapper around log4j logger for the given category.
getLogger(Object) - Method in class org.apache.ignite.logger.NullLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Creates new logger with given category based off the current instance.
getLogin() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets login.
getLoginContextName() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Gets login context name.
getLoginContextName() - Method in interface org.gridgain.grid.security.jaas.JaasAuthenticatorMBean
Gets login context name.
getLoginTimeout() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getLogWriter() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getLong(String, long) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getLongJVMPauseLastEvents() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getLongJVMPausesCount() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getLongJVMPausesTotalDuration() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getLongOperationsDumpTimeout() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns a timeout (in millis) for printing to log long-running transactions as well as transactions that cannot receive locks for all their keys for a long time.
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.SqlConfiguration
Gets timeout in milliseconds after which long query warning will be printed.
getLongRunningOwnerTransactions(int) - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
Long running near transactions
getLongRunningOwnerTransactions(int) - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets a map of all transactions for which the local node is the originating node and which duration exceeds the given duration.
getLongTransactionTimeDumpThreshold() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns threshold timeout in milliseconds for long transactions, if transaction exceeds it, it will be dumped in log with information about how much time did it spent in system time (time while aquiring locks, preparing, commiting, etc.)
getLoss() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the loss function to be minimized during the training.
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getManagementThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal and Visor GridJobs.
getManager() - Static method in class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathFactory
Gets commons-vfs2 manager.
getMapCapacity() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets initial internal hash map capacity.
getMapping(int, int, long) - Static method in class org.apache.ignite.ml.composition.bagging.BaggedTrainer
Get mapping R^featuresVectorSize -> R^maximumFeaturesCntPerMdl.
getMapping(int, int, long) - Static method in class org.apache.ignite.ml.trainers.TrainerTransformers
Get mapping R^featuresVectorSize -> R^maximumFeaturesCntPerMdl.
getMapSegments() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets number of map segments.
getMarshaller() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Since 2.1. Some Ignite features will not work if non-null marshaller is set (IgniteCache.withKeepBinary(), .NET, CPP, ODBC)
getMaster() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Get Kubernetes master url.
getMasterKeyName() - Method in interface org.apache.ignite.IgniteEncryption
Gets the current master key name.
getMasterKeyName() - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
Gets the current master key name.
getMasterKeyName() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Gets the current master key name.
getMasterKeyName() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets the current master key name.
getMasterKeyName() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Gets the current master key name.
getMax() - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPartitionData
 
getMax() - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPreprocessor
 
getMaxAbs() - Method in class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPartitionData
 
getMaxAbs() - Method in class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPreprocessor
 
getMaxAckTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets maximum message acknowledgement timeout.
getMaxAckTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets maximum message acknowledgement timeout.
getMaxActiveComputeTasksPerConnection() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Gets active compute tasks per connection limit.
getMaxActiveTxPerConnection() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Gets active transactions count per connection limit.
getMaxBackupQueueSize() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets maximum size of backup entries queue.
getMaxBatches() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets maximum amount of batches awaiting for sender hub acknowledge.
getMaxConcurrentAsyncOperations() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getMaxConcurrentAsyncOperations() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum number of allowed concurrent asynchronous operations.
getMaxConnectionsPerNode() - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
 
getMaxConnectTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum connect timeout.
getMaxDeep() - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
 
getMaxDepth() - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Get the max depth.
getMaxDepth() - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Get the max depth.
getMaxErrors() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets maximum amount of sequential errors in receiver hub responses.
getMaxErrors() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Maximum amount of errors received from remote data center sender hub node.
getMaxFailedConnectAttempts() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets maximum failed connect attempts.
getMaxFailedConnectAttempts() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets maximum failed connection attempts.
getMaxFilesCount() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets maximum amount of files files which can be used to store data.
getMaxFileSize() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets maximum size of each file where data is stored in bytes.
getMaximumActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of jobs that ever ran concurrently on this node.
getMaximumActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of jobs that ever ran concurrently on this node.
getMaximumCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of cancelled jobs this node ever had running concurrently.
getMaximumCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of cancelled jobs this node ever had running concurrently.
getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.always.AlwaysFailoverSpiMBean
Gets maximum number of attempts to execute a failed job on another node.
getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Gets maximum number of attempts to execute a failed job on another node.
getMaximumJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets time it took to execute the longest job on the node.
getMaximumJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets time it took to execute the longest job on the node.
getMaximumJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum time a job ever spent waiting in a queue to be executed.
getMaximumJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum time a job ever spent waiting in a queue to be executed.
getMaximumNumberOfPartitionCopies() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Calculates maximum number of partitions copies for all partitions of this cache group.
getMaximumPoolSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get Max workers thread count.
getMaximumPoolSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Get maximum workers thread count.
getMaximumPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the maximum allowed number of threads.
getMaximumRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of jobs rejected at once during a single collision resolution operation.
getMaximumRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of jobs rejected at once during a single collision resolution operation.
getMaximumStealingAttempts() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getMaximumStealingAttempts() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets maximum number of attempts to steal job by another node.
getMaximumThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the maximum live thread count since the JVM started or peak was reset.
getMaximumThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the maximum live thread count since the JVM started or peak was reset.
getMaximumWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of waiting jobs this node had.
getMaximumWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of waiting jobs this node had.
getMaximumWriteAttempts() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets maximum number of write attempts in case of database error.
getMaximumWriteAttempts() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets maximum number of write attempts in case of database error.
getMaxIterations() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Gets the max number of iterations before convergence.
getMaxIterations() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Gets the max number of iterations before convergence.
getMaxIterations() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the maximal number of iterations before the training will be stopped.
getMaxIterations() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Get the max amount of iterations.
getMaxIterations() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Get the max amount of iterations.
getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets maximum allowed cache size in bytes.
getMaxMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets max message processing time.
getMaxMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets max message processing time.
getMaxOpenCursors() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Gets maximum number of opened cursors per connection.
getMaxOpenCursorsPerConnection() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets maximum number of opened cursors per connection.
getMaxOpenCursorsPerConnection() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Gets maximum number of opened cursors per connection.
getMaxParameterCount() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Get max query parameters count.
getMaxParameterCount() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Get max query parameters count.
getMaxPerNodeCount() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets maximum number of deployed service instances on each node, 0 for unlimited.
getMaxPoolSize() - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Get maximum workers thread count.
getMaxQueryIteratorsCount() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getMaxQueryIteratorsCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum number of query iterators that can be stored.
getMaxQueueSize() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets maximum wait queue size.
getMaxQueueSize() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets maximum wait queue size.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Maximum memory region size defined by this data region.
getMaxSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Maximum memory region size defined by this memory policy.
getMaxSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Maximum memory region size defined by its DataRegionConfiguration.
getMaxSize() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Maximum memory region size defined by its MemoryPolicyConfiguration.
getMaxSize() - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Gets maximum number of entries can be stored.
getMaxSparsity() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets maximum allowed file sparsity above which compaction has to start.
getMaxTries() - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
Returns the max number of tries to stop the hyperparameter search.
getMaxWalArchiveSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a max allowed size(in bytes) of WAL archives.
getMBean() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
getMBean() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
getMBean() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
getMBean() - Method in interface org.apache.ignite.mxbean.IgniteMBeanAware
 
getMBeanInfo() - Method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
getMBeanServer() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return MBean server instance.
getMBeanServerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getMdl() - Method in class org.apache.ignite.ml.composition.ModelOnFeaturesSubspace
Returns model.
getMdlClsNameInSpark() - Method in enum org.apache.ignite.ml.sparkmodelparser.SupportedSparkModels
 
getMdlDescStorageBackups() - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
getMdlStorageBackups() - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
getMeans() - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
 
getMeans() - Method in class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerPreprocessor
 
getMeanValue() - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
 
getMemoryAllocator() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
 
getMemoryAllocator() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getMemoryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getMemoryPolicies() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Gets an array of all memory policies configured.
getMemoryPolicyName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
getMessageDigestFactory() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
getMessageExpireTime() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getMessageExpireTime() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Message expire time configuration parameter.
getMessageInterceptor() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets interceptor for objects, moving to and from remote clients.
getMessageQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets message queue limit for incoming and outgoing messages.
getMessageQueueLimit() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets message queue limit for incoming and outgoing messages in receiver hub's TCP server.
getMessageQueueLimit() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets message queue limit for incoming and outgoing messages.
getMessageSize() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
getMessageSize() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
getMessageWorkerQueueSize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets message worker queue current size.
getMessageWorkerQueueSize() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets message worker queue current size.
getMetaStorage() - Method in interface org.apache.ignite.ml.math.MetaAttributes
Implementation should return an instance of the map to store meta attributes.
getMetaStorage() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Implementation should return an instance of the map to store meta attributes.
getMetaStorage() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Implementation should return an instance of the map to store meta attributes.
getMetaStorage() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Implementation should return an instance of the map to store meta attributes.
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.
getMetricExporterSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured metric SPI implementations.
getMetricsExpireTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Elapsed time in milliseconds after which node metrics are considered expired.
getMetricsHistorySize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Number of node metrics to keep in memory to calculate totals and averages.
getMetricsLogFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets frequency of metrics log print out.
getMetricsRateTimeInterval() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
getMetricsRateTimeInterval() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
getMetricsSubIntervalCount() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
getMetricsSubIntervalCount() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
getMetricsUpdateFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Ignite metrics update frequency in milliseconds.
getMin() - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPartitionData
 
getMin() - Method in class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPreprocessor
 
getMinCompactSize() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets minimum file size for compaction.
getMinImpurityDecrease() - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Get the min impurity decrease.
getMinImpurityDecrease() - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Get the min impurity decrease.
getMinImpurityDecrease() - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
 
getMinimumNumberOfPartitionCopies() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Calculates minimum number of partitions copies for all partitions of this cache group.
getMinorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
getMinorVersion() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getMinWalArchiveSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a min allowed size(in bytes) of WAL archives.
getMissingNode() - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
getModel(Ignite, String) - Static method in class org.apache.ignite.ml.inference.IgniteModelStorageUtil
Retrieves Ignite model by name using SingleModelBuilder.
getModel(Double) - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
 
getModelDescriptorStorage(Ignite) - Method in class org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorageFactory
Returns model descriptor storage based on Apache Ignite cache.
getModels() - Method in class org.apache.ignite.ml.composition.ModelsComposition
Returns containing models.
getModelsComposition() - Method in class org.apache.ignite.ml.xgboost.XGModelComposition
 
getModelStorage(Ignite) - Method in class org.apache.ignite.ml.inference.storage.model.ModelStorageFactory
Returns model storage based on Apache Ignite cache.
getModeNames() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getModificationTime() - Method in class org.apache.ignite.ml.inference.storage.model.FileStat
 
getModificationTs() - Method in interface org.apache.ignite.ml.inference.storage.model.FileOrDirectory
Returns time since file modification.
getModuleName() - Method in class org.apache.ignite.springdata22.repository.config.IgniteRepositoryConfigurationExtension
getModulePrefix() - Method in class org.apache.ignite.springdata22.repository.config.IgniteRepositoryConfigurationExtension
getMovingPartitionsAllocationMap() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets allocation map of partitions with state MOVING in the cluster.
getMulticastGroup() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets IP address of multicast group.
getMulticastPort() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets port number which multicast messages are sent to.
getMultipleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
 
getMutationProbability() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getMutationRate() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve the mutation rate.
getMvccVacuumFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
getMvccVacuumThreadCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
getName() - Method in class org.apache.ignite.cache.QueryIndex
Gets index name.
getName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
 
getName() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns POJO field name.
getName() - Method in interface org.apache.ignite.client.ClientCache
 
getName() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Cache name.
getName() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets data region name.
getName() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Get thread pool name.
getName() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets memory policy name.
getName() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in class org.apache.ignite.ml.dataset.feature.FeatureMeta
 
getName() - Method in class org.apache.ignite.ml.inference.ModelDescriptor
 
getName() - Method in class org.apache.ignite.ml.selection.paramgrid.BruteForceStrategy
Returns the name of strategy.
getName() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
Returns the name of strategy.
getName() - Method in class org.apache.ignite.ml.selection.paramgrid.HyperParameterTuningStrategy
Returns the name of strategy.
getName() - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
Returns the name of strategy.
getName() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets service name.
getName() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource name, either class name or alias name, such as alias specified by ComputeTaskName annotation.
getName() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource name, either class name or alias name, such as alias specified by ComputeTaskName annotation.
getName() - Method in interface org.apache.ignite.spi.IgniteSpi
Gets SPI name.
getName() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets SPI name.
getName() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets name of the SPI.
getName() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets name of the SPI.
getName() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Gets SPI name.
getName() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Gets file name.
getNameMapper() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets name mapper.
getNameMapper() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets name mapper.
getNameMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getNamespace() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Get Kubernetes namespace.
getNativeFactory() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
Gets the wrapped factory object.
getNaturalIdValues(Object) - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
getNearConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
 
getNearEvictionPolicy() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
getNearEvictionPolicyFactory() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Gets cache eviction policy factory.
getNearStartSize() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Gets initial cache size for near cache which will be used to pre-create internal hash table after start.
getNeedClientAuth() - Method in class org.apache.ignite.ssl.SslContextFactory
Returns true if SSL needs client authentication.
getNetworkCompressionLevel() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Compression level of internal network messages.
getNetworkSendRetryCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Message send retries count.
getNetworkSendRetryDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Interval in milliseconds between message send retries.
getNetworkTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Maximum timeout in milliseconds for network requests.
getNetworkTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets network timeout.
getNetworkTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets network timeout.
getNode() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets node this job executed on.
getNode() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getNode(UUID) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets node by ID.
getNode(UUID) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets node by ID.
getNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets node by ID.
getNode(UUID) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets node by ID.
getNode0(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
getNodeAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeFilter() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets filter which determines on what nodes the cache should be started.
getNodeFilter() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getNodeFilter() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets node filter used to filter nodes on which the service will be deployed.
getNodeId() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getNodeId() - Method in class org.apache.ignite.logger.java.JavaLogger
Gets node ID.
getNodeId() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Gets node ID.
getNodeId() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Gets node ID.
getNodeId() - Method in interface org.apache.ignite.logger.LoggerNodeIdAware
Deprecated.
Gets node ID.
getNodeId() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer.NodeImpurityHistograms
 
getNodeId() - Method in class org.apache.ignite.tensorflow.cluster.spec.TensorFlowServerAddressSpec
 
getNodeId() - Method in class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcess
 
getNodeId() - Method in class org.apache.ignite.tensorflow.core.nativerunning.NativeProcess
 
getNodeOrder() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets node join order.
getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets failed nodes count.
getNodesFailed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets failed nodes count.
getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets failed nodes count.
getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets joined nodes count.
getNodesJoined() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets joined nodes count.
getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets joined nodes count.
getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets left nodes count.
getNodesLeft() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets left nodes count.
getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets left nodes count.
getNodeStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the start time of grid node in milliseconds.
getNodeStartTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the start time of grid node in milliseconds.
getNodeWeight() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
getNodeWeight() - Method in interface org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpiMBean
Gets weight of this node.
getNonHeapMemoryCommitted() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of non-heap memory in bytes that is committed for the JVM to use.
getNonHeapMemoryCommitted() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of non-heap memory in bytes that is committed for the JVM to use.
getNonHeapMemoryInitialized() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of non-heap memory in bytes that the JVM initially requests from the operating system for memory management.
getNonHeapMemoryInitialized() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of non-heap memory in bytes that the JVM initially requests from the operating system for memory management.
getNonHeapMemoryMaximum() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the maximum amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryMaximum() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the maximum amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryTotal() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the total amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryTotal() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the total amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryUsed() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current non-heap memory size that is used by Java VM.
getNonHeapMemoryUsed() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current non-heap memory size that is used by Java VM.
getNonLoopbackAddress() - Static method in class org.apache.ignite.mesos.ClusterProperties
Finds a local, non-loopback, IPv4 address
getNotNullFields() - Method in class org.apache.ignite.cache.QueryEntity
Gets names of fields that must be checked for null.
getNumberOfRetries() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets number of retries in case of DB failure.
getNumberOfRetries() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets number of retries in case of DB failure.
getObj() - Method in class org.apache.ignite.ml.recommendation.ObjectSubjectPair
Returns object of recommendation.
getObjects() - Method in class org.apache.ignite.ml.recommendation.util.RecommendationDatasetData
Returns set of objects contained in RecommendationDatasetData.ratings.
getObjGrad() - Method in class org.apache.ignite.ml.recommendation.util.MatrixFactorizationGradient
Returns gradient of object of recommendation matrix (unmodifiable).
getOdbcConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getOffHeapAllocatedSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets memory size allocated in off-heap.
getOffHeapAllocatedSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets memory size allocated in off-heap.
getOffHeapBackupEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of backup entries stored in off-heap memory.
getOffHeapBackupEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets number of backup entries stored in off-heap memory.
getOffHeapEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of entries stored in off-heap memory.
getOffHeapEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets number of entries stored in off-heap memory.
getOffHeapEvictions() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of evictions from the off-heap memory.
getOffHeapEvictions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of evictions from the off-heap memory.
getOffHeapGets() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of get requests to the off-heap memory.
getOffHeapGets() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of get requests to the off-heap memory.
getOffHeapHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the percentage of hits on off-heap memory.
getOffHeapHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets the percentage of hits on off-heap memory.
getOffHeapHits() - Method in interface org.apache.ignite.cache.CacheMetrics
The number of get requests that were satisfied by the off-heap memory.
getOffHeapHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The number of get requests that were satisfied by the off-heap memory.
getOffHeapMaxMemory() - Method in class org.apache.ignite.configuration.CollectionConfiguration
Deprecated.
No longer used.
getOffHeapMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
A miss is a get request that is not satisfied by off-heap memory.
getOffHeapMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
A miss is a get request that is not satisfied by off-heap memory.
getOffHeapMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the percentage of misses on off-heap memory.
getOffHeapMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets the percentage of misses on off-heap memory.
getOffHeapPrimaryEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of primary entries stored in off-heap memory.
getOffHeapPrimaryEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets number of primary entries stored in off-heap memory.
getOffHeapPuts() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of put requests to the off-heap memory.
getOffHeapPuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of put requests to the off-heap memory.
getOffHeapRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of removals from the off-heap memory.
getOffHeapRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
The total number of removals from the off-heap memory.
getOffHeapSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Total offheap size in bytes.
getOffHeapSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Total offheap size in bytes.
getOffHeapSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Total offheap size in bytes.
getOffHeapSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Total offheap size in bytes.
getOffheapUsedSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Metric is redundant, it's effectively equals to DataRegionMetrics.getPhysicalMemorySize() value.
getOffheapUsedSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Total used offheap size in bytes.
getOffheapUsedSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Total used offheap size in bytes.
getOffheapUsedSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Total used offheap size in bytes.
getOperationProgress() - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
 
getOpt() - Method in interface org.apache.ignite.ml.environment.parallelism.Promise
Wrap result of Future to Optional-object.
getOptions(Method) - Static method in class org.apache.ignite.springdata22.repository.query.IgniteQueryGenerator
Determines whether query is dynamic or not (by list of method parameters)
getOrCreateCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache with default configuration if it does not exist.
getOrCreateCache(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache if it does not exist.
getOrCreateCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Gets existing cache with the given name or creates new one with the given configuration.
getOrCreateCache(String) - Method in interface org.apache.ignite.Ignite
Gets existing cache with the given name or creates new one using template configuration.
getOrCreateCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Gets existing cache with the given cache configuration or creates one if it does not exist.
getOrCreateCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing cache with the given name or creates new one with the given configuration.
getOrCreateCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing cache with the given cache configuration or creates one if it does not exist.
getOrCreateCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing cache with the given name or creates new one using template configuration.
getOrCreateCache(String) - Method in class org.apache.ignite.springdata.proxy.IgniteClientProxy
Gets existing cache with the given name or creates new one.
getOrCreateCache(String) - Method in interface org.apache.ignite.springdata.proxy.IgniteProxy
Gets existing cache with the given name or creates new one.
getOrCreateCache(String) - Method in class org.apache.ignite.springdata.proxy.IgniteProxyImpl
Gets existing cache with the given name or creates new one.
getOrCreateCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache with default configuration if it does not exist.
getOrCreateCacheAsync(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache if it does not exist.
getOrCreateCaches(Collection<CacheConfiguration>) - Method in interface org.apache.ignite.Ignite
Gets existing caches with the given name or created one with the given configuration.
getOrCreateCaches(Collection<CacheConfiguration>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing caches with the given name or created one with the given configuration.
getOrCreateCondition(String) - Method in interface org.apache.ignite.IgniteLock
Returns a Condition instance for use with this IgniteLock instance.
getOrCreateMetricRegistry(String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns exisiting or newly created instance of metric registry with given name.
getOrCreateNearCache(String, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Gets existing near cache with the given name or creates a new one.
getOrCreateNearCache(String, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing near cache with the given name or creates a new one.
getOrOpenForFile(int, int) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
getOrStart(IgniteConfiguration) - Static method in class org.apache.ignite.Ignition
Gets or starts new grid instance if it hasn't been started yet.
getOsInformation() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getOsUser() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets outbound messages queue size.
getOutgoingPayload() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getOutputMsg() - Method in class org.apache.ignite.ml.inference.ModelSignature
 
getOverflowMode() - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Gets overflow mode defining how store will behave in case of overflow.
getOwnerTransactionsNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of active transactions for which this node is the initiator.
getOwnerTransactionsNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of active transactions for which this node is the initiator.
getOwningPartitionsAllocationMap() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets allocation map of partitions with state OWNING in the cluster.
getP() - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Returns the P rows permutation matrix.
getPageEvictionMode() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets memory pages eviction mode.
getPageEvictionMode() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets memory pages eviction mode.
getPageIo(int, int) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
 
getPageReplacementMode() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets memory pages replacement mode.
getPagesFillFactor() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Returns the ratio of space occupied by user and system data to the size of all pages that contain this data.
getPagesFillFactor() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets the percentage of space that is still free and can be filled in.
getPagesFillFactor() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets the percentage of space that is still free and can be filled in.
getPagesFillFactor() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Returns the ratio of space occupied by user and system data to the size of all pages that contain this data.
getPagesFillFactor() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets the percentage of space that is still free and can be filled in.
getPageSize() - Method in class org.apache.ignite.cache.query.Query
Gets optional page size, if 0, then default is used.
getPageSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
The page memory consists of one or more expandable data regions defined by DataRegionConfiguration.
getPageSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
The pages memory consists of one or more expandable memory regions defined by MemoryPolicyConfiguration.
getPageSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets memory page size.
getPageSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets memory page size.
getPagesRead() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
The number of read pages from last restart.
getPagesRead() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
The number of read pages from last restart.
getPagesRead() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
The number of read pages from last restart.
getPagesRead() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
The number of read pages from last restart.
getPagesReplaceAge() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets average age (in milliseconds) for the pages being replaced from the disk storage.
getPagesReplaceAge() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets average age (in milliseconds) for the pages being replaced from the disk storage.
getPagesReplaced() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
The number of replaced pages from last restart .
getPagesReplaced() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
The number of replaced pages from last restart.
getPagesReplaced() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
The number of replaced pages from last restart .
getPagesReplaced() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
The number of replaced pages from last restart.
getPagesReplaceRate() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesWritten() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
The number of written pages from last restart.
getPagesWritten() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
The number of written pages from last restart.
getPagesWritten() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
The number of written pages from last restart.
getPagesWritten() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
The number of written pages from last restart.
getParallelism() - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy
Returns default parallelism.
getParallelism() - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy
Returns default parallelism.
getParallelism() - Method in interface org.apache.ignite.ml.environment.parallelism.ParallelismStrategy
Returns default parallelism.
getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
getParallelJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets number of jobs that can be executed in parallel.
getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets number of jobs that can be executed in parallel.
getParallelJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets number of jobs that can be executed in parallel.
getParallelLoadCacheMinimumThreshold() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Parallel load cache minimum row count threshold.
getParallelLoadCacheMinimumThreshold() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Parallel load cache minimum row count threshold.
getParamNameByIndex(int) - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
Returns the name of hyper-parameter by the given index.
getParamRawData() - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
Prepare data for hyper-parameter tuning.
getParamValuesByParamIdx() - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
 
getParent() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Gets parent.
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcDriver
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getParser() - Method in class org.apache.ignite.ml.inference.ModelDescriptor
 
getPartition() - Method in class org.apache.ignite.cache.query.IndexQuery
Gets partition number over which this query should iterate.
getPartition() - Method in class org.apache.ignite.cache.query.ScanQuery
Gets partition number over which this query should iterate.
getPartitionId() - Method in class org.gridgain.grid.persistentstore.SnapshotIssue
 
getPartitionIds() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Local partition ids.
getPartitionLossPolicy() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets partition loss policy.
getPartitionLossPolicy() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets partition loss policy.
getPartitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets total number of key partitions.
getPartitions() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets partitions for query, in ascending order.
getPartitions() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets partitions for query, in ascending order.
getPartitions() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Gets count of partitions for this cache group.
getPartitionsWritten() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Partitions written during snapshot creation.
getPartitionsWritten(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Partitions written during snapshot creation.
getPartitionUpdateCounter() - Method in class org.apache.ignite.cache.CacheInterceptorEntry
Each cache update increases partition counter.
getPartitionUpdateCounter() - Method in class org.apache.ignite.cache.query.CacheQueryEntryEvent
Each cache update increases partition counter.
getPasscodesFormatted() - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Gets text presentation of the valid passcodes collection.
getPasscodesFormatted() - Method in interface org.gridgain.grid.security.passcode.PasscodeAuthenticatorMBean
Gets text presentation of the valid passcodes collection.
getPassphrase() - Method in class org.gridgain.grid.configuration.SftpConfiguration
 
getPassword() - Method in interface org.apache.ignite.cache.store.cassandra.datasource.Credentials
Returns password
getPassword() - Method in class org.apache.ignite.cache.store.cassandra.datasource.PlainCredentials
Returns password
getPassword() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getPassword() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets password.
getPatchOperations() - Method in class org.apache.ignite.cache.QueryEntityPatch
 
getPath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Gets path.
getPeerClassLoadingLocalClassPathExclude() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return list of packages from the system classpath that need to be peer-to-peer loaded from task originating node. '*' is supported at the end of the package name which means that all sub-packages and their classes are included like in Java package import clause.
getPeerClassLoadingMissedResourcesCacheSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns missed resources cache size.
getPeerClassLoadingThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool which is in charge of peer class loading requests/responses.
getPendingMessagesDiscarded() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets pending messages discarded count.
getPendingMessagesDiscarded() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets pending messages discarded count.
getPendingMessagesRegistered() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets pending messages registered count.
getPendingMessagesRegistered() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets pending messages registered count.
getPermissionsProvider() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Gets permissions provider.
getPerNodeBufferSize() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets per-node data buffer size.
getPerNodeBufferSize() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets data center replication data loader per node buffer size.
getPerNodeParallelLoadOperations() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets per-node parallel load operations.
getPerNodeParallelLoadOperations() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets per node parallel load operations.
getPersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns Ignite cache persistence settings.
getPersistenceSettings() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Returns Ignite cache key/value persistence settings.
getPersistenceSettings() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Persistence settings to use for an operation.
getPersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Returns Ignite cache key/value persistence settings.
getPersistenceSettings() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Returns Ignite cache key/value persistence settings.
getPersistentStoreConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Part of old API. Use DataStorageConfiguration for configuring persistence instead.
getPersistentStorePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Returns a path the root directory where the Persistent Store will persist data and indexes.
getPessimisticTxLogLinger() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets delay, in milliseconds, after which pessimistic recovery entries will be cleaned up for failed node.
getPessimisticTxLogSize() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets size of pessimistic transactions log stored on node in order to recover transaction commit if originating node has left grid before it has sent all messages to transaction nodes.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemorySize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets total size of pages loaded to the RAM.
getPhysicalMemorySize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets total size of pages loaded to the RAM.
getPivot() - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Returns the pivot permutation vector.
getPixels() - Method in class org.apache.ignite.ml.util.MnistUtils.MnistImage
 
getPlatformCacheConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets platform cache configuration.
getPlatformConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets platform configuration.
getPluginConfigurations() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets array of cache plugin configurations.
getPluginConfigurations() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getPluginProviders() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets plugin providers.
getPnt() - Method in class org.apache.ignite.ml.knn.utils.PointWithDistance
 
getPojoFieldAccessor(Class, String) - Static method in class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
Returns property accessor by class property name.
getPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the current number of threads in the pool.
getPopulationSize() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve the population size
getPort() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get port.
getPort() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets port for TCP binary protocol server.
getPort() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get port.
getPort() - Method in class org.apache.ignite.tensorflow.cluster.spec.TensorFlowServerAddressSpec
 
getPort() - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
getPortRange() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get port range.
getPortRange() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets number of ports to try if configured port is already in use.
getPortRange() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get port range.
getPrediction() - Method in class org.apache.ignite.ml.selection.scoring.LabelPair
 
getPredictionsAggregator() - Method in class org.apache.ignite.ml.composition.ModelsComposition
Returns predictions aggregator.
getPreparedId() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getPreprocessor() - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
 
getPreviousSnapshots(Set<Integer>, Collection<SnapshotPath>) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
Get iterable with previous snapshots (if this snapshot is incremental) of specific cache groups.
getPrimaryKeyDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Returns Cassandra DDL for primary key.
getPriorityAttributeKey() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets key name of task priority attribute.
getPriorityAttributeKey() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets key name of task priority attribute.
getProbabilities() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
 
getProcBuilderSupplier() - Method in class org.apache.ignite.tensorflow.core.nativerunning.NativeProcess
 
getProcessed() - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
 
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).
getProcesses() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowCluster
 
getProcessorCoefficient() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Gets coefficient of every CPU processor.
getProgress() - Method in class org.apache.ignite.yarn.ApplicationMaster
getProgress() - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
 
getProjection(String) - Static method in class org.apache.ignite.springdata22.repository.query.QueryUtils
Returns the projection part of the query, i.e. everything between select and from.
getProjector(int[]) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Get projector from index mapping.
getProperties() - Method in class org.apache.ignite.cache.CacheManager
getProperties() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
Gets a map of properties.
getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Get properties.
getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Get properties.
getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Get properties.
getPropertyInfo(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
getPropertyInfo(String, Properties) - Method in class org.apache.ignite.IgniteJdbcThinDriver
getProto() - Method in class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
 
getProtocol() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets protocol for secure transport.
getProtocols() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets enabled protocols.
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.
getPublicThreadPoolSize() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets a public thread pool size to be used in grid.
getPwd() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets checkpoint jdbc password.
getPwd() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets checkpoint jdbc password.
getQueryDetailMetricsSize() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getQueryDetailMetricsSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets size of queries detail metrics that will be stored in memory for monitoring purposes.
getQueryEntities() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets a collection of configured query entities.
getQueryInitiatorId() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
getQueryKeyspace() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getQueryLookupStrategy(QueryLookupStrategy.Key, QueryMethodEvaluationContextProvider) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
getQueryMethod() - Method in class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery
getQueryParallelism() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getQueryParallelism() - Method in class org.apache.ignite.configuration.CacheConfiguration
Defines a hint to query execution engine on desired degree of parallelism within a single node.
getQueryString() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getQueryString(String, String) - Static method in class org.apache.ignite.springdata22.repository.query.QueryUtils
Returns the query string for the given class name.
getQueryThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing query messages.
getQueueLength() - Method in interface org.apache.ignite.IgniteSemaphore
Returns an estimate of the number of nodes waiting to acquire.
getQueueSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
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.
getR1norm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getR2norm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getRateTimeInterval() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
getRateTimeInterval() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
getRating() - Method in class org.apache.ignite.ml.recommendation.ObjectSubjectRatingTriplet
Returns rating.
getRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the value at specified index.
getRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the value at specified index.
getRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
getRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
getRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
getRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
getRaw() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector.Element
Gets element's value.
getRaw(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the value at specified index.
getRaw(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
 
getRaw(int) - Method in class org.apache.ignite.ml.structures.DatasetRow
Gets the value at specified index.
getRawX(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the value at specified index without checking for index boundaries.
getRawX(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the value at specified index without checking for index boundaries.
getRawX(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the value at specified index without checking for index boundaries.
getReadBufferSize() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets read buffer size.
getReadBufferSize() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets read buffer size.
getReader() - Method in class org.apache.ignite.ml.inference.ModelDescriptor
 
getReadTimeout() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets read timeout.
getReadTimeout() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets read timeout in milliseconds.
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.client.ClientCacheConfiguration
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and provide one new to each next demand request.
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
The number of batches generated by supply node at rebalancing procedure start.
getRebalanceBatchSize() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets size (in number bytes) to be loaded within a single rebalance message.
getRebalanceBatchSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceBatchSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
The supply message size in bytes to be loaded within a single rebalance batch.
getRebalanceClearingPartitionsLeft() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalanceClearingPartitionsLeft() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getRebalanceDelay() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets delay in milliseconds upon a node joining or leaving topology (or crash) after which rebalancing should be started automatically.
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.
getRebalancedKeys() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancedKeys() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getRebalanceMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets rebalance mode.
getRebalanceMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets rebalance mode for distributed cache.
getRebalanceOrder() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets cache rebalance order.
getRebalanceOrder() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache rebalance order.
getRebalanceThreadPoolSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
getRebalanceThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Max count of threads can be used at rebalancing.
getRebalanceThrottle() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
getRebalanceThrottle() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceThrottle() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
getRebalanceTimeout() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets rebalance timeout (ms).
getRebalanceTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Rebalance timeout for supply and demand messages in milliseconds.
getRebalancingBytesRate() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingBytesRate() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getRebalancingKeysRate() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingKeysRate() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getRebalancingPartitionsCount() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getRebalancingStartTime() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingStartTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getReceiveBufferSize() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getReceiveBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server receive buffer size in bytes.
getReceivedBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets received bytes count.
getReceivedBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received bytes count.
getReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets received messages counts (grouped by type).
getReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets received messages counts (grouped by type).
getReceivedMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received messages counts (grouped by node).
getReceivedMessagesByNode() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received messages counts (grouped by node).
getReceivedMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received messages counts (grouped by type).
getReceivedMessagesByType() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received messages counts (grouped by type).
getReceivedMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets received messages count.
getReceivedMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received messages count.
getReceiverAddresses() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets addresses of remote receiver hubs.
getReconnectCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of reconnect attempts used when establishing connection with remote nodes.
getReconnectCount() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets number of connection attempts.
getReconnectCount() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets number of connection attempts.
getReconnectDelay() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets the amount of time in milliseconds that node waits before retrying to (re)connect to the cluster.
getReconnectOnFailureTimeout() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets reconnect-on-failure timeout.
getReconnectOnFailureTimeout() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Timeout after which node can be reconnected in case it was previously disconnected due to a failure.
getReconnectThrottlingPeriod() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets reconnect throttling period.
getReconnectThrottlingRetries() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets reconnect throttling retries.
getReencryptionBatchSize() - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Gets the number of pages that is scanned during re-encryption under checkpoint lock.
getReencryptionRateLimit() - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Gets re-encryption rate limit.
getRegion() - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Gets all addresses registered in this finder.
getRegistryCache() - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotInputStreamFactory
 
getRegistryTransformer() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
getRejectedExecutionHandlerClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
The class name of the handler for tasks that cannot be executed.
getRemoteFilter() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets remote filter.
getRemoteFilterFactory() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets remote filter.
getRemoteNodes() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteTransformerFactory() - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Gets remote transformer factory
getRepositoryBaseClass(RepositoryMetadata) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
getRepositoryFactoryBeanClassName() - Method in class org.apache.ignite.springdata22.repository.config.IgniteRepositoryConfigurationExtension
getRepositoryMetadata(Class<?>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
getResourceClass() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource class.
getResourceClass() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource class.
getResourceFactory() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
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.
getRestoreOperationParallelism() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Snapshot restore operation parallelism level.
getRetries() - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
getRetryLimit() - Method in class org.apache.ignite.configuration.ClientConfiguration
Get retry limit.
getRetryPolicy() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getRetryPolicy() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the retry policy.
getRetryPolicy() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
getRight() - Method in class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasure
 
getRight() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
getRightCnt() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
 
getRightY() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
 
getRightY2() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
 
getRole() - Method in class org.apache.ignite.mesos.IgniteFramework
 
getRootNode() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeRoot
 
getRootPath() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets root directory path for storage.
getRoutingKey() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getRow(int) - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetPartition
Returns vector from dataset in according to row id.
getRow(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Get a specific row from matrix.
getRow(int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Get a specific row from matrix.
getRow(int) - Method in class org.apache.ignite.ml.structures.Dataset
Retrieves Labeled Vector by given index.
getRows() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleDatasetData
 
getRows() - Method in class org.apache.ignite.ml.dataset.primitive.data.SimpleLabeledDatasetData
 
getRows() - Method in class org.apache.ignite.ml.recommendation.util.MatrixFactorizationGradient
Returns number of rows the gradient calculated on.
getRowsCount() - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetPartition
Returns rows count.
getRuleIndex() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
getRuleIndex() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
getRuleIndex() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
getRuleIndex() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
getRuleIndex() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
getRuleIndex() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
getRuleNames() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getRuleNames() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
getSamplesBufferSize() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Returns size of the buffer that should hold samples collected for dictionary training.
getSatisfactoryFitness() - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
 
getScanners() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets scanners.
getSchema() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Get schema for the query.
getSchema() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getSchema() - Method in class org.apache.ignite.ml.inference.ModelSignature
 
getScoringBoard() - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
Gets the Scoring Board.
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.
getSecurityCredentialsProvider() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets security credentials.
getSecurityThreadPoolSize() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Size of thread pool that is in charge of processing authorization and expiration of thin clients.
getSeed() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the multilayer perceptron model initializer.
getSeed() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Get the seed for random generator.
getSeed() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Get the seed for random generator.
getSeed() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getSeed() - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
Returns the seed.
getSeed() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Get the seed number.
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.
getSelectionMtd() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Get the selection method
getSelectionStgy() - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
getSelectorCount() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get count of selectors to use in TCP server.
getSelectorCount() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets number of selector threads in REST TCP server.
getSelectorCount() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets amount of selector threads in receiver hub's TCP server.
getSelectorCount() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets number of selector threads in receiver hub's TCP server.
getSelectorsCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets count of selectors used in TCP server.
getSelectorSpins() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Defines how many non-blocking selector.selectNow() should be made before falling into selector.select(long) in NIO server.
getSendBufferSize() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSendBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server send buffer size.
getSenderGroup() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets sender group name which sender will be used for replication.
getSenderGroups() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Get group this sender hub will participate in.
getSenderGroups() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets group names this sender hub participate in.
getSendQueueLimit() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server send queue limit.
getSentBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets sent bytes count.
getSentBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets sent bytes count.
getSentBytesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets sent bytes count.
getSentBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent bytes count.
getSentBytesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent bytes count.
getSentMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent messages counts (grouped by node).
getSentMessagesByNode() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent messages counts (grouped by node).
getSentMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent messages counts (grouped by type).
getSentMessagesByType() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent messages counts (grouped by type).
getSentMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets sent messages count.
getSentMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent messages count.
getSeparator() - Method in enum org.apache.ignite.ml.util.MLSandboxDatasets
 
getSerialConsistencyLevel() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getSerializedATN() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getSerializedATN() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
getSerializer() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets serializer.
getSerializer() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns serializer to be used for BLOBs.
getSerializer() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets serializer.
getSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getServerUri() - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
getService() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets service instance.
getServiceConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configurations for services to be deployed on the grid.
getServiceName() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Get Kubernetes service name.
getServiceName() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
getServiceThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return a thread pool size to be used in grid.
getSessionFactory() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
Gets Hibernate session factory.
getSessionTimeout() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getSetterByIndex(int) - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
Returns setter for parameter with the given index.
getSftpConfiguration() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
getSharedMemoryPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets local port for shared memory communication.
getShutdownPolicy() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets shutdown policy.
getSigmas() - Method in class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerPreprocessor
 
getSignature() - Method in class org.apache.ignite.ml.inference.ModelDescriptor
 
getSingleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
 
getSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
Can overflow. Use CacheMetrics.getCacheSize() instead.
getSize() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Get thread pool size.
getSize() - Method in class org.apache.ignite.ml.inference.storage.model.FileStat
 
getSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets number of non-null values in the cache.
getSizeInMemory() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
getSizeInMemory() - Method in class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
getSleepSummary() - Method in class org.apache.ignite.cache.store.cassandra.common.RandomSleeper
Returns summary sleep time.
getSlowClientQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets slow client queue limit.
getSnapshotConfiguration() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets GridGain snapshot configuration.
getSnapshotLabel() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Snapshot folder label.
getSnapshotOperationParallelism() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Snapshot Operation parallelism level.
getSnapshotProgressThrottlingInterval() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
getSnapshotsCatalogConnectorConfiguration() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Deprecated.
Snapshot Catalog functionality was removed from GridGain completely as obsolete. Providing configuration for Catalog Connectior won't have any effect.
getSnapshotsPath() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Gets database snapshot SPI.
getSocketReceiveBuffer() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getSocketReceiveBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets receive buffer size for sockets created or accepted by this SPI.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets socket receive buffer size.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Gets socket receive buffer size.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Gets socket receive buffer size.
getSocketReceiveBufferSize() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets socket receive buffer size in bytes.
getSocketReceiveBufferSize() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets socket receive buffer size in bytes.
getSocketSendBuffer() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getSocketSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets send buffer size for sockets created or accepted by this SPI.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets socket send buffer size.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Gets socket send buffer size.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Gets socket send buffer size.
getSocketSendBufferSize() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets socket send buffer size in bytes.
getSocketSendBufferSize() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets socket send buffer size in bytes.
getSocketTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets socket timeout.
getSocketTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets socket timeout.
getSocketWriteTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets socket write timeout for TCP connections.
getSoLinger() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets SO_LINGER timeout for socket.
getSolutionById(int) - Static method in class org.apache.ignite.ml.genetic.functions.GAGridFunction
Retrieve and individual solution by Chromosome key.
getSolutionsAsc() - Static method in class org.apache.ignite.ml.genetic.functions.GAGridFunction
Retrieve solutions in ascending order based on fitness score.
getSolutionsDesc() - Static method in class org.apache.ignite.ml.genetic.functions.GAGridFunction
Retrieve solutions in descending order based on fitness score.
getSortOrder() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Returns sort order for the field.
getSpanContainer() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getSparseStorageSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Storage space allocated adjusted for possible sparsity in bytes.
getSparseStorageSize() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Storage space allocated for group adjusted for possible sparsity, in bytes.
getSparseStorageSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Storage space allocated adjusted for possible sparsity in bytes.
getSparsityCheckFrequency() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets frequency to check sparsity of files for compaction.
getSpec() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowCluster
 
getSpiContext() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets SPI context.
getSpiContext() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets SPI context.
getSpiContext() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets SPI context.
getSpiState() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets current SPI state.
getSpiState() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets current SPI state.
getSpiState() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets current SPI state.
getSql() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets SQL clause.
getSql() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets SQL clause.
getSqlConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets initial configuration of the SQL subsystem.
getSqlConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getSqlFunctionClasses() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets classes with methods annotated by QuerySqlFunction to be used as user-defined functions from SQL queries.
getSqlGlobalMemoryQuota() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getSqlGlobalMemoryQuota() - Method in class org.apache.ignite.configuration.SqlConfiguration
Returns global memory pool size for SQL queries.
getSqlIndexMaxInlineSize() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getSqlIndexMaxInlineSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum inline size for sql indexes.
getSqlOnheapCacheMaxSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum SQL on-heap cache.
getSqlQueryHistorySize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getSqlQueryHistorySize() - Method in class org.apache.ignite.configuration.SqlConfiguration
Number of SQL query history elements to keep in memory.
getSqlQueryMemoryQuota() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getSqlQueryMemoryQuota() - Method in class org.apache.ignite.configuration.SqlConfiguration
Returns per-query memory quota.
getSqlSchema() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getSqlSchema() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets custom name of the sql schema.
getSqlSchemas() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getSqlSchemas() - Method in class org.apache.ignite.configuration.SqlConfiguration
Gets SQL schemas to be created on node startup.
getSrvProcMgr() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
 
getSSEAlgorithm() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Gets S3 server-side encryption algorithm.
getSSEAlgorithm() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
 
getSslClientCertificateKeyStorePassword() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslClientCertificateKeyStorePassword() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets key store password.
getSslClientCertificateKeyStorePath() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslClientCertificateKeyStoreType() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslClientCertificateKeyStoreType() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets key store type used for context creation.
getSslClientCertificateKeyStoreUrl() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets the key store URL.
getSslContextFactory() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslContextFactory() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Returns SSL context factory that will be used for creating a secure socket layer.
getSslContextFactory() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Deprecated.
getSslContextFactory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns SSL context factory that will be used for creating a secure socket layer.
getSslContextFactory() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets SSL context factory.
getSslContextFactory() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets SSL context factory.
getSslFactory() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets context factory that will be used for creating a secure socket layer of rest binary server.
getSslFactory() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets the class name of the custom implementation of the Factory<SSLSocketFactory>.
getSslKeyAlgorithm() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslKeyAlgorithm() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets algorithm that will be used to create a key manager.
getSslMode() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslMode() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets SSL connection mode.
getSslProtocol() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslProtocol() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets protocol for secure transport.
getSslTrustCertificateKeyStorePassword() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslTrustCertificateKeyStorePassword() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets trust store password.
getSslTrustCertificateKeyStorePath() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslTrustCertificateKeyStoreType() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslTrustCertificateKeyStoreType() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets trust store type.
getSslTrustCertificateKeyStoreUrl() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets the trust store URL.
getStageNum() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
getStartStageTime() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
getStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the start time of the JVM in milliseconds.
getStartTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets start of computation time for the task.
getStartTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the start time of the JVM in milliseconds.
getStartTime() - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
 
getStartTimeLocal() - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
 
getStartTimestamp() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getStartTimestamp() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Get start timestamp of this SPI.
getStartTimestamp() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Get start timestamp of this SPI.
getStartTimestampFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getStartTimestampFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets string presentation of the start timestamp.
getStartTimestampFormatted() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets string presentation of the start timestamp.
getStarvationIncrement() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets value to increment job priority by every time a lower priority job gets behind a higher priority job.
getStarvationIncrement() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets value to increment job priority by every time a lower priority job gets behind a higher priority job.
getState() - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Gets state of default grid instance.
getState(String) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Gets state for a given grid instance.
getState() - Method in class org.apache.ignite.tensorflow.core.longrunning.task.util.LongRunningProcessStatus
 
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Returns unbind CLQ statement for to be executed inside batch operation.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchLoaderAssistant
Returns CQL statement to use in batch load operation.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Returns CQL statement to be used for an operation.
getStatement() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Returns unbind CLQ statement for to be executed.
getStatement() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Returns unbind CLQ statement for to be executed.
getStatement() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Returns unbind CLQ statement for to be executed.
getStateTransferBatchSendSizeBytes() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets full state transfer batch size in bytes.
getStateTransferThreadsCount() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
getStateTransferThrottle() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Gets state transfer throttle.
getStateTransferThrottle() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
getStateTransferThrottleBytes() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Gets state transfer throttle bytes.
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.
getStatus() - Method in interface org.gridgain.grid.ru.GridGainRollingUpgrade
Returns cluster-wide status of Rolling Upgrade process.
getStdin() - Method in class org.apache.ignite.tensorflow.core.nativerunning.NativeProcess
 
getStealingAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getStealingAttributes() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Configuration parameter to enable stealing to/from only nodes that have these attributes set (see ClusterNode.attribute(String) and IgniteConfiguration.getUserAttributes() methods).
getStorage() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets matrix storage model.
getStorage() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets matrix storage model.
getStorage() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets vector storage model.
getStorage() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets vector storage model.
getStorage() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets vector storage model.
getStoragePath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getStorageSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Storage space allocated in bytes.
getStorageSize() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Storage space allocated for group, in bytes.
getStorageSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Storage space allocated in bytes.
getStore() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets store.
getStore() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets data store used for this connection.
getStoreConcurrentLoadAllThreshold() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets the threshold used in cases when values for multiple keys are being loaded from an underlying CacheStore in parallel.
getStrategy() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns persistence strategy to use.
getStreamer() - Method in class org.apache.ignite.stream.StreamAdapter
 
getString(String) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getString(String, String) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getStripedPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns striped pool size that should be used for cache requests processing.
getStripesActiveStatuses() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getStripesCompletedTasksCounts() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getStripesCount() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getStripesQueueSizes() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getSubIntervals() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
getSubIntervals() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
getSubj() - Method in class org.apache.ignite.ml.recommendation.ObjectSubjectPair
Returns subject of recommendation.
getSubjects() - Method in class org.apache.ignite.ml.recommendation.util.RecommendationDatasetData
Returns set of subjects contained in RecommendationDatasetData.ratings.
getSubjGrad() - Method in class org.apache.ignite.ml.recommendation.util.MatrixFactorizationGradient
Returns gradient of subject of recommendation function (unmodifiable).
getSumOfValues() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.MeanValueStatistic
 
getSumsHolder() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
 
getSumsHolder() - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
 
getSwapFilePath() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
A path to the memory-mapped files the memory region defined by this memory policy will be mapped to.
getSwapFilePath() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
A path to the memory-mapped files the memory region defined by MemoryPolicyConfiguration will be mapped to.
getSwapPath() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
A path to the memory-mapped files the memory region defined by this data region will be mapped to.
getSwapPath() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
A path to the memory-mapped files the memory region defined by DataRegionConfiguration will be mapped to.
getSyncModel(Ignite, String, SyncModelBuilder) - Static method in class org.apache.ignite.ml.inference.IgniteModelStorageUtil
Retrieves Ignite model by name using synchronous model builder.
getSystemCacheInitialSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Initial size of a memory region reserved for system cache.
getSystemCacheMaxSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Maximum memory region size reserved for system cache.
getSystemRegionInitialSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Initial size of a data region reserved for system cache.
getSystemRegionMaxSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Maximum data region size reserved for system cache.
getSystemRequestTimeout() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets system request timeout.
getSystemRequestTimeout() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets system request timeout.
getSystemThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal system messages.
getSystemViewExporterSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured system view SPI implementations.
getSystemWorkerBlockedTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns maximum inactivity period for system worker.
getSystemWorkerBlockedTimeout() - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
getTable() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns Cassandra table to use.
getTable() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Cassandra table to use for an operation.
getTable() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Cassandra table to use for an operation.
getTable() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.BaseMutation
Cassandra table to use for an operation.
getTable() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Cassandra table to use for an operation.
getTableColumns() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns column names for Cassandra table.
getTableColumns() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns set of database column names, used to persist field values
getTableColumnsDDL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns Cassandra table columns DDL, corresponding to POJO fields which should be persisted.
getTableColumnsDDL(Set<String>) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Returns Cassandra table columns DDL, corresponding to POJO fields which should be persisted.
getTableDDLStatement(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns DDL statement to create Cassandra table.
getTableName() - Method in class org.apache.ignite.cache.QueryEntity
Gets table name for this query entity.
getTag() - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Gets current cluster tag.
getTarget() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Gets target object for method execution.
getTarget() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
Gets target object to execute method on.
getTargetRepository(RepositoryInformation) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
getTargetVersion() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Returns target cluster version.
getTask() - Method in class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcess
 
getTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the approximate total number of tasks that have been scheduled for execution.
getTaskIdx() - Method in class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
 
getTaskName() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets task name of the task this session belongs to.
getTaskNodeId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets ID of the node on which task execution originated.
getTaskSession() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Gets task session of execution grid task.
getTaskSession() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Gets current task session associated with this job.
getTaskSession() - Method in interface org.apache.ignite.spi.failover.FailoverContext
Gets current task session.
getTaskState() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
getTemporaryDirectoryPath() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets temporary directory path.
getTemporaryDirectoryPath() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
Gets temporary directory path.
getTerminateCriteria() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retreive the termination criteria
getTestFilter() - Method in class org.apache.ignite.ml.selection.split.TrainTestSplit
 
getText() - Method in class org.apache.ignite.cache.query.TextQuery
Gets text search string.
getTheBestSolution() - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
Returns the best chromosome's genes presented as double array.
getThenNode() - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
getThinClientConfiguration() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets thin-client specific configuration.
getThreadCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets thread count for warmup.
getThreadFactoryClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns the class name of thread factory used to create new threads.
getThreadPoolSize() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Size of thread pool that is in charge of processing client requests.
getThreadPoolSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Should return a thread pool size to be used for processing of client messages (REST requests).
getThreadPoolSize() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Size of thread pool that is in charge of processing ODBC tasks.
getThreadPoolSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Size of thread pool that is in charge of processing SQL requests.
getThreadPriority() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets thread priority.
getThreadPriority() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets thread priority.
getThreadsCount() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns number of worker threads.
getThreshold() - Method in class org.apache.ignite.ml.preprocessing.binarization.BinarizationPreprocessor
Get the threshold parameter.
getThreshold() - Method in class org.apache.ignite.ml.preprocessing.binarization.BinarizationTrainer
Get the threshold parameter value.
getThreshold() - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
getTimeInterval() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets time interval.
getTimeout() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets the query execution timeout in milliseconds.
getTimeout() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets the query execution timeout in milliseconds.
getTimeout() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getTimeServerPortBase() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets base UPD port number for grid time server.
getTimeServerPortRange() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Defines port range to try for time server start.
getTimeToLive() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Set the default time-to-live for multicast packets sent out on this IP finder.
getTimeUntilAutoAdjust() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
getTlbSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
getTm() - Method in interface org.apache.ignite.cache.jta.CacheTmLookup
Gets Transaction Manager (TM).
getTm() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
Gets Transaction Manager (TM).
getTm() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Gets Transaction Manager (TM).
getTokenNames() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Deprecated.
getTokenNames() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Deprecated.
getTopHist() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getTopHistorySize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
getTopology() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets a collection of grid nodes IDs.
getTopologyValidator() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets topology validator.
getTopologyVersion() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get current topology version.
getTopSnapshot() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getTopVer() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getTotal() - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
 
getTotalAllocatedPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets a total number of allocated pages related to the data region.
getTotalAllocatedPages() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets a total number of allocated pages related to the memory policy.
getTotalAllocatedPages() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets a total number of allocated pages related to the memory policy.
getTotalAllocatedPages() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Cache group total allocated pages.
getTotalAllocatedPages() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets a total number of allocated pages related to the data region.
getTotalAllocatedPages() - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Gets a total number of allocated pages related to the memory policy.
getTotalAllocatedSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets a total size of memory allocated in the data region.
getTotalAllocatedSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Total size of memory allocated in bytes.
getTotalAllocatedSize() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Total size of memory allocated for group, in bytes.
getTotalAllocatedSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets a total size of memory allocated in the data region.
getTotalAllocatedSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Total size of memory allocated in bytes.
getTotalBaselineNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of total baseline nodes.
getTotalBusyTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total time this node spent executing jobs.
getTotalBusyTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total time this node spent executing jobs.
getTotalBytesWrittenOnStorage() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Total bytes written on storage during snapshot creation (including snapshot metadata).
getTotalBytesWrittenOnStorage(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Total bytes written on storage during snapshot creation.
getTotalCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of cancelled jobs since node startup.
getTotalCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of cancelled jobs since node startup.
getTotalClientNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of client nodes.
getTotalCompletedTasksCount() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getTotalCount() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets total number of deployed service instances in the cluster, 0 for unlimited.
getTotalCpus() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the number of CPUs available to the Java Virtual Machine.
getTotalCpus() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the number of CPUs available to the Java Virtual Machine.
getTotalExecutedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of jobs handled by the node since node startup.
getTotalExecutedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of jobs handled by the node since node startup.
getTotalExecutedTasks() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of tasks handled by the node.
getTotalExecutedTasks() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of tasks handled by the node.
getTotalFailedOverJobsCount() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Get total number of jobs that were failed over including stolen ones.
getTotalFailedOverJobsCount() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Get total number of jobs that were failed over including stolen ones.
getTotalFailoverJobsCount() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Get total number of jobs that were failed over.
getTotalFailoverJobsCount() - Method in interface org.apache.ignite.spi.failover.always.AlwaysFailoverSpiMBean
Get total number of jobs that were failed over.
getTotalFitness() - Method in class org.apache.ignite.ml.util.genetic.Population
Returns the total fitness value of population or Double.NaN if not all fitnesses are calculated for all chromosomes.
getTotalIdleTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total time this node spent idling (not executing any jobs).
getTotalIdleTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total time this node spent idling (not executing any jobs).
getTotalJobsExecutionTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total time all finished jobs takes to execute on the node since node startup.
getTotalJobsExecutionTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total time all finished jobs takes to execute on the node since node startup.
getTotalNodes() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of nodes.
getTotalNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of nodes.
getTotalPartitionsCount() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getTotalPartitionsCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
getTotalProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets total processed messages count.
getTotalProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets total processed messages count.
getTotalQueueSize() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
getTotalReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets total received messages count.
getTotalReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets total received messages count.
getTotalRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of jobs this node rejects during collision resolution operations since node startup.
getTotalRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of jobs this node rejects during collision resolution operations since node startup.
getTotalServerNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of server nodes.
getTotalStartedThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the total number of threads created and also started since the JVM started.
getTotalStartedThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the total number of threads created and also started since the JVM started.
getTotalStolenJobsCount() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Get total number of jobs that were stolen.
getTotalStolenJobsCount() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Get total number of jobs that were stolen.
getTotalStolenJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets total number of stolen jobs.
getTotalStolenJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets total number of stolen jobs.
getTotalUsedPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets a total number of pages used for storing the data.
getTotalUsedPages() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets a total number of pages used for storing the data.
getTotalUsedSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Returns the total amount of bytes occupied by the non-empty pages.
getTotalUsedSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Returns the total amount of bytes occupied by the non-empty pages.
getTracingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured tracing SPI implementation.
getTrainer() - Method in class org.apache.ignite.ml.pipeline.Pipeline
Returns trainer.
getTrainFilter() - Method in class org.apache.ignite.ml.selection.split.TrainTestSplit
 
getTransactionConcurrency() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Gets transaction concurrency level.
getTransactionConfiguration() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets transactions configuration.
getTransactionConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets transactions configuration.
getTransactionManager() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Gets transaction manager.
getTransactionManagerLookupClassName() - Method in class org.apache.ignite.configuration.CacheConfiguration
getTransactionsCommittedNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of transactions which were committed.
getTransactionsCommittedNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of transactions which were committed on the local node.
getTransactionsHoldingLockNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of active transactions holding at least one key lock.
getTransactionsHoldingLockNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of active transactions on the local node holding at least one key lock.
getTransactionsRolledBackNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of transactions which were rollback.
getTransactionsRolledBackNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of transactions which were rolled back on the local node.
getTransactionTimeDumpSamplesCoefficient() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns the coefficient for samples of completed transactions that will be dumped in log.
getTransactionTimeDumpSamplesPerSecondLimit() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns the limit of samples of completed transactions that will be dumped in log per second, if TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient() is above 0.0.
getTransformer() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets types transformer.
getTransformer() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets types transformer.
getTransformerName() - Method in interface org.gridgain.grid.persistentstore.SnapshotRegistryTransformer
Gets the name of the transformer algorithm and possibly the essential details on its parameters, if any.
getTruncateRate() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Retrieve truncateRate
getTrustManagers() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets pre-configured trust managers.
getTrustStoreFilePath() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets path to the trust store file.
getTrustStorePassword() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets trust store password.
getTrustStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets trust store type used for context creation.
getTruth() - Method in class org.apache.ignite.ml.selection.scoring.LabelPair
 
getTTL() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns ttl to use for while inserting new rows into Cassandra table.
getTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
Deprecated.
getTxCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxCommitQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
Gets number of cached committed transaction IDs.
getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
Gets number of cached committed DHT transaction IDs.
getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
Gets number of cached rolled back DHT transaction IDs.
getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
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
Deprecated.
Gets transaction DHT per-Xid map size.
getTxKeyCollisions() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks if there were any tx key collisions last time.
getTxKeyCollisions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Checks if there were any tx key collisions last time.
getTxKeyCollisionsInterval() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
 
getTxManagerFactory() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets transaction manager factory for integration with JEE app servers.
getTxManagerLookupClassName() - Method in class org.apache.ignite.configuration.TransactionConfiguration
getTxOwnerDumpRequestsAllowed() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Shows if dump requests from local node to near node are allowed, when long running transaction is found.
getTxPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxPrepareQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
Gets number of cached rolled back transaction IDs.
getTxStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxStartVersionCountsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
Gets transaction per-thread map size.
getTxTimeoutOnPartitionMapExchange() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Some Ignite operations provoke partition map exchange process within Ignite to ensure the partitions distribution state is synchronized cluster-wide.
getTxTimeoutOnPartitionMapExchange() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Gets transaction timeout on partition map exchange.
getTxXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction per-Xid map size.
getTxXidMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets transaction per-Xid map size.
getType() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets type for query.
getType() - Method in class org.apache.ignite.cache.query.TextQuery
Gets type for query.
getType() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
getType() - Method in interface org.apache.ignite.mxbean.CacheGroupMetricsMXBean
Deprecated.
Cache group type.
getTypeConfigurations() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets types configuration.
getTypeName() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets type name.
getTypeName() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
Sets type name for which affinity field name is being defined.
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets .NET type name.
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Gets .NET type name.
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Get type name.
getTypes() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets types known by store.
getTypes() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets types known by store.
getTypes() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getTypesConfiguration() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getU() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRPartitionContext
 
getU() - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Returns the matrix U of the decomposition.
getUnacknowledgedMessagesBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of stored unacknowledged messages per connection to node.
getUpdateBatchSize() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets update internal bach size.
getUpdatedNodes() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Returns a list of alive nodes in the cluster that are upgraded.
getUpdatesCalculator() - Method in class org.apache.ignite.ml.nn.UpdatesStrategy
Get parameter update calculator (see ParameterUpdateCalculator).
getUpdatesStgy() - Method in class org.apache.ignite.ml.nn.MLPTrainer
Get the update strategy that defines how to update model parameters during the training.
getUpdatesStgy() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Get the update strategy.
getUpdatesStgy() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Get the update strategy.
getUpstreamCache() - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDataset
 
getUpstreamCacheName() - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowJobArchive
 
getUpTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the uptime of the JVM in milliseconds.
getUpTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the uptime of the JVM in milliseconds.
getUpTime() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getUpTime() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets up-time of this SPI in ms.
getUpTime() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets up-time of this SPI in ms.
getUpTimeFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getUpTimeFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets string presentation of up-time for this SPI.
getUpTimeFormatted() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets string presentation of up-time for this SPI.
getURI() - Method in class org.apache.ignite.cache.CacheManager
getUriList() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets list of URIs that are processed by SPI.
getUriList() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
Gets list of URIs that are processed by SPI.
getURL() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Different application servers us different format (URL & url).
getUrl() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getUseConsistentId() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
 
getUsedCheckpointBufferPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets used checkpoint buffer size in pages.
getUsedCheckpointBufferPages() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets used checkpoint buffer size in pages.
getUsedCheckpointBufferPages() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets used checkpoint buffer size in pages.
getUsedCheckpointBufferPages() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets used checkpoint buffer size in pages.
getUsedCheckpointBufferSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets used checkpoint buffer size in bytes.
getUsedCheckpointBufferSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets used checkpoint buffer size in bytes.
getUsedCheckpointBufferSize() - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
Deprecated.
Gets used checkpoint buffer size in bytes.
getUsedCheckpointBufferSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets used checkpoint buffer size in bytes.
getUsedFeatures() - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeRoot
 
getUser() - Method in interface org.apache.ignite.cache.store.cassandra.datasource.Credentials
Returns user name
getUser() - Method in class org.apache.ignite.cache.store.cassandra.datasource.PlainCredentials
Returns user name
getUser() - Method in class org.apache.ignite.mesos.IgniteFramework
 
getUser() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets checkpoint jdbc user name.
getUser() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets checkpoint jdbc user name.
getUserAttributes() - Method in class org.apache.ignite.configuration.ClientConfiguration
Returns user attributes which can be used on server node.
getUserAttributes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return any user-defined attributes to be added to this node.
getUserAttributesFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getUserName() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getUsername() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getUserObject() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets user-specific object.
getUserPassword() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getUserScriptException(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Returns an exception that happened during execution or null if there is no exception.
getUtilityCacheKeepAliveTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Keep alive time of thread pool that is in charge of processing utility cache messages.
getUtilityCacheThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Default size of thread pool that is in charge of processing utility cache messages.
getUUID(String, UUID) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getVal() - Method in class org.apache.ignite.ml.genetic.Gene
 
getVal() - Method in class org.apache.ignite.ml.tree.DecisionTreeLeafNode
 
getVal() - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeSplit
 
getValue(Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Returns field value for the object instance.
getValue() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
getValue() - Method in class org.apache.ignite.lang.IgniteBiTuple
getValue(Integer) - Method in interface org.apache.ignite.ml.dataset.feature.Histogram
 
getValue(Integer) - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
getValue() - Method in class org.apache.ignite.ml.dataset.UpstreamEntry
 
getValue(Integer) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
getValue(Integer) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
getValueFieldName() - Method in class org.apache.ignite.cache.QueryEntity
Get value field name.
getValueFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets value field name for checkpoint table.
getValueFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets value field name for checkpoint table.
getValueFields() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns list of Ignite cache value POJO fields to be mapped to Cassandra table columns.
getValueFields() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets optional persistent value fields (needed only if CacheJdbcPojoStore is used).
getValueFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets value field type for checkpoint table.
getValueFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets value field type for checkpoint table.
getValueFromObject(Object, Serializer) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Gets field value as an object having Cassandra compatible type.
getValuePersistenceSettings() - Method in class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Returns persistence settings for Ignite cache values.
getValueType() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines the required type of values for this Cache, if any.
getValueType() - Method in class org.apache.ignite.cache.query.IndexQuery
Cache Value type.
getValueType() - Method in class org.apache.ignite.cache.QueryEntity
Gets value type for this query pair.
getValueType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets value type.
getValueType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Determines the required type of values for this Cache, if any.
getValueTypeName() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Gets fully-qualified platform type name of the cache value used for the local map.
getVar() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getVariables() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
getVariances() - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
 
getVector() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Get the delegating vector
getVmName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
getVocabulary() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
getVocabulary() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
getWaitingJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
getWaitingJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Maximum number of jobs that are allowed to wait in waiting queue.
getWaitingJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Maximum number of jobs that are allowed to wait in waiting queue.
getWaitingJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Maximum number of jobs that are allowed to wait in waiting queue.
getWaitJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getWaitJobsThreshold() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets job count threshold at which this node will start stealing jobs from other nodes.
getWaitQueueLength(IgniteCondition) - Method in interface org.apache.ignite.IgniteLock
Returns an estimate of the number of threads on this node that are waiting on the given condition associated with this lock.
getWalArchivePath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a path to the WAL archive directory.
getWalArchivePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a path to the WAL archive directory.
getWalArchiveSegments() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the current number of WAL segments in the WAL archive.
getWalArchiveSegments() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the current number of WAL segments in the WAL archive.
getWalArchiveSegments() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the current number of WAL segments in the WAL archive.
getWalArchiveSegments() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the current number of WAL segments in the WAL archive.
getWalArchiveSegments() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the current number of WAL segments in the WAL archive.
getWalAutoArchiveAfterInactivity() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalAutoArchiveAfterInactivity() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
getWalBufferSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property defines size(in bytes) of WAL buffer.
getWalBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
getWalBuffPollSpinsRate() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Returns WAL buffer poll spins number over the last time interval.
getWalBuffPollSpinsRate() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Returns WAL buffer poll spins number over the last time interval.
getWalCompactionLevel() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalCompactionLevel() - Method in interface org.apache.ignite.mxbean.DataStorageMXBean
 
getWalCompressedBytes() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Getting the total size of the compressed segments in bytes.
getWalCompressedBytes() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Getting the total size of the compressed segments in bytes.
getWalFlushFrequency() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property define how often WAL will be fsync-ed in BACKGROUND mode.
getWalFlushFrequency() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property define how often WAL will be fsync-ed in BACKGROUND mode.
getWalFsyncDelayNanos() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalFsyncDelayNanos() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets the fsync delay, in nanoseconds.
getWalFsyncTimeAverage() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalFsyncTimeAverage() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalFsyncTimeAverage() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalFsyncTimeAverage() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalFsyncTimeAverage() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
getWalHistorySize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Instead of walHistorySize use maxWalArchiveSize for manage of archive size.
getWalHistorySize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a total number of checkpoints to keep in the WAL history.
getWalLastRollOverTime() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Time of the last WAL segment rollover.
getWalLastRollOverTime() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Time of the last WAL segment rollover.
getWalLoggingRate() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
getWalLoggingRate() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
getWalLoggingRate() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
getWalLoggingRate() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
getWalLoggingRate() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
getWalMode() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property that defines behavior of wal fsync.
getWalMode() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Type define behavior wal fsync.
getWalPageCompression() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets compression algorithm for WAL page snapshot records.
getWalPageCompressionLevel() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets algorithm specific WAL page compression level.
getWalPath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a path to the directory where WAL is stored.
getWalRecordIteratorBufferSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property define how many bytes iterator read from disk (for one reading), during go ahead wal.
getWalRecordIteratorBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Property define how many bytes iterator read from disk (for one reading), during go ahead wal.
getWalSegments() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a number of WAL segments to work with.
getWalSegments() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a number of WAL segments to work with.
getWalSegmentSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets size(in bytes) of a WAL segment.
getWalSegmentSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets size of a WAL segment in bytes.
getWalStorePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a path to the directory where WAL is stored.
getWalThreadLocalBufferSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property for size of thread local buffer.
getWalTotalSize() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Total size in bytes for storage wal files.
getWalTotalSize() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Total size in bytes for storage wal files.
getWalWritingRate() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Gets the average number of bytes per second written during the last time interval.
getWalWritingRate() - Method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
Gets the average number of bytes per second written during the last time interval.
getWalWritingRate() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Gets the average number of bytes per second written during the last time interval.
getWalWritingRate() - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Gets the average number of bytes per second written during the last time interval.
getWalWritingRate() - Method in interface org.apache.ignite.PersistenceMetrics
Deprecated.
Gets the average number of bytes per second written during the last time interval.
getWalWrittenBytes() - Method in interface org.apache.ignite.DataStorageMetrics
Deprecated.
Getting the total number of logged bytes into the WAL.
getWalWrittenBytes() - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
Deprecated.
Getting the total number of logged bytes into the WAL.
getWarmupClosure() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets grid warmup closure.
getWarmUpConfiguration() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets warm-up configuration.
getWarmupMethods() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets warmup methods to use for cache warmup.
getWeights() - Method in class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
 
getWeights() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
 
getWithId() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily
 
getWorkDirectory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Ignite work directory.
getWorkerNames() - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Returns names of all registered workers.
getWorkerThreads() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets amount of threads responsible for sender hub batches processing.
getWorkerThreads() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets number of threads responsible for sender hub requests processing.
getWrappedStatement() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
Getter for wrapped statement.
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
Deprecated.
Gets count of entries that were processed by the write-behind store and have not been flushed to the underlying store yet.
getWriteBehindCoalescing() - Method in class org.apache.ignite.configuration.CacheConfiguration
Write coalescing flag for write-behind cache store operations.
getWriteBehindCriticalOverflowCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets count of write buffer overflow events in progress at the moment.
getWriteBehindCriticalOverflowCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
Gets count of write buffer overflow events since initialization.
getWriteBufferSize() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets write buffer size in bytes.
getWriteDelay() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets write delay after which write buffer can be flushed to the disk.
getWriteMode() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets write mode.
getWriteStatement(String) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Returns CQL statement to insert row into Cassandra table.
getWriteSynchronizationMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets write synchronization mode.
getWriteSynchronizationMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets write synchronization mode.
getWriteThrottlingTime() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Time in milliseconds when snapshot writer thread was parked.
getWriteThrottlingTime(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Time in milliseconds when snapshot writer thread was parked.
getWriteTimeout() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets write timeout for receiver hub's TCP server connection.
getWriteTimeout() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Gets write timeout for sender hub socket connection.
getX() - Method in class org.apache.ignite.ml.math.isolve.IterativeSolverResult
 
getX(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the matrix value at the provided location without checking boundaries.
getX(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the matrix value at the provided location without checking boundaries.
getX(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the value at specified index without checking for index boundaries.
getX(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the value at specified index without checking for index boundaries.
getX(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the value at specified index without checking for index boundaries.
getX() - Method in class org.apache.ignite.ml.tree.impurity.util.StepFunction
 
getXnorm() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
getY() - Method in class org.apache.ignite.ml.structures.partition.LabelPartitionDataOnHeap
 
getY() - Method in class org.apache.ignite.ml.tree.impurity.util.StepFunction
 
getZkConnectionString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
getZkConnectionString() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getZkConnectionString() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets connection string used to connect to ZooKeeper cluster.
getZkRootPath() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getZkRootPath() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets root path in ZooKeeper cluster Zk client uses to put data to.
getZkSessionId() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets session id of Zk client established with ZooKeeper cluster.
getZkSessionTimeout() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets session timeout used by Zk client of local Ignite node.
GG_BROKEN_TRACKING_PAGE_LOG_BATCH_SIZE - Static variable in class org.gridgain.grid.GridSystemProperties
Batch size for logging broken TrackingPage of incremental snapshots.
GG_DB_SKIP_CRC - Static variable in class org.gridgain.grid.GridSystemProperties
Skip CRC calculation flag.
GG_DISABLE_SNAPSHOT_ON_BASELINE_CHANGE_WITH_ENABLED_PITR - Static variable in class org.gridgain.grid.GridSystemProperties
 
GG_DR_FORCE_DC_ID - Static variable in class org.gridgain.grid.GridSystemProperties
Force node to use specified dc id rather then value from configuration.
GG_DR_SYSTEM_CACHE_SCAN_TIMEOUT - Static variable in class org.gridgain.grid.GridSystemProperties
Timeout in ms for scan iterator on system cache for DR purposes.
GG_DR_USE_METASTORE - Static variable in class org.gridgain.grid.GridSystemProperties
Experimental mode.
GG_EXCHANGELESS_SNAPSHOT_CREATION - Static variable in class org.gridgain.grid.GridSystemProperties
If this property is True, exchange is not triggered on snapshot creation.
GG_INCREMENTAL_STATE_TRANSFER - Static variable in class org.gridgain.grid.GridSystemProperties
Incremental mode for DR stater transfer.
GG_LIC_EXPIRE_DAYS_THRESHOLD - Static variable in class org.gridgain.grid.GridSystemProperties
 
GG_MAX_ATTEMPTS_CREATING_IMPLICIT_CONSISTENT_CUT - Static variable in class org.gridgain.grid.GridSystemProperties
Number of attempts to create an implicit consistent cut as part of exchangeless snapshot.
GG_MAX_SNAPSHOT_WRITE_THROTTLING_MILLIS - Static variable in class org.gridgain.grid.GridSystemProperties
Maximum time (in milliseconds) snapshot writer thread can be parked.
GG_POINT_IN_TIME_DOUBLE_CHECK_INTERVAL - Static variable in class org.gridgain.grid.GridSystemProperties
 
GG_POINT_IN_TIME_FETCHING_POOL_SIZE - Static variable in class org.gridgain.grid.GridSystemProperties
 
GG_POINT_IN_TIME_STORED_TX_INTERVAL - Static variable in class org.gridgain.grid.GridSystemProperties
 
GG_RECEIVER_DR_STREAMER_RECREATE_TIMEOUT - Static variable in class org.gridgain.grid.GridSystemProperties
Data streamer recreating timeout in DrReceiver.
GG_SECURITY_CONTEXT_PROPAGATION_TIMEOUT_MILLIS - Static variable in class org.gridgain.grid.GridSystemProperties
How long to wait for security context propagation milliseconds before failing authentication.
GG_SECURITY_SESSION_INVALIDATE_TIMEOUT_MILLIS - Static variable in class org.gridgain.grid.GridSystemProperties
Delay session invalidation timeout to give some time for finishing async operations on disconnected client.
GG_SNAPSHOT_COPY_LARGE_BUFFER_SIZE - Static variable in class org.gridgain.grid.GridSystemProperties
Buffer size fo performing large copy operations between streams.
GG_SNAPSHOT_COPY_MAX_WORK_BATCH_SIZE - Static variable in class org.gridgain.grid.GridSystemProperties
Snapshot single copy max work batch size property.
GG_SNAPSHOT_METRICS_HISTORY_SIZE - Static variable in class org.gridgain.grid.GridSystemProperties
Snapshot metrics history size.
GG_SNAPSHOT_SECURITY_FEATURE - Static variable in class org.gridgain.grid.GridSystemProperties
 
GG_SNAPSHOT_SECURITY_LEVEL - Static variable in class org.gridgain.grid.GridSystemProperties
Snapshot security level property.
GG_SNAPSHOT_SECURITY_LEVEL_AUDIT_LOG - Static variable in class org.gridgain.grid.GridSystemProperties
Path to file that is updated each time a snapshot security level changes.
GG_VISOR_CLIENT_LOG_LEVEL - Static variable in class org.gridgain.grid.GridSystemProperties
Specifies log level for Visor client logging.
GG_WAITING_FOR_REORDERED_ATOMIC_UPDATES_INTERVAL - Static variable in class org.gridgain.grid.GridSystemProperties
Time interval, in ms, for how much consistent cut should wait to pick globally consistent atomic counters.
GiniHistogram - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Class contains implementation of splitting point finding algorithm based on Gini metric (see https://en.wikipedia.org/wiki/Gini_coefficient) and represents a set of histograms in according to this metric.
GiniHistogram(int, Map<Double, Integer>, BucketMeta) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
Creates an instance of GiniHistogram.
GiniHistogramsComputer - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Implementation of ImpurityHistogramsComputer for classification task.
GiniHistogramsComputer(Map<Double, Integer>) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogramsComputer
Creates an instance of GiniHistogramsComputer.
GiniImpurityMeasure - Class in org.apache.ignite.ml.tree.impurity.gini
Gini impurity measure which is calculated the following way: \-frac{1}{L}\sum_{i=1}^{s}l_i^2 - \frac{1}{R}\sum_{i=s+1}^{n}r_i^2.
GiniImpurityMeasureCalculator - Class in org.apache.ignite.ml.tree.impurity.gini
Gini impurity measure calculator.
GiniImpurityMeasureCalculator(Map<Double, Integer>, boolean) - Constructor for class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasureCalculator
Constructs a new instance of Gini impurity measure calculator.
globalId() - Method in class org.apache.ignite.lang.IgniteUuid
Gets global ID portion of this GridUuid.
GmmModel - Class in org.apache.ignite.ml.clustering.gmm
Gaussian Mixture Model.
GmmModel(Vector, List<MultivariateGaussianDistribution>) - Constructor for class org.apache.ignite.ml.clustering.gmm.GmmModel
Creates an instance of GmmModel.
GmmTrainer - Class in org.apache.ignite.ml.clustering.gmm
Traner for GMM model.
GmmTrainer() - Constructor for class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Creates an instance of GmmTrainer.
GmmTrainer(int, int) - Constructor for class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Creates an instance of GmmTrainer.
GmmTrainer(int) - Constructor for class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Creates an instance of GmmTrainer.
gracePeriod() - Method in interface org.gridgain.grid.product.ProductLicense
Gets license violation grace period in minutes.
gracePeriodLeft() - Method in interface org.gridgain.grid.GridProduct
 
gradient(long, double, double) - Method in class org.apache.ignite.ml.composition.boosting.loss.LogLoss
Error gradient value for model answer.
gradient(long, double, double) - Method in interface org.apache.ignite.ml.composition.boosting.loss.Loss
Error gradient value for model answer.
gradient(long, double, double) - Method in class org.apache.ignite.ml.composition.boosting.loss.SquaredError
Error gradient value for model answer.
gradient() - Method in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDParameterUpdate
Get gradient.
greaterThanEqual(int, int, int) - Method in class org.apache.ignite.lang.IgniteProductVersion
 
grid() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
grid() - Method in interface org.apache.ignite.plugin.PluginContext
 
GRID_CONFIG_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
GRID_LOG_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
GRID_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
gridDiscoveryData(int) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
GridDr - Interface in org.gridgain.grid
Data center replication (DR) interface.
GridGain - Interface in org.gridgain.grid
GridGain plugin.
GRIDGAIN_UPDATE_URL - Static variable in class org.apache.ignite.IgniteSystemProperties
Url of updates service.
GridGainCacheConfiguration - Class in org.gridgain.grid.configuration
Cache configuration.
GridGainCacheConfiguration() - Constructor for class org.gridgain.grid.configuration.GridGainCacheConfiguration
Empty constructor.
GridGainCacheConfiguration(GridGainCacheConfiguration) - Constructor for class org.gridgain.grid.configuration.GridGainCacheConfiguration
Copy constructor.
GridGainConfiguration - Class in org.gridgain.grid.configuration
Plugin configuration.
GridGainConfiguration() - Constructor for class org.gridgain.grid.configuration.GridGainConfiguration
Default constructor.
GridGainConfiguration(GridGainConfiguration) - Constructor for class org.gridgain.grid.configuration.GridGainConfiguration
Copying constructor.
GridGainRollingUpgrade - Interface in org.gridgain.grid.ru
Defines public API for Rolling Upgrade process.
GridGainWalIteratorFactory - Class in org.gridgain.grid.persistentstore.snapshot.file.remote.wal
Factory for creating iterator over WAL files on remote storage.
GridGainWalIteratorFactory(IgniteLogger) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.GridGainWalIteratorFactory
 
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
 
GridNodeAttributes - Class in org.gridgain.grid
This class defines constants (NOT enums) for internally-used node attributes.
GridNodeAttributes() - Constructor for class org.gridgain.grid.GridNodeAttributes
 
GridProduct - Interface in org.gridgain.grid
Provides information about current release.
GridRollingUpgradeStatus - Class in org.gridgain.grid.ru
Rolling Upgrade status.
GridRollingUpgradeStatus(boolean, boolean, IgniteProductVersion, IgniteProductVersion) - Constructor for class org.gridgain.grid.ru.GridRollingUpgradeStatus
 
GridSecurity - Interface in org.gridgain.grid
Grid security facade.
GridSnapshot - Interface in org.gridgain.grid.persistentstore
Interface that controls GridGain snapshot.
gridStartTime - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Start time of the very first grid node.
GridSystemProperties - Class in org.gridgain.grid
Contains constants for all system properties and environmental variables in GridGain.
GridSystemProperties() - Constructor for class org.gridgain.grid.GridSystemProperties
 
groupId() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
groupId() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
groupName() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
groupName() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
GRP_IDX_UNASSIGNED - Static variable in class org.apache.ignite.thread.IgniteThread
Index for unassigned thread.
gt(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Greater Than.
gte(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Greater Than or Equal To.
guid() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Auto-generated globally unique matrix ID.
guid() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Auto-generated globally unique matrix ID.
guid() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Auto-generated globally unique vector ID.
guid() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Auto-generated globally unique vector ID.
guid() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Auto-generated globally unique vector ID.
GzipCompressionConfiguration - Class in org.gridgain.grid.cache.compress
Enables gzip-based compression.
GzipCompressionConfiguration() - Constructor for class org.gridgain.grid.cache.compress.GzipCompressionConfiguration
 
GzipCompressionStrategy - Class in org.gridgain.grid.cache.compress
Gzip-based implementation of EntryCompressionStrategy.
GzipCompressionStrategy(GzipCompressionConfiguration) - Constructor for class org.gridgain.grid.cache.compress.GzipCompressionStrategy
 

H

H2Dialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the H2 database.
H2Dialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
 
HALF_MAX_WAL_ARCHIVE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Value used to indicate the use of half of the DataStorageConfiguration.getMaxWalArchiveSize().
HammingDistance - Class in org.apache.ignite.ml.math.distances
Calculates the Hamming distance between two points.
HammingDistance() - Constructor for class org.apache.ignite.ml.math.distances.HammingDistance
 
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.AbstractFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.NoOpFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.RestartProcessFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.StopNodeFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Actual failure handling.
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.apache.ignite.mesos.resource.ResourceHandler
handledIndices - Variable in class org.apache.ignite.ml.preprocessing.encoding.EncoderPreprocessor
Feature indices to apply encoder.
HANDSHAKE2_MESSAGE_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Message size in bytes including HandshakeMessage fields.
HANDSHAKE_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Handshake message type.
HANDSHAKE_WAIT_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Handshake wait message type.
HandshakeFailEvent - Class in org.apache.ignite.client.events
Event that is fired when a connection handshake fails.
HandshakeFailEvent(ConnectionDescription, long, Throwable) - Constructor for class org.apache.ignite.client.events.HandshakeFailEvent
 
HandshakeMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Handshake message.
HandshakeMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Default constructor required by Message.
HandshakeMessage(UUID, long, long) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
HandshakeMessage2 - Class in org.apache.ignite.spi.communication.tcp.messages
Updated handshake message.
HandshakeMessage2() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
 
HandshakeMessage2(UUID, long, long, int) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
 
HandshakeStartEvent - Class in org.apache.ignite.client.events
Event that is fired when a handshake is started.
HandshakeStartEvent(ConnectionDescription) - Constructor for class org.apache.ignite.client.events.HandshakeStartEvent
 
HandshakeSuccessEvent - Class in org.apache.ignite.client.events
Event that is fired when a handshake is completed successfully.
HandshakeSuccessEvent(ConnectionDescription, long) - Constructor for class org.apache.ignite.client.events.HandshakeSuccessEvent
 
HandshakeWaitMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Message requesting to wait until node's SPI context initialize.
HandshakeWaitMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Default constructor required by Message.
hasAttribute(String) - Method in interface org.apache.ignite.ml.math.MetaAttributes
Checks if given meta attribute is present.
hasBias() - Method in class org.apache.ignite.ml.nn.architecture.TransformationLayerArchitecture
Checks if this layer has a bias.
hasBiases(int) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Checks if layer with given index has biases.
hasCause(Class<? extends Throwable>...) - Method in exception org.apache.ignite.IgniteCheckedException
Checks if this exception has given class in 'cause' hierarchy.
hasCause(Class<? extends Throwable>...) - Method in exception org.apache.ignite.IgniteException
Checks if this exception has given class in 'cause' hierarchy.
hasCause(Class<? extends Throwable>...) - Method in exception org.apache.ignite.IgniteIllegalStateException
Checks if this exception has given class in 'cause' hierarchy.
hasConflict() - Method in class org.apache.ignite.cache.QueryEntityPatch
Check for conflict in this patch.
hasConnection(byte) - Method in interface org.gridgain.grid.dr.DrSender
Check whether sender has configured connection to remote data center with provided ID.
hasConstructorExpression(String) - Static method in class org.apache.ignite.springdata22.repository.query.QueryUtils
Returns whether the given JPQL query contains a constructor expression.
hasField(String) - Method in interface org.apache.ignite.binary.BinaryObject
Checks whether field exists in the object.
hashCode() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
hashCode() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
hashCode() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Hash code implementation which delegates to the underlying AffinityKey.key().
hashCode() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
hashCode() - Method in class org.apache.ignite.cache.hibernate.HibernateKeyWrapper
hashCode() - Method in class org.apache.ignite.cache.QueryEntity
hashCode() - Method in class org.apache.ignite.cache.QueryIndex
hashCode(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
Calculate hash code for specified object and fields.
hashCode() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
hashCode(Collection<?>) - Method in interface org.apache.ignite.cache.store.jdbc.JdbcTypeHasher
Calculate hash code for specified object and fields.
hashCode() - Method in class org.apache.ignite.events.EventAdapter
hashCode() - Method in class org.apache.ignite.lang.IgniteBiTuple
hashCode() - Method in class org.apache.ignite.lang.IgniteProductVersion
hashCode() - Method in class org.apache.ignite.lang.IgniteUuid
hashCode() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
hashCode() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModelFormat
hashCode() - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedVector
hashCode() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
hashCode() - Method in class org.apache.ignite.ml.knn.ann.ANNModelFormat
hashCode() - Method in class org.apache.ignite.ml.knn.ann.KNNModelFormat
hashCode() - Method in class org.apache.ignite.ml.knn.NNClassificationModel
hashCode() - Method in class org.apache.ignite.ml.math.distances.EuclideanDistance
hashCode() - Method in class org.apache.ignite.ml.math.distances.HammingDistance
hashCode() - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
hashCode() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
hashCode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
hashCode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
hashCode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
hashCode() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
hashCode() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
hashCode() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
hashCode() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
hashCode() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
hashCode() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
hashCode() - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
hashCode() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
hashCode() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
hashCode() - Method in class org.apache.ignite.ml.structures.Dataset
hashCode() - Method in class org.apache.ignite.ml.structures.DatasetRow
hashCode() - Method in class org.apache.ignite.ml.structures.FeatureMetadata
hashCode() - Method in class org.apache.ignite.ml.structures.LabeledVector
hashCode() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
hashCode() - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeId
hashCode() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
hashCode() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
hashCode() - Method in class org.apache.ignite.services.ServiceConfiguration
hashCode() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
hashCode() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
hashCode() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
hashCode() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
hasHeader() - Method in enum org.apache.ignite.ml.util.MLSandboxDatasets
 
hasher - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Hash calculator.
hasJoiningNodeData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData
 
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
hasMerge() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
 
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
hasNewValue() - Method in class org.apache.ignite.events.CacheEvent
Gets flag indicating whether cache entry has new value in case if we only have new value in serialized form in which case CacheEvent.newValue() will return null.
hasNext() - Method in class org.apache.ignite.ml.dataset.impl.cache.util.IteratorWithConcurrentModificationChecker
hasOldValue() - Method in class org.apache.ignite.events.CacheEvent
Gets flag indicating whether cache entry has old value in case if we only have old value in serialized form in which case CacheEvent.oldValue() will return null.
hasQueuedThread(Thread) - Method in interface org.apache.ignite.IgniteLock
Queries whether the given thread is waiting to acquire this lock.
hasQueuedThreads() - Method in interface org.apache.ignite.IgniteLock
Queries whether any threads on this node are waiting to acquire this lock.
hasQueuedThreads() - Method in interface org.apache.ignite.IgniteSemaphore
Queries whether any threads are waiting to acquire.
hasQueuedThreads() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
hasQueuedThreads() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
hasWaiters(IgniteCondition) - Method in interface org.apache.ignite.IgniteLock
Queries whether any threads on this node are waiting on the given condition associated with this lock.
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.
HibernateAccessStrategyAdapter(Ignite, HibernateCacheProxy, HibernateExceptionConverter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
 
HibernateAccessStrategyFactory - Class in org.apache.ignite.cache.hibernate
Access strategy factory.
HibernateAccessStrategyFactory(HibernateKeyTransformer, HibernateExceptionConverter, Ignite) - Constructor for class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
HibernateCacheProxy - Class in org.apache.ignite.cache.hibernate
Hibernate cache proxy used to substitute hibernate keys with ignite keys.
HibernateCollectionRegion - Class in org.apache.ignite.cache.hibernate
Implementation of CollectionRegion.
HibernateCollectionRegion(HibernateRegionFactory, String, Ignite, HibernateCacheProxy, 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, HibernateCacheProxy, CacheDataDescription) - Constructor for class org.apache.ignite.cache.hibernate.HibernateEntityRegion
 
HibernateExceptionConverter - Interface in org.apache.ignite.cache.hibernate
Converts Ignite errors into Hibernate runtime exceptions.
HibernateGeneralDataRegion - Class in org.apache.ignite.cache.hibernate
Implementation of GeneralDataRegion.
HibernateKeyTransformer - Interface in org.apache.ignite.cache.hibernate
An interface for transforming hibernate keys to Ignite keys.
HibernateKeyWrapper - Class in org.apache.ignite.cache.hibernate
Hibernate cache key wrapper.
HibernateNaturalIdRegion - Class in org.apache.ignite.cache.hibernate
Implementation of NaturalIdRegion.
HibernateNaturalIdRegion(HibernateRegionFactory, String, Ignite, HibernateCacheProxy, CacheDataDescription) - Constructor for class org.apache.ignite.cache.hibernate.HibernateNaturalIdRegion
 
HibernateNonStrictAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of NONSTRICT_READ_WRITE cache access strategy.
HibernateQueryResultsRegion - Class in org.apache.ignite.cache.hibernate
Implementation of QueryResultsRegion.
HibernateQueryResultsRegion(HibernateRegionFactory, String, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.HibernateQueryResultsRegion
 
HibernateReadOnlyAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of READ_ONLY cache access strategy.
HibernateReadOnlyAccessStrategy(Ignite, HibernateCacheProxy, HibernateExceptionConverter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
 
HibernateReadWriteAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of READ_WRITE cache access strategy.
HibernateReadWriteAccessStrategy(Ignite, HibernateCacheProxy, ThreadLocal, HibernateExceptionConverter) - Constructor for class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
 
HibernateRegion - Class in org.apache.ignite.cache.hibernate
Implementation of Region.
HibernateRegion(RegionFactory, String, Ignite, HibernateCacheProxy) - 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, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.HibernateTimestampsRegion
 
HibernateTransactionalAccessStrategy - Class in org.apache.ignite.cache.hibernate
Implementation of {TRANSACTIONAL cache access strategy.
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).
HIGH - Static variable in class org.apache.ignite.ml.environment.logging.ConsoleLogger.Factory
High.
HINGE - Static variable in class org.apache.ignite.ml.optimization.LossFunctions
Hinge loss function.
Histogram<T,H extends Histogram<T,H>> - Interface in org.apache.ignite.ml.dataset.feature
Interface of histogram over type T.
HistogramMetric - Interface in org.apache.ignite.spi.metric
Histogram metric calculates counts of measurements that gets into each bounds interval.
holdcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Holds (suspends) a given job indefinitely until ComputeJobContinuation.callcc() is called.
holdcc(long) - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Holds (suspends) a given job for specified timeout or until ComputeJobContinuation.callcc() is called.
holdcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Holds (suspends) a given job indefinitely until ComputeJobContinuation.callcc() is called.
holdcc(long) - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Holds (suspends) a given job for specified timeout or until ComputeJobContinuation.callcc() is called.
host - Variable in class org.apache.ignite.mesos.IgniteTask
 
host() - Method in class org.apache.ignite.mesos.IgniteTask
 
HOST_IP - Static variable in class org.apache.ignite.cache.store.cassandra.common.SystemHelper
Host IP address
HOST_NAME - Static variable in class org.apache.ignite.cache.store.cassandra.common.SystemHelper
Host name.
hostnameConstraint(Pattern) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets hostname constraint.
hostnameConstraint() - Method in class org.apache.ignite.mesos.ClusterProperties
 
hostnameConstraint(Pattern) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets hostname constraint.
hostnameConstraint() - Method in class org.apache.ignite.yarn.ClusterProperties
 
hostNames() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets the read-only collection of hostnames in this cluster group.
hostNames() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets collection of host names this node is known by.
hostNames() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
hostNames() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collection of host names this node is known by.
hostnames() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
httpServerHost() - Method in class org.apache.ignite.mesos.ClusterProperties
 
httpServerPort() - Method in class org.apache.ignite.mesos.ClusterProperties
 
HyperParameterTuningStrategy - Class in org.apache.ignite.ml.selection.paramgrid
The parent abstract class of all hyper-parameter tuning strategies.
HyperParameterTuningStrategy() - Constructor for class org.apache.ignite.ml.selection.paramgrid.HyperParameterTuningStrategy
 

I

id() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets globally unique node ID.
id() - Method in interface org.apache.ignite.events.Event
Gets globally unique ID of this event.
id() - Method in class org.apache.ignite.events.EventAdapter
Gets globally unique ID of this event.
id() - Method in interface org.apache.ignite.IgniteCluster
Cluster ID is a unique identifier automatically generated when cluster starts up for the very first time.
id(UUID) - Method in interface org.apache.ignite.IgniteCluster
Sets a new cluster ID.
id() - Method in class org.apache.ignite.ml.genetic.Chromosome
Get the id (primary key) for this chromosome
id() - Method in class org.apache.ignite.ml.genetic.Gene
 
id() - Method in class org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor
Identifier of processor.
id() - Method in enum org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor.Method
 
id(UUID) - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Changes cluster ID to provided value.
id() - Method in interface org.apache.ignite.plugin.extensions.communication.IoPool
Gets the numeric identifier of the pool.
id() - Method in interface org.apache.ignite.plugin.platform.PlatformCachePluginConfigurationClosureFactory
Gets the factory id.
id() - Method in interface org.apache.ignite.plugin.platform.PlatformPluginConfigurationClosureFactory
Gets the factory id.
id() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject ID.
id() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets scheduled task ID.
id() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets globally unique node ID.
id() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
 
id() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
id() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
id() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
id() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
id - Variable in class org.apache.ignite.yarn.IgniteContainer
 
id() - Method in class org.apache.ignite.yarn.IgniteContainer
 
id() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets unique state transfer ID.
id() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
id() - Method in interface org.gridgain.grid.product.ProductLicense
Gets license ID.
id() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
Gets subject ID.
identity() - Static method in interface org.apache.ignite.ml.dataset.UpstreamTransformerBuilder
Returns identity upstream transformer.
IDENTITY - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns its argument.
identity() - Static method in interface org.apache.ignite.ml.math.functions.IgniteFunction
Identity function.
identity(int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
 
identityLike(Matrix, int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Create the identity matrix like a given matrix.
identityTrainer() - Static method in class org.apache.ignite.ml.trainers.DatasetTrainer
Returns the trainer which returns identity model.
IdleSession - Class in org.apache.ignite.cache.store.cassandra.session.pool
Simple wrapper for idle Cassandra session returned to pool, responsible for monitoring session expiration and its closing.
IdleSession(Session, long) - Constructor for class org.apache.ignite.cache.store.cassandra.session.pool.IdleSession
Creates instance of Cassandra driver session wrapper.
idleTimeout() - Method in class org.apache.ignite.mesos.ClusterProperties
Sets the maximum Idle time for a http connection, which will be used for jetty server.
idx() - Method in enum org.apache.ignite.spi.tracing.Scope
 
IFitnessFunction - Interface in org.apache.ignite.ml.genetic
Fitness function are used to determine how optimal a particular solution is relative to other solutions.
ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Grid.
ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
Grid instance.
ignite - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Auto injected ignite instance.
ignite() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
ignite() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets instance of grid.
Ignite - Interface in org.apache.ignite
Main entry-point for all Ignite APIs.
ignite() - Static method in class org.apache.ignite.Ignition
Gets an instance of default no-name grid.
ignite(UUID) - Static method in class org.apache.ignite.Ignition
Gets a grid instance for given local node ID.
ignite(String) - Static method in class org.apache.ignite.Ignition
Gets a named Ignite instance.
ignite() - Method in class org.apache.ignite.messaging.MessagingListenActor
Gets grid instance associated with this actor.
ignite - Variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Deprecated.
Since 2.8. May contain an invalid Ignite instance when multiple nodes shares same TcpDiscoveryIpFinder instance.
ignite - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
Ignite instance.
ignite() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets ignite instance.
ignite() - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Returns the Ignite instance bound to the repository
ignite() - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Returns the Ignite instance bound to the repository
ignite - Variable in class org.apache.ignite.stream.StreamAdapter
Ignite.
ignite - Variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
 
IGNITE_AFFINITY_BACKUPS_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Size threshold to allocate and retain additional HashMap to improve contains() which leads to extra memory consumption.
IGNITE_AFFINITY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for affinity assignment history.
IGNITE_ALLOW_ATOMIC_OPS_IN_TX - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag indicating whether atomic operations allowed to be used inside transactions.
IGNITE_ALLOW_DML_INSIDE_TRANSACTION - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Ignite will allow execute DML operation (MERGE|INSERT|UPDATE|DELETE) within transaction for non MVCC mode.
IGNITE_ALLOW_START_CACHES_IN_PARALLEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables start caches in parallel.
IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
No longer used.
IGNITE_ATOMIC_CACHE_QUEUE_RETRY_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Atomic cache deferred update timeout.
IGNITE_ATOMIC_DEFERRED_ACK_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Atomic cache deferred update response buffer size.
IGNITE_ATOMIC_DEFERRED_ACK_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Atomic cache deferred update timeout.
IGNITE_BASELINE_AUTO_ADJUST_LOG_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Interval between logging of time of next auto-adjust.
IGNITE_BINARY_DONT_WRAP_TREE_STRUCTURES - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Should be removed in Apache Ignite 2.0.
IGNITE_BINARY_MARSHALLER_USE_STRING_SERIALIZATION_VER_2 - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages type of serialization mechanism for String that is marshalled/unmarshalled by BinaryMarshaller.
IGNITE_BINARY_SORT_OBJECT_FIELDS - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true fields are written by BinaryMarshaller in sorted order.
IGNITE_BPLUS_TREE_LOCK_RETRIES - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of repetitions to capture a lock in the B+Tree.
IGNITE_CACHE_CLIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling default behavior of cache client flag.
IGNITE_CACHE_KEY_VALIDATION_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since 2.7.26. Obsolete because of common use of binary marshaller.
IGNITE_CACHE_REMOVED_ENTRIES_TTL - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
No longer used.
IGNITE_CACHE_RETRIES_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of cache operation retries in case of topology exceptions.
IGNITE_CACHE_START_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Cache start size for on-heap maps.
IGNITE_CFG_FILE_PATH_PARAM - Static variable in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
Configuration file path parameter name.
IGNITE_CHECK_COMMUNICATION_HANDSHAKE_MESSAGE_SENDER - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables additional check that sender of communication handshake message corresponds to the node id included in the message.
IGNITE_CHECK_SENDER_NODE_SUBJECT - Static variable in class org.apache.ignite.IgniteSystemProperties
If the property is set, coincidence of client identifier and subject is required when security is enabled.
IGNITE_CHECKPOINT_MAP_SNAPSHOT_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold of the checkpoint quantity since the last earliest checkpoint map snapshot.
IGNITE_CHECKPOINT_READ_LOCK_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout for checkpoint read lock acquisition in milliseconds.
IGNITE_CHECKPOINT_TRIGGER_ARCHIVE_SIZE_PERCENTAGE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property for setup percentage of archive size for checkpoint trigger.
IGNITE_CLIENT_CACHE_CHANGE_MESSAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
When client cache is started or closed special discovery message is sent to notify cluster (for example this is needed for ClusterGroup.forCacheNodes(String) API.
IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite cluster name.
IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_CONFIG_URL - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold optional configuration URL.
IGNITE_CONFIG_XML - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_CONFIG_XML - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_CONFIG_XML_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_CONSISTENT_ID_BY_HOST_WITHOUT_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, for consistent id will calculate by host name, without port, and you can use only one node for host in cluster.
IGNITE_CONSOLE_APPENDER - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true (default) and Ignite is launched in verbose mode (see IgniteSystemProperties.IGNITE_QUIET) and no console appenders can be found in configuration, then default console appender will be added.
IGNITE_DAEMON - Static variable in class org.apache.ignite.IgniteSystemProperties
Presence of this system property with value true will make the grid node start as a daemon node.
IGNITE_DATA_STORAGE_FOLDER_BY_CONSISTENT_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Data store folders are generated only by consistent id, and no consistent ID will be set based on existing data store folders.
IGNITE_DATA_STREAMER_ALLOW_OVERWRITE - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_DATA_STREAMING_EXECUTOR_SERVICE_TASKS_STEALING_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Tasks stealing will be started if tasks queue size per data-streamer thread exceeds this threshold.
IGNITE_DEFAULT_DATA_STORAGE_PAGE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Sets default storage page size.
IGNITE_DEFAULT_DISK_PAGE_COMPRESSION - Static variable in class org.apache.ignite.IgniteSystemProperties
Sets default isk page compression.
IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
One phase commit deferred ack request buffer size.
IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
One phase commit deferred ack request timeout.
IGNITE_DEFRAGMENTATION_REGION_SIZE_PERCENTAGE - Static variable in class org.apache.ignite.IgniteSystemProperties
Defragmentation region size percentage of configured region size.
IGNITE_DELAYED_REPLACED_PAGE_WRITE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true (default), pages are written to page store without holding segment lock (with delay).
IGNITE_DEP_MODE_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override deployment mode configuration parameter.
IGNITE_DEPLOYMENT_ADDITIONAL_CHECK - Static variable in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Enables additional check for resource name on resources removal.
IGNITE_DEV_ONLY_LOGGING_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, warnings that are intended for development environments and not for production (such as coding mistakes in code using Ignite) will not be logged.
IGNITE_DFLT_ALLOW_EMPTY_SYS_PERMISSIONS - Static variable in class org.apache.ignite.IgniteSystemProperties
If specified, enforces legacy behavior for system properties authorization when SecurityPermissionSet.defaultAllowAll() is set to true: if user's system permission set is empty, all system actions will be prohibited.
IGNITE_DIAGNOSTIC_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_DIAGNOSTIC_WARN_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of diagnostic warning messages per category, when waiting for PME.
IGNITE_DIRECT_IO_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, direct IO may be enabled.
IGNITE_DISABLE_AFFINITY_MEMORY_OPTIMIZATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag to disable memory optimization: BitSets instead of HashSets to store partitions.
IGNITE_DISABLE_GRP_STATE_LAZY_STORE - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable group state lazy store.
IGNITE_DISABLE_HOSTNAME_VERIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to disable HostnameVerifier for SSL connections.
IGNITE_DISABLE_MAINTENANCE_CLEAR_FOLDER_TASK - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_DISABLE_ONHEAP_CACHE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, on-heap cache cannot be enabled - see CacheConfiguration.setOnheapCacheEnabled(boolean).
IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION - Static variable in class org.apache.ignite.IgniteSystemProperties
When property is set false each next exchange will try to compare with previous.
IGNITE_DISABLE_SMART_DR_THROTTLING - Static variable in class org.apache.ignite.IgniteSystemProperties
Disables smart DR throttling.
IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT - Static variable in class org.apache.ignite.IgniteSystemProperties
Disables cache interceptor triggering in case of conflicts.
IGNITE_DISABLE_WAL_DURING_REBALANCING - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to false, WAL will not be automatically disabled during rebalancing if there is no partition in OWNING state.
IGNITE_DISCO_FAILED_CLIENT_RECONNECT_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines reconnect delay in milliseconds for client node that was failed forcible.
IGNITE_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of discovery message history used to support client reconnect.
IGNITE_DISCOVERY_DISABLE_CACHE_METRICS_UPDATE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, cache metrics are not included into the discovery metrics update message (in this case message contains only cluster metrics).
IGNITE_DISCOVERY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for discovery messages history.
IGNITE_DISCOVERY_METRICS_QNT_WARN - Static variable in class org.apache.ignite.IgniteSystemProperties
Logging a warning message when metrics quantity exceeded a specified number.
IGNITE_DISK_SPACE_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_DUMP_PAGE_LOCK_ON_FAILURE - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables threads locks dumping on critical node failure.
IGNITE_DUMP_THREADS_ON_FAILURE - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables threads dumping on critical node failure.
IGNITE_DUMP_THREADS_ON_FAILURE_THROTTLING_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Throttling time out for thread dump generation during failure handling.
IGNITE_DUMP_TX_COLLISIONS_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
When above zero, prints tx key collisions once per interval.
IGNITE_ENABLE_EXPERIMENTAL_COMMAND - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to enable experimental commands in control.sh script.
IGNITE_ENABLE_EXTRA_INDEX_REBUILD_LOGGING - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables extended logging of indexes create/rebuild process.
IGNITE_ENABLE_FORCIBLE_NODE_KILL - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set, a node will forcible fail a remote node when it fails to establish a communication connection.
IGNITE_ENABLE_HASH_JOIN - Static variable in class org.apache.ignite.IgniteSystemProperties
Enable hash join (create hash index on the fly) for query optimizer.
IGNITE_ENABLE_SUBQUERY_REWRITE_OPTIMIZATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables subquery rewriting optimization.
IGNITE_EVENT_DRIVEN_SERVICE_PROCESSOR_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages the type of the implementation of the service processor (implementation of the IgniteServices).
IGNITE_EVICTION_PERMITS - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
IGNITE_EXCEPTION_REGISTRY_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling size of buffer holding last exception.
IGNITE_EXCHANGE_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for exchange history.
IGNITE_EXCHANGE_MERGE_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_EXECUTE_DURABLE_BACKGROUND_TASKS_ON_NODE_START_OR_ACTIVATE - Static variable in class org.apache.ignite.IgniteSystemProperties
There can be background tasks that can be interrupted due to node stop, node fail, or cluster deactivation, but need to be completed, so they start after node start or cluster activation.
IGNITE_FAIL_NODE_ON_UNRECOVERABLE_PARTITION_INCONSISTENCY - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag to enable triggering failure handler for node if unrecoverable partition inconsistency is discovered during partition update counters exchange.
IGNITE_FAILURE_HANDLER_RESERVE_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Amount of memory reserved in the heap at node start, which can be dropped to increase the chances of success when handling OutOfMemoryError.
IGNITE_FORCE_MVCC_MODE_IN_TESTS - Static variable in class org.apache.ignite.IgniteSystemProperties
For test purposes only.
IGNITE_GLOBAL_METASTORAGE_HISTORY_MAX_BYTES - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum amount of bytes that can be stored in history of DistributedMetaStorage updates.
IGNITE_GRID_CLIENT_LOG_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true enable logging in GridClient.
IGNITE_H2_DEBUG_CONSOLE - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since 2.8. H2 console is no longer supported.
IGNITE_H2_DEBUG_CONSOLE_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since 2.8. H2 console is no longer supported.
IGNITE_H2_INDEXING_CACHE_CLEANUP_PERIOD - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify period in milliseconds between calls of the SQL statements cache cleanup task.
IGNITE_H2_INDEXING_CACHE_THREAD_USAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify timeout in milliseconds after which thread's SQL statements cache is cleared by cleanup task if the thread does not perform any query.
IGNITE_H2_LOCAL_RESULT_FACTORY - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines factory class for H2 LocalResult (see org.gridgain.internal.h2.result.LocalResult).
IGNITE_HASH_JOIN_MAX_TABLE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size of table (rows count) when temporary hash index can be built on fly.
IGNITE_HOME - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines Ignite installation folder.
IGNITE_HOME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
IGNITE_HOSTNAME_CONSTRAINT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HOSTNAME_CONSTRAINT - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_HTTP_SERVER_HOST - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HTTP_SERVER_IDLE_TIMEOUT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HTTP_SERVER_IDLE_TIMEOUT_DEFAULT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_HTTP_SERVER_PORT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_IGNORE_LOCAL_HOST_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to ignore reading hostname of the local address.
IGNITE_INDEX_COST_FUNCTION - Static variable in class org.apache.ignite.IgniteSystemProperties
Choose the index cost function.
IGNITE_INDEX_REBUILD_BATCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Count of rows, being processed within a single checkpoint lock when indexes are rebuilt.
IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Indexing discovery history size.
IGNITE_INSTANCE_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
Hibernate L2 cache Ignite instance name property name.
IGNITE_IO_BALANCE_PERIOD - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_IO_DUMP_ON_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_IPC_SHMEM_SPACE_DEBUG - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then shared memory space native debug will be enabled.
IGNITE_JCACHE_DEFAULT_ISOLATED - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling whether CacheManager will start grid with isolated IP finder when default URL is passed in.
IGNITE_JDBC_DRIVER_CURSOR_REMOVE_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
JDBC driver cursor remove delay.
IGNITE_JETTY_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override Jetty host for REST processor.
IGNITE_JETTY_LOG_NO_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
This property does not allow Ignite to override Jetty log configuration for REST processor.
IGNITE_JETTY_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override Jetty local port for REST processor.
IGNITE_JOBS_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override default job processor maps sizes for finished jobs and cancellation requests.
IGNITE_JOBS_METRICS_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Use GridMetricManager instead.
IGNITE_JVM_OPTS - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_JVM_OPTS - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_JVM_PAUSE_DETECTOR_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector disabled.
IGNITE_JVM_PAUSE_DETECTOR_LAST_EVENTS_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector last events count.
IGNITE_JVM_PAUSE_DETECTOR_PRECISION - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector precision.
IGNITE_JVM_PAUSE_DETECTOR_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector threshold.
IGNITE_KEEP_STATIC_CACHE_CONFIGURATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Keep static cache configuration even if stored cache data differs from the static config.
IGNITE_KEEP_UNCLEARED_EXCHANGE_FUTURES_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines how many exchange futures are kept uncleared in the queue.
IGNITE_KEY_ALGORITHM_PROPERTY - Static variable in class org.apache.ignite.ssl.SslContextFactory
Deprecated.
Use "ssl.KeyManagerFactory.algorithm" instead as per JSSE standard. Should be considered for deletion in 9.0.
IGNITE_LOADED_PAGES_BACKWARD_SHIFT_MAP - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to false, loaded pages implementation is switched to previous version of implementation, FullPageIdTable.
IGNITE_LOCAL_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
The system property sets a system-wide local IP address or hostname to be used by Ignite networking components.
IGNITE_LOCAL_STORE_KEEPS_PRIMARY_ONLY - Static variable in class org.apache.ignite.IgniteSystemProperties
Indicating whether local store keeps primary only.
IGNITE_LOCAL_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_LOG_CLASSPATH_CONTENT_ON_STARTUP - Static variable in class org.apache.ignite.IgniteSystemProperties
Scan the classpath on startup and log all the files containing in it.
IGNITE_LOG_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
Environment variable to override logging directory that has been set in logger configuration.
IGNITE_LOG_GRID_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_LOG_INSTANCE_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is present the Ignite will include instance name into verbose log.
IGNITE_LOG_THROTTLE_CAPACITY - Static variable in class org.apache.ignite.IgniteSystemProperties
Max amount of remembered errors for GridLogThrottle.
IGNITE_LONG_LONG_HASH_MAP_LOAD_FACTOR - Static variable in class org.apache.ignite.IgniteSystemProperties
Long-long offheap map load factor.
IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Cache operations that take more time than value of this property will be output to log.
IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Upper time limit between long running/hanging operations debug dumps.
IGNITE_LONG_TRANSACTION_TIME_DUMP_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold timeout for long transactions, if transaction exceeds it, it will be dumped in log with information about how much time did it spent in system time (time while aquiring locks, preparing, commiting, etc) and user time (time when client node runs some code while holding transaction and not waiting it).
IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify per thread binary allocator chunk pool size.
IGNITE_MARSHAL_BUFFERS_RECHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify how often in milliseconds marshal buffers should be rechecked and potentially trimmed.
IGNITE_MARSHALLER_BLACKLIST - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines path to the file that contains list of classes disallowed to safe deserialization.
IGNITE_MARSHALLER_WHITELIST - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines path to the file that contains list of classes allowed to safe deserialization.
IGNITE_MASTER_KEY_NAME_TO_CHANGE_BEFORE_STARTUP - Static variable in class org.apache.ignite.IgniteSystemProperties
The master key name that the node will use during the recovery.
IGNITE_MAX_COMPLETED_TX_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling size of buffer holding completed transaction versions.
IGNITE_MAX_INDEX_PAYLOAD_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify maximum payload size in bytes for H2TreeIndex.
IGNITE_MAX_NESTED_LISTENER_CALLS - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of nested listener calls before listener notification becomes asynchronous.
IGNITE_MBEAN_APPEND_CLASS_LOADER_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then Ignite will append hash code of class loader to MXBean name.
IGNITE_MBEAN_APPEND_JVM_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then Ignite will append hash code of Ignite class as hex string and append JVM name returned by RuntimeMXBean.getName().
IGNITE_MBEANS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If property is set to true, then Ignite will disable MBeans registration.
IGNITE_MEMORY_OVERHEAD_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_MEMORY_PER_BYTE_COPY_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
When unsafe memory copy if performed below this threshold, Ignite will do it on per-byte basis instead of calling to Unsafe.copyMemory().
IGNITE_MEMORY_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_MEMORY_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_MEMORY_UNALIGNED_ACCESS - Static variable in class org.apache.ignite.IgniteSystemProperties
Whether Ignite can access unaligned memory addresses.
IGNITE_MIN_AFFINITY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Minimum size for affinity assignment history.
IGNITE_MIN_BUFFERED_COMMUNICATION_MSG_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Not used anymore.
IGNITE_MIN_CPU_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_MIN_MEMORY_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_MVCC_TX_SIZE_CACHING_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number for cached MVCC transaction updates.
IGNITE_NEAR_GET_MAX_REMAPS - Static variable in class org.apache.ignite.IgniteSystemProperties
This property defines the maximum number of attempts to remap near get to the same primary node.
IGNITE_NIO_RECOVERY_DESCRIPTOR_RESERVATION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Sets timeout for TCP client recovery descriptor reservation.
IGNITE_NO_ASCII - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is present (any value) - no ASCII logo will be printed.
IGNITE_NO_DISCO_ORDER - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property to disable requirement for proper node ordering by discovery SPI.
IGNITE_NO_SELECTOR_OPTS - Static variable in class org.apache.ignite.IgniteSystemProperties
If set to true, then default selected keys set is used inside GridNioServer which lead to some extra garbage generation when processing selected keys.
IGNITE_NO_SHUTDOWN_HOOK - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is set to true - no shutdown hook will be set.
IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_NODE_IDS_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size of history of server nodes (server node IDs) that ever joined to current topology.
IGNITE_OFFHEAP_LOCK_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite page memory concurrency level.
IGNITE_OFFHEAP_SAFE_RELEASE - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag that will force Ignite to fill memory block with some recognisable pattern right before this memory block is released.
IGNITE_OPTIMIZED_MARSHALLER_USE_DEFAULT_SUID - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages OptimizedMarshaller behavior of serialVersionUID computation for Serializable classes.
IGNITE_OVERRIDE_CONSISTENT_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify consistent id of Ignite node.
IGNITE_OVERRIDE_MCAST_GRP - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override multicast group taken from configuration.
IGNITE_OVERRIDE_WRITE_THROTTLING_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set, DataStorageConfiguration.isWriteThrottlingEnabled() will be overridden to true regardless the initial value in the configuration.
IGNITE_PACKAGE_PATH - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_PACKAGE_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_PAGE_LOCK_TRACKER_CAPACITY - Static variable in class org.apache.ignite.IgniteSystemProperties
Capacity in pages for storing in page lock tracker strucuture.
IGNITE_PAGE_LOCK_TRACKER_CHECK_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Page lock tracker thread for checking hangs threads interval.
IGNITE_PAGE_LOCK_TRACKER_TYPE - Static variable in class org.apache.ignite.IgniteSystemProperties
Page lock tracker type
IGNITE_PAGES_LIST_DISABLE_ONHEAP_CACHING - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_PART_DISTRIBUTION_WARN_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
The threshold of uneven distribution above which partition distribution will be logged.
IGNITE_PARTITION_RELEASE_FUTURE_DUMP_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
If a partition release future completion time during an exchange exceeds this threshold, the contents of the future will be dumped to the log on exchange.
IGNITE_PARTITION_RELEASE_FUTURE_WARN_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property specifies the maximum number of futures that are included into diagnostic message.
IGNITE_PATH - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_PDS_MAX_CHECKPOINT_MEMORY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of checkpoint history entries held in memory.
IGNITE_PDS_PARTITION_DESTROY_CHECKPOINT_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
IGNITE_PDS_SKIP_CRC - Static variable in class org.apache.ignite.IgniteSystemProperties
Skip CRC calculation flag.
IGNITE_PDS_WAL_REBALANCE_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
use Distributed MetaStorage property GridCacheDatabaseSharedManager.HISTORICAL_REBALANCE_THRESHOLD_DMS_KEY.
IGNITE_PENDING_TX_TRACKER_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to enable pending transaction tracker.
IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag indicating whether performance suggestions output on start should be disabled.
IGNITE_PREFER_WAL_REBALANCE - Static variable in class org.apache.ignite.IgniteSystemProperties
Prefer historical rebalance if there's enough history regardless of all heuristics.
IGNITE_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
IGNITE_PRELOAD_RESEND_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold preload resend timeout for evicted partitions.
IGNITE_PROG_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property defining name of command line program.
IGNITE_QUIET - Static variable in class org.apache.ignite.IgniteSystemProperties
Set to either true or false to enable or disable quiet mode of Ignite.
IGNITE_READ_LOAD_BALANCING - Static variable in class org.apache.ignite.IgniteSystemProperties
Whenever read load balancing is enabled, that means 'get' requests will be distributed between primary and backup nodes if it is possible and CacheConfiguration.isReadFromBackup() is true.
IGNITE_REBALANCE_STATISTICS_TIME_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_REBALANCE_THROTTLE_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_RECOVERY_SEMAPHORE_PERMITS - Static variable in class org.apache.ignite.IgniteSystemProperties
Limit the maximum number of objects in memory during the recovery procedure.
IGNITE_RECOVERY_VERBOSE_LOGGING - Static variable in class org.apache.ignite.IgniteSystemProperties
Allows to log additional information about all restored partitions after binary and logical recovery phases.
IGNITE_REFLECTION_CACHE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override default reflection cache size.
IGNITE_RELEASES_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_REST_GETALL_AS_ARRAY - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Should be made default in Apache Ignite 3.0.
IGNITE_REST_MAX_TASK_RESULTS - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override maximum count of task results stored on one node in REST processor.
IGNITE_REST_SECURITY_TOKEN_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allow rewriting default (300) REST session security token expire time (in seconds).
IGNITE_REST_SESSION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allow rewriting default (30) REST session expire time (in seconds).
IGNITE_REST_START_ON_CLIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override default behavior that rest processor doesn't start on client node.
IGNITE_RESTART_CODE - Static variable in class org.apache.ignite.IgniteSystemProperties
This property is used internally to pass an exit code to loader when Ignite instance is being restarted.
IGNITE_REUSE_MEMORY_ON_DEACTIVATE - Static variable in class org.apache.ignite.IgniteSystemProperties
Try reuse memory on deactivation.
IGNITE_RUN_CPU_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_RUN_CPU_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_SECURITY_COMPATIBILITY_MODE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Ignite switches to compatibility mode with versions that don't support service security permissions.
IGNITE_SECURITY_FOR_SYS_CACHE_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If the property is set, client nodes should have explicitly rights to access to system cache.
IGNITE_SENSITIVE_DATA_LOGGING - Static variable in class org.apache.ignite.IgniteSystemProperties
Setting to "plain" enables writing sensitive information in toString() output.
IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
Property allowing to skip configuration consistency checks.
IGNITE_SKIP_PARTITION_SIZE_VALIDATION - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Ignite will skip partitions sizes check on partition validation after rebalance has finished.
IGNITE_SLOW_TX_WARN_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Transactions that take more time, than value of this property, will be output to log with warning level.
IGNITE_SQL_ALLOW_KEY_VAL_UPDATES - Static variable in class org.apache.ignite.IgniteSystemProperties
Allow use composite _key, _val columns at the INSERT/UPDATE/MERGE statements.
IGNITE_SQL_DISABLE_SYSTEM_VIEWS - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable SQL system views.
IGNITE_SQL_DISTINCT_RESULTS_USE_TREE_MAP - Static variable in class org.apache.ignite.IgniteSystemProperties
Use TreeMap instead of HashMap to hold distinct values.
IGNITE_SQL_ENABLE_CONNECTION_MEMORY_QUOTA - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Possibility to modify query qouta is now managed by security permission SecurityPermission.SET_QUERY_MEMORY_QUOTA.
IGNITE_SQL_FILL_ABSENT_PK_WITH_DEFAULTS - Static variable in class org.apache.ignite.IgniteSystemProperties
Forcibly fills missing columns belonging to the primary key with nulls or default values if those have been specified.
IGNITE_SQL_MAX_EXTRACTED_PARTS_FROM_BETWEEN - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of different partitions to be extracted from between expression within sql query.
IGNITE_SQL_MEMORY_RESERVATION_BLOCK_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines default memory reservation block size.
IGNITE_SQL_MERGE_TABLE_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling maximum number of SQL result rows which can be fetched into a merge table.
IGNITE_SQL_MERGE_TABLE_PREFETCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling number of SQL result rows that will be fetched into a merge table at once before applying binary search for the bounds.
IGNITE_SQL_PARSER_DISABLE_H2_FALLBACK - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable fallback to H2 SQL parser if the internal SQL parser fails to parse the statement.
IGNITE_SQL_RETRY_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
SQL retry timeout.
IGNITE_SQL_SYSTEM_SCHEMA_NAME_IGNITE - Static variable in class org.apache.ignite.IgniteSystemProperties
Enable backward compatible to use 'IGNITE' as SQL system schema.
IGNITE_SQL_UUID_DDL_BYTE_FORMAT - Static variable in class org.apache.ignite.IgniteSystemProperties
Enable backward compatible handling of UUID through DDL.
IGNITE_SSH_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold SSH host for visor-started nodes.
IGNITE_SSH_USER_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold SSH user name for visor-started nodes.
IGNITE_SSL_HANDSHAKE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
SSL handshake timeout.
IGNITE_START_CACHES_ON_JOIN - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_STARVATION_CHECK_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
This system property defines interval in milliseconds in which Ignite will check thread pool state for starvation.
IGNITE_STREAM_TRANSFORMER_COMPATIBILITY_MODE - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages backward compatibility of StreamTransformer.from(CacheEntryProcessor) method.
IGNITE_STRICT_CONSISTENCY_CHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables strict mode to check not critical internal invariants.
IGNITE_SUCCESS_FILE - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property defining success file name.
IGNITE_SYSTEM_WORKER_BLOCKED_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum inactivity period for system worker in milliseconds.
IGNITE_TCP_COMM_SET_ATTR_HOST_NAMES - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables setting attribute value of ATTR_HOST_NAMES when value getLocalHost is ip, for backward compatibility.
IGNITE_TCP_DISCOVERY_ADDRESSES - Static variable in class org.apache.ignite.IgniteSystemProperties
Comma separated list of addresses in format "10.100.22.100:45000,10.100.22.101:45000".
IGNITE_TEST_ENV - Static variable in class org.apache.ignite.IgniteSystemProperties
Set to true only during the junit tests.
IGNITE_TEST_FEATURES_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If property is set to true, then test features will be enabled.
IGNITE_THREAD_DUMP_ON_EXCHANGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then Ignite will log thread dump in case of partition exchange timeout.
IGNITE_THRESHOLD_WAIT_TIME_NEXT_WAL_SEGMENT - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold time (in millis) to print warning to log if waiting for next wal segment took longer than the threshold.
IGNITE_THRESHOLD_WAL_ARCHIVE_SIZE_PERCENTAGE - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_THROTTLE_LOG_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold for throttling operations logging.
IGNITE_TO_STRING_COLLECTION_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Limit collection (map, array) elements number to output.
IGNITE_TO_STRING_INCLUDE_SENSITIVE - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_TO_STRING_MAX_LENGTH - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum length for toString() result.
IGNITE_TO_STRING_THROW_RUNTIME_EXCEPTION - Static variable in class org.apache.ignite.IgniteSystemProperties
Boolean flag indicating whether GridToStringBuilder should throw RuntimeException when building string representation of an object or should just print information about exception into the log and proceed.
IGNITE_TOTAL_CPU - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_TOTAL_DISK_SPACE - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_TOTAL_MEMORY - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
The coefficient for samples of completed transactions that will be dumped in log.
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
The limit of samples of completed transactions that will be dumped in log per second, if IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT is above 0.0.
IGNITE_TROUBLESHOOTING_LOGGER - Static variable in class org.apache.ignite.IgniteSystemProperties
Setting this option to true will enable troubleshooting logger.
IGNITE_TTL_EXPIRE_BATCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
When cache has entries with expired TTL and/or tombstones, each user operation will also remove this amount of expired entries.
IGNITE_TX_DEADLOCK_DETECTION_MAX_ITERS - Static variable in class org.apache.ignite.IgniteSystemProperties
Specifies maximum number of iterations for deadlock detection procedure.
IGNITE_TX_DEADLOCK_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Specifies timeout for deadlock detection procedure.
IGNITE_TX_OWNER_DUMP_REQUESTS_ALLOWED - Static variable in class org.apache.ignite.IgniteSystemProperties
Shows if dump requests from local node to near node are allowed, when long running transaction is found.
IGNITE_TX_SALVAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Transactions are salvaged immediately to reduce PME latency.
IGNITE_UNWIND_THROTTLING_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
No longer used.
IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Should be removed in Apache Ignite 2.0.
IGNITE_UPDATE_NOTIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is set to false - no checks for new versions will be performed by Ignite.
IGNITE_URL - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_USE_ASYNC_FILE_IO_FACTORY - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set, then Ignite will use Async File IO factory by default.
IGNITE_USE_LEGACY_NODE_COMPARATOR - Static variable in class org.apache.ignite.IgniteSystemProperties
If the property is set Ignite will use legacy node comparator (based on node order) inste Default value is false.
IGNITE_USERS_LIBS - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_USERS_LIBS - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_USERS_LIBS_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_VERSION - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_WAIT_FOR_BACKUPS_ON_SHUTDOWN - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Use ShutdownPolicy instead.
IGNITE_WAIT_SCHEMA_UPDATE - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout for waiting schema update if schema was not found for last accepted version.
IGNITE_WAL_COMPRESSOR_WORKER_THREAD_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Count of WAL compressor worker threads.
IGNITE_WAL_DEBUG_LOG_ON_RECOVERY - Static variable in class org.apache.ignite.IgniteSystemProperties
Default value is false.
IGNITE_WAL_FSYNC_WITH_DEDICATED_WORKER - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, WAL implementation with dedicated worker will be used even in FSYNC mode.
IGNITE_WAL_MMAP - Static variable in class org.apache.ignite.IgniteSystemProperties
Property that indicates should be mapped byte buffer used or not.
IGNITE_WAL_SEGMENT_SYNC_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Property for setup Ignite WAL segment sync timeout.
IGNITE_WAL_SERIALIZER_VERSION - Static variable in class org.apache.ignite.IgniteSystemProperties
Property for setup WAL serializer version.
IGNITE_WORK_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
Environment variable to set work directory.
IGNITE_WORK_DIR - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
IGNITE_WORKING_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
IGNITE_YARN_QUEUE - Static variable in class org.apache.ignite.yarn.ClusterProperties
Ignite Yarn Queue
IGNITE_ZOOKEEPER_DISCOVERY_MAX_RETRY_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of attempts to reconnect to ZooKeeper.
IGNITE_ZOOKEEPER_DISCOVERY_RETRY_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout between ZooKeeper client retries, default 2s.
IgniteAllNodesPredicate() - Constructor for class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
 
IgniteAsyncCallback - Annotation Type in org.apache.ignite.lang
If callback has this annotation then it will be executing in another thread.
IgniteAsyncSupport - Interface in org.apache.ignite.lang
Deprecated.
since 2.0. Please use specialized asynchronous methods.
IgniteAsyncSupported - Annotation Type in org.apache.ignite.lang
Deprecated.
since 2.0. Please use specialized asynchronous methods.
IgniteAtomicLong - Interface in org.apache.ignite
This interface provides a rich API for working with distributedly cached atomic long value.
IgniteAtomicReference<T> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed atomic reference.
IgniteAtomicSequence - Interface in org.apache.ignite
This interface provides a rich API for working with distributed atomic sequence.
IgniteAtomicStamped<T,S> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed atomic stamped value.
IgniteAuthenticationException - Exception in org.apache.ignite
Exception that represents authentication failure.
IgniteAuthenticationException(String) - Constructor for exception org.apache.ignite.IgniteAuthenticationException
Creates authentication exception with given error message.
IgniteAuthenticator - Class in org.gridgain.grid.security.passcode
Authenticate server nodes using PasscodeAuthenticator.
IgniteAuthenticator() - Constructor for class org.gridgain.grid.security.passcode.IgniteAuthenticator
 
IgniteBiClosure<E1,E2,R> - Interface in org.apache.ignite.lang
Defines generic closure with two parameters.
IgniteBiConsumer<T,U> - Interface in org.apache.ignite.ml.math.functions
Serializable binary consumer.
IgniteBiFunction<T,U,R> - Interface in org.apache.ignite.ml.math.functions
Serializable binary function.
IgniteBiInClosure<E1,E2> - Interface in org.apache.ignite.lang
Closure with two in-parameters and void return type.
IgniteBinary - Interface in org.apache.ignite
Defines binary objects functionality.
IgniteBinaryOperator<A> - Interface in org.apache.ignite.ml.math.functions
Serializable binary operator.
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.
IgniteCacheClientProxy<K,V> - Class in org.apache.ignite.springdata.proxy
Implementation of IgniteCacheProxy that provides access to Ignite cache through ClientCache instance.
IgniteCacheClientProxy(ClientCache<K, V>) - Constructor for class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
 
igniteCacheConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
IgniteCachedDomainDataAccess - Class in org.apache.ignite.cache.hibernate
Implementation of L2 cache access strategy delegating to HibernateAccessStrategyAdapter.
IgniteCachedDomainDataAccess(HibernateAccessStrategyAdapter, RegionFactory, DomainDataRegion, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
 
IgniteCacheProxy<K,V> - Interface in org.apache.ignite.springdata.proxy
Reperesents Ignite cache operations required by Spring Data.
IgniteCacheProxyImpl<K,V> - Class in org.apache.ignite.springdata.proxy
Implementation of IgniteCacheProxy that provides access to Ignite cache through IgniteCache instance.
IgniteCacheProxyImpl(IgniteCache<K, V>) - Constructor for class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
 
IgniteCacheRestartingException - Exception in org.apache.ignite
Exception thrown from ignite cache API if cache is restarting.
IgniteCacheRestartingException(String) - Constructor for exception org.apache.ignite.IgniteCacheRestartingException
 
IgniteCacheRestartingException(IgniteFuture<?>, String) - Constructor for exception org.apache.ignite.IgniteCacheRestartingException
 
IgniteCacheRestartingException(IgniteFuture<?>, String, Throwable) - Constructor for exception org.apache.ignite.IgniteCacheRestartingException
 
IgniteCallable<V> - Interface in org.apache.ignite.lang
Grid-aware adapter for Callable implementations.
igniteCfg() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteCfg() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteCheckedException - Exception in org.apache.ignite
General grid exception.
IgniteCheckedException() - Constructor for exception org.apache.ignite.IgniteCheckedException
Create empty exception.
IgniteCheckedException(String) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message.
IgniteCheckedException(Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteCheckedException(String, Throwable, boolean) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message and optional nested exception.
IgniteCheckedException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message and optional nested exception.
IgniteClient - Interface in org.apache.ignite.client
Ignite thin client.
IgniteClientDisconnectedException - Exception in org.apache.ignite
Exception thrown from Ignite API when client node disconnected from cluster.
IgniteClientDisconnectedException(IgniteFuture<?>, String) - Constructor for exception org.apache.ignite.IgniteClientDisconnectedException
 
IgniteClientDisconnectedException(IgniteFuture<?>, String, Throwable) - Constructor for exception org.apache.ignite.IgniteClientDisconnectedException
 
IgniteClientFuture<T> - Interface in org.apache.ignite.client
Thin client async operations future.
IgniteClientProxy - Class in org.apache.ignite.springdata.proxy
Implementation of IgniteProxy that provides access to Ignite cluster through IgniteClient instance.
IgniteClientProxy(IgniteClient) - Constructor for class org.apache.ignite.springdata.proxy.IgniteClientProxy
 
IgniteClosure<E,R> - Interface in org.apache.ignite.lang
Defines generic closure with one parameter.
IgniteCluster - Interface in org.apache.ignite
Represents whole cluster (all available nodes) and also provides a handle on IgniteCluster.nodeLocalMap() which provides map-like functionality linked to current grid node.
IgniteClusterMXBean - Interface in org.apache.ignite.mxbean
MX Bean allows to access information about cluster ID and tag and change tag.
IgniteCollectionDataAccess - Class in org.apache.ignite.cache.hibernate
Ignite implementation of CollectionDataAccess interface for Hibernate integration.
IgniteCollectionDataAccess(HibernateAccessStrategyAdapter, AccessType, RegionFactory, DomainDataRegion, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.IgniteCollectionDataAccess
 
IgniteCompute - Interface in org.apache.ignite
Defines compute grid functionality for executing tasks and closures over nodes in the ClusterGroup.
IgniteCondition - Interface in org.apache.ignite
This interface provides a rich API for working with condition objects associated with distributed reentrant locks.
IgniteConfiguration - Class in org.apache.ignite.configuration
This class defines grid runtime configuration.
IgniteConfiguration() - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
Creates valid grid configuration with all default values.
IgniteConfiguration(IgniteConfiguration) - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
Creates grid configuration by coping all configuration properties from given configuration.
igniteConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
igniteConfiguration() - Method in interface org.apache.ignite.plugin.PluginContext
 
igniteConfigUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteConfigUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
IgniteConsumer<T> - Interface in org.apache.ignite.ml.math.functions
Serializable consumer.
IgniteContainer - Class in org.apache.ignite.yarn
Information about launched task.
IgniteContainer(ContainerId, NodeId, double, double) - Constructor for class org.apache.ignite.yarn.IgniteContainer
Ignite launched task.
IgniteCountDownLatch - Interface in org.apache.ignite
This interface provides a rich API for working with distributed count down latch.
IgniteCurriedBiFunction<A,B,T> - Interface in org.apache.ignite.ml.math.functions
Serializable binary function.
IgniteCurriedTriFunction<A,B,C,D> - Interface in org.apache.ignite.ml.math.functions
Serializable curried tri-function.
IgniteDataIntegrityViolationException - Exception in org.gridgain.grid.cache.db.wal.crc
Will be thrown if data integrity violation is found
IgniteDataIntegrityViolationException() - Constructor for exception org.gridgain.grid.cache.db.wal.crc.IgniteDataIntegrityViolationException
Default constructor.
IgniteDataIntegrityViolationException(String) - Constructor for exception org.gridgain.grid.cache.db.wal.crc.IgniteDataIntegrityViolationException
 
IgniteDataStreamer<K,V> - Interface in org.apache.ignite
Data streamer is responsible for streaming external data into cache.
IgniteDataStreamerTimeoutException - Exception in org.apache.ignite
Exception is thrown when timeout of some IgniteDataStreamer operations occurs.
IgniteDataStreamerTimeoutException(String) - Constructor for exception org.apache.ignite.IgniteDataStreamerTimeoutException
Creates new timeout exception with given error message.
IgniteDataStreamerTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteDataStreamerTimeoutException
Creates new timeout exception with given error message and optional nested exception.
IgniteDeploymentException - Exception in org.apache.ignite
Deployment or re-deployment failed.
IgniteDeploymentException(String) - Constructor for exception org.apache.ignite.IgniteDeploymentException
Creates new exception with given error message.
IgniteDeploymentException(Throwable) - Constructor for exception org.apache.ignite.IgniteDeploymentException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteDeploymentException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteDeploymentException
Creates a new exception with given error message and optional nested cause exception.
IgniteDifferentiableDoubleToDoubleFunction - Interface in org.apache.ignite.ml.math.functions
Interface for differentiable functions from double to double.
IgniteDifferentiableVectorToDoubleFunction - Interface in org.apache.ignite.ml.math.functions
Interface for differentiable functions from vector to double.
IgniteDiscoveryThread - Interface in org.apache.ignite.spi.discovery
Marker interface for discovery thread on cluster server node.
IgniteDistributedModelBuilder - Class in org.apache.ignite.ml.inference.builder
Builder that allows to start Apache Ignite services for distributed inference and get a facade that allows to work with this distributed inference infrastructure as with a single inference model (see Model).
IgniteDistributedModelBuilder(Ignite, int, int) - Constructor for class org.apache.ignite.ml.inference.builder.IgniteDistributedModelBuilder
Constructs a new instance of Ignite distributed inference model builder.
IgniteDomainDataRegion - Class in org.apache.ignite.cache.hibernate
Ignite implementation of DomainDataRegion interface for Hibernate integration.
IgniteDomainDataRegion(DomainDataRegionConfig, RegionFactory, CacheKeysFactory, DomainDataRegionBuildingContext, HibernateAccessStrategyFactory) - Constructor for class org.apache.ignite.cache.hibernate.IgniteDomainDataRegion
 
IgniteDoubleFunction<Double> - Interface in org.apache.ignite.ml.math.functions
Serializable double function.
IgniteEncryption - Interface in org.apache.ignite
Defines encryption features.
IgniteEntityDataAccess - Class in org.apache.ignite.cache.hibernate
Ignite implementation of EntityDataAccess for Hibernate integration.
IgniteEntityDataAccess(HibernateAccessStrategyAdapter, AccessType, RegionFactory, DomainDataRegion, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
IgniteEvents - Interface in org.apache.ignite
Provides functionality for local and remote event notifications on nodes defined by IgniteEvents.clusterGroup().
IgniteException - Exception in org.apache.ignite
General grid exception.
IgniteException() - Constructor for exception org.apache.ignite.IgniteException
Create empty exception.
IgniteException(String) - Constructor for exception org.apache.ignite.IgniteException
Creates new exception with given error message.
IgniteException(Throwable) - Constructor for exception org.apache.ignite.IgniteException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteException
Creates new exception with given error message and optional nested exception.
IgniteExperimental - Annotation Type in org.apache.ignite.lang
This annotation marks API elements (such as interfaces, methods, annotations and whole API packages) as experimental meaning that the API is not finalized yet and may be changed or replaced in future Ignite releases.
IgniteFramework - Class in org.apache.ignite.mesos
Ignite mesos framework.
IgniteFramework() - Constructor for class org.apache.ignite.mesos.IgniteFramework
 
IgniteFunction<T,R> - Interface in org.apache.ignite.ml.math.functions
Serializable function.
IgniteFuture<V> - Interface in org.apache.ignite.lang
Future with simplified exception handling, functional programming support and ability to listen for future completion via functional callback.
IgniteFutureCancelledException - Exception in org.apache.ignite.lang
Future computation cannot be retrieved because it was cancelled.
IgniteFutureCancelledException(String) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
Creates new exception with given error message.
IgniteFutureCancelledException(Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteFutureCancelledException(String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
Creates a new exception with given error message and optional nested cause exception.
IgniteFutureTimeoutException - Exception in org.apache.ignite.lang
Future computation completion is timed out.
IgniteFutureTimeoutException(String) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
Creates new exception with given error message.
IgniteFutureTimeoutException(Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteFutureTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
Creates a new exception with given error message and optional nested cause exception.
IgniteGeneralDataRegion - Class in org.apache.ignite.cache.hibernate
Implementation of DirectAccessRegion.
IgniteIllegalStateException - Exception in org.apache.ignite
This exception indicates the ignite access in invalid state.
IgniteIllegalStateException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
Constructs exception with given message and cause.
IgniteIllegalStateException(Throwable) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
Creates exception given throwable as a cause and source of error message.
IgniteIllegalStateException(String) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
Constructs exception with given message.
IgniteInClosure<E> - Interface in org.apache.ignite.lang
Closure with one in-parameter and void return type.
igniteInstanceName - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
Ignite instance name.
igniteInstanceName - Variable in class org.apache.ignite.thread.IgniteThread
The name of the Ignite instance this thread belongs to.
IgniteInstanceResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of current Ignite instance.
IgniteIntDoubleToDoubleBiFunction - Interface in org.apache.ignite.ml.math.functions
BiFunction (int, double) -> double.
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.
IgniteIntIntToIntBiFunction - Interface in org.apache.ignite.ml.math.functions
BiFunction (int, int) -> int.
IgniteJdbcDriver - Class in org.apache.ignite
JDBC driver implementation for In-Memory Data Grid.
IgniteJdbcDriver() - Constructor for class org.apache.ignite.IgniteJdbcDriver
 
IgniteJdbcThinDataSource - Class in org.apache.ignite
JDBC thin DataSource implementation.
IgniteJdbcThinDataSource() - Constructor for class org.apache.ignite.IgniteJdbcThinDataSource
 
IgniteJdbcThinDriver - Class in org.apache.ignite
JDBC driver thin implementation for In-Memory Data Grid.
IgniteJdbcThinDriver() - Constructor for class org.apache.ignite.IgniteJdbcThinDriver
 
igniteLocalWorkDir() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteLock - Interface in org.apache.ignite
This interface provides a rich API for working with distributed reentrant locks.
IgniteLogger - Interface in org.apache.ignite
This interface defines basic logging functionality used throughout the system.
IgniteMBeanAware - Interface in org.apache.ignite.mxbean
MBean-aware interface.
IgniteMessageFactory - Interface in org.apache.ignite.plugin.extensions.communication
Message factory for all communication messages registered using IgniteMessageFactory.register(short, Supplier) method call.
IgniteMessaging - Interface in org.apache.ignite
Provides functionality for topic-based message exchange among nodes defined by IgniteMessaging.clusterGroup().
IgniteModel<T,V> - Interface in org.apache.ignite.ml
Basic interface for all models.
IgniteModelDescriptorStorage - Class in org.apache.ignite.ml.inference.storage.descriptor
Model descriptor storage based on Apache Ignite cache.
IgniteModelDescriptorStorage(IgniteCache<String, ModelDescriptor>) - Constructor for class org.apache.ignite.ml.inference.storage.descriptor.IgniteModelDescriptorStorage
Constructs a new instance of Ignite model descriptor storage.
IgniteModelParser<I,O> - Class in org.apache.ignite.ml.inference.parser
Implementation of model parser that accepts serialized IgniteFunction.
IgniteModelParser() - Constructor for class org.apache.ignite.ml.inference.parser.IgniteModelParser
 
IgniteModelStorageProvider - Class in org.apache.ignite.ml.inference.storage.model
Implementation of ModelStorageProvider based on Apache Ignite cache.
IgniteModelStorageProvider(IgniteCache<String, FileOrDirectory>) - Constructor for class org.apache.ignite.ml.inference.storage.model.IgniteModelStorageProvider
Constructs a new instance of Ignite model storage provider.
IgniteModelStorageUtil - Class in org.apache.ignite.ml.inference
Utils class that helps to operate with model storage and Ignite models.
IgniteModelStorageUtil() - Constructor for class org.apache.ignite.ml.inference.IgniteModelStorageUtil
 
IgniteMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on kernal.
IgniteNaturalIdDataAccess - Class in org.apache.ignite.cache.hibernate
Ignite implementation of NaturalIdDataAccess for Hibernate integration.
IgniteNaturalIdDataAccess(HibernateAccessStrategyAdapter, AccessType, RegionFactory, DomainDataRegion, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
IgniteNodeValidationResult - Class in org.apache.ignite.spi
Result of joining node validation.
IgniteNodeValidationResult(UUID, String) - Constructor for class org.apache.ignite.spi.IgniteNodeValidationResult
 
IgniteNodeValidationResult(UUID, String, String) - Constructor for class org.apache.ignite.spi.IgniteNodeValidationResult
 
IgniteNotPeerDeployable - Annotation Type in org.apache.ignite.lang
This annotations should be used to mark any type that should not be peer deployable.
IgniteOutClosure<T> - Interface in org.apache.ignite.lang
Closure that does not take any parameters and returns a value.
ignitePackagePath() - Method in class org.apache.ignite.mesos.ClusterProperties
Path on local file system to ignite archive.
ignitePackageUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
URL to ignite package.
ignitePath() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgnitePlugin - Interface in org.apache.ignite.plugin
Marker interface for all Ignite plugins.
IgnitePortProtocol - Enum in org.apache.ignite.spi
Protocols supported by port processor.
IgnitePredicate<E> - Interface in org.apache.ignite.lang
Defines a predicate which accepts a parameter and returns true or false.
IgniteProducer<T> - Interface in org.apache.ignite.lang
Defines a producer which can throw IgniteCheckedException.
IgniteProductVersion - Class in org.apache.ignite.lang
Represents node version.
IgniteProductVersion() - Constructor for class org.apache.ignite.lang.IgniteProductVersion
Empty constructor required by Externalizable.
IgniteProductVersion(byte, byte, byte, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
 
IgniteProductVersion(byte, byte, byte, String, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
 
IgniteProvider - Class in org.apache.ignite.mesos.resource
Class downloads and stores Ignite.
IgniteProvider(String) - Constructor for class org.apache.ignite.mesos.resource.IgniteProvider
 
IgniteProvider - Class in org.apache.ignite.yarn
Downloads and stores Ignite.
IgniteProvider(ClusterProperties, FileSystem) - Constructor for class org.apache.ignite.yarn.IgniteProvider
 
IgniteProvider.VersionComparator - Class in org.apache.ignite.yarn
Ignite version comparator.
IgniteProxy - Interface in org.apache.ignite.springdata.proxy
Reperesents Ignite cluster operations required by Spring Data.
IgniteProxyImpl - Class in org.apache.ignite.springdata.proxy
Implementation of IgniteProxy that provides access to Ignite cluster through Ignite instance.
IgniteProxyImpl(Ignite) - Constructor for class org.apache.ignite.springdata.proxy.IgniteProxyImpl
 
IgniteQuery - Class in org.apache.ignite.springdata22.repository.query
Ignite query helper class.
IgniteQuery(String, boolean, boolean, boolean, IgniteQuery.Option) - Constructor for class org.apache.ignite.springdata22.repository.query.IgniteQuery
 
IgniteQueryGenerator - Class in org.apache.ignite.springdata22.repository.query
Ignite query generator for Spring Data framework.
IgniteQueryResultsRegion - Class in org.apache.ignite.cache.hibernate
Implementation of QueryResultsRegion.
IgniteQueryResultsRegion(HibernateRegionFactory, String, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.IgniteQueryResultsRegion
 
IgniteQueue<T> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed queues based on In-Memory Data Grid.
IgniteReducer<E,R> - Interface in org.apache.ignite.lang
Defines generic reducer that collects multiple values and reduces them into one.
IgniteReflectionFactory<T> - Class in org.apache.ignite.configuration
Factory implementation that use reflection to create instance of given class.
IgniteReflectionFactory() - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
Default constructor.
IgniteReflectionFactory(Class<? extends T>, boolean) - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
 
IgniteReflectionFactory(Class<? extends T>) - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
Creates non-singleton component factory.
igniteReleasesDir() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteRepositoriesRegistar - Class in org.apache.ignite.springdata22.repository.config
Apache Ignite specific implementation of RepositoryBeanDefinitionRegistrarSupport.
IgniteRepositoriesRegistar() - Constructor for class org.apache.ignite.springdata22.repository.config.IgniteRepositoriesRegistar
 
IgniteRepository<V,K extends Serializable> - Interface in org.apache.ignite.springdata22.repository
Apache Ignite repository that extends basic capabilities of CrudRepository.
IgniteRepositoryConfigurationExtension - Class in org.apache.ignite.springdata22.repository.config
Apache Ignite specific implementation of RepositoryConfigurationExtension.
IgniteRepositoryConfigurationExtension() - Constructor for class org.apache.ignite.springdata22.repository.config.IgniteRepositoryConfigurationExtension
 
IgniteRepositoryFactory - Class in org.apache.ignite.springdata22.repository.support
Crucial for spring-data functionality class.
IgniteRepositoryFactory(ApplicationContext) - Constructor for class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
Creates the factory with initialized Ignite instance.
IgniteRepositoryFactoryBean<T extends org.springframework.data.repository.Repository<V,K>,V,K extends Serializable> - Class in org.apache.ignite.springdata22.repository.support
Apache Ignite repository factory bean.
IgniteRepositoryFactoryBean(Class<? extends T>) - Constructor for class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactoryBean
 
IgniteRepositoryImpl<V,K extends Serializable> - Class in org.apache.ignite.springdata22.repository.support
General Apache Ignite repository implementation.
IgniteRepositoryImpl(IgniteProxy, IgniteCacheProxy<K, V>) - Constructor for class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Repository constructor.
IgniteRepositoryQuery - Class in org.apache.ignite.springdata22.repository.query
Ignite query implementation.
IgniteRepositoryQuery(RepositoryMetadata, IgniteQuery, Method, ProjectionFactory, IgniteCacheProxy<?, ?>, DynamicQueryConfig, QueryMethodEvaluationContextProvider) - Constructor for class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery
Instantiates a new Ignite repository query.
IgniteRepositoryQuery.QueryCursorWrapper<T,V> - Class in org.apache.ignite.springdata22.repository.query
Ignite QueryCursor wrapper.
IgniteRunnable - Interface in org.apache.ignite.lang
Grid-aware adapter for Runnable implementations.
IgniteScheduler - Interface in org.apache.ignite
Provides functionality for scheduling jobs locally using UNIX cron-based syntax.
IgniteScheduler - Class in org.apache.ignite.mesos
Ignite scheduler receives offers from Mesos and decides how many resources will be occupied.
IgniteScheduler(ClusterProperties, ResourceProvider) - Constructor for class org.apache.ignite.mesos.IgniteScheduler
 
IgniteSemaphore - Interface in org.apache.ignite
This interface provides a rich API for working with distributed semaphore.
IgniteServices - Interface in org.apache.ignite
Defines functionality necessary to deploy distributed services on the grid.
IgniteSet<T> - Interface in org.apache.ignite
Set implementation based on 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.
IgniteSpiMBeanAdapter - Class in org.apache.ignite.spi
This class provides convenient adapter for MBean implementations.
IgniteSpiMBeanAdapter(IgniteSpiAdapter) - Constructor for class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Constructor
IgniteSpiMultiException - Exception in org.apache.ignite.spi
Grid SPI exception which may contain more than one failure.
IgniteSpiMultiException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new exception with given error message.
IgniteSpiMultiException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteSpiMultiException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new exception with given error message and optional nested exception.
IgniteSpiMultiException(String, Throwable, Collection<Throwable>) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new exception with given error message and optional nested exception.
IgniteSpiMultipleInstancesSupport - Annotation Type in org.apache.ignite.spi
Annotates whether or not multiple instances of this SPI can be started in the same VM.
IgniteSpiNoop - Annotation Type in org.apache.ignite.spi
Annotates NO-OP SPI implementations.
IgniteSpiOperationTimeoutException - Exception in org.apache.ignite.spi
Kind of exception that is used when failure detection timeout is enabled for TcpDiscoverySpi or TcpCommunicationSpi.
IgniteSpiOperationTimeoutException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiOperationTimeoutException
Constructor.
IgniteSpiOperationTimeoutHelper - Class in org.apache.ignite.spi
Object that incorporates logic that determines a timeout value for the next network related operation and checks whether a failure detection timeout is reached or not.
IgniteSpiOperationTimeoutHelper(IgniteSpiAdapter, boolean) - Constructor for class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Constructor.
IgniteSpiThread - Class in org.apache.ignite.spi
This class provides convenient adapter for threads used by SPIs.
IgniteSpiThread(String, String, IgniteLogger) - Constructor for class org.apache.ignite.spi.IgniteSpiThread
Creates thread with given name.
IgniteSpiThreadFactory - Class in org.apache.ignite.spi
This class provides implementation of ThreadFactory factory for creating grid SPI threads.
IgniteSpiThreadFactory(String, String, IgniteLogger) - Constructor for class org.apache.ignite.spi.IgniteSpiThreadFactory
 
IgniteSpiTimeoutObject - Interface in org.apache.ignite.spi
Provides possibility to schedule delayed execution, see IgniteSpiContext.addTimeoutObject(IgniteSpiTimeoutObject).
IgniteSpiVersionCheckException - Exception in org.apache.ignite.spi
Grid SPI exception for version check failure.
IgniteSpiVersionCheckException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
Creates new SPI exception with given error message.
IgniteSpiVersionCheckException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
Creates new SPI exception given throwable as a cause and source of error message.
IgniteSpiVersionCheckException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
Creates new SPI exception with given error message and optional nested exception.
IgniteSpring - Class in org.apache.ignite
Factory methods to start Ignite with optional Spring application context, this context can be injected into grid tasks and grid jobs using @SpringApplicationContextResource annotation.
IgniteSpring() - Constructor for class org.apache.ignite.IgniteSpring
 
IgniteSpringBean - Class in org.apache.ignite
Ignite Spring bean allows to bypass Ignition methods.
IgniteSpringBean() - Constructor for class org.apache.ignite.IgniteSpringBean
 
IgniteState - Enum in org.apache.ignite
Possible states of Ignition.
IgniteStripedThreadPoolExecutor - Class in org.apache.ignite.thread
An ExecutorService that executes submitted tasks using pooled grid threads.
IgniteStripedThreadPoolExecutor(int, String, String, Thread.UncaughtExceptionHandler, boolean, long) - Constructor for class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
Create striped thread pool.
IgniteSupplier<T> - Interface in org.apache.ignite.ml.math.functions
Serializable supplier.
IgniteSystemProperties - Class in org.apache.ignite
Contains constants for all system properties and environmental variables in Ignite.
IgniteTask - Class in org.apache.ignite.mesos
Information about launched task.
IgniteTask(String, double, double, double) - Constructor for class org.apache.ignite.mesos.IgniteTask
Ignite launched task.
IgniteThread - Class in org.apache.ignite.thread
This class adds some necessary plumbing on top of the Thread class.
IgniteThread(GridWorker) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates thread with given worker.
IgniteThread(String, String) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance.
IgniteThread(String, String, Runnable) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance.
IgniteThread(String, String, Runnable, int, int, byte) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance with specified thread group.
IgniteThread(String, ThreadGroup, String) - Constructor for class org.apache.ignite.thread.IgniteThread
 
IgniteThreadFactory - Class in org.apache.ignite.thread
This class provides implementation of ThreadFactory factory for creating grid threads.
IgniteThreadFactory(String, String) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadFactory(String, String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadFactory(String, String, byte, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadPoolExecutor - Class in org.apache.ignite.thread
An ExecutorService that executes submitted tasks using pooled grid threads.
IgniteThreadPoolExecutor(String, String, int, int, long, BlockingQueue<Runnable>) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(String, String, int, int, long, BlockingQueue<Runnable>, byte, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteTimestampsRegion - Class in org.apache.ignite.cache.hibernate
Implementation of TimestampsRegion.
IgniteTimestampsRegion(RegionFactory, String, Ignite, HibernateCacheProxy) - Constructor for class org.apache.ignite.cache.hibernate.IgniteTimestampsRegion
 
IgniteToDoubleFunction<T> - Interface in org.apache.ignite.ml.math.functions
Serializable function that produces a double-valued result.
IgniteTransactions - Interface in org.apache.ignite
Transactions facade provides ACID-compliant semantic when working with caches.
IgniteTriConsumer<A,B,C> - Interface in org.apache.ignite.ml.math.functions
Serializable tri-consumer.
IgniteTriFunction<A,B,C,R> - Interface in org.apache.ignite.ml.math.functions
Serializable TriFunction (A, B, C) -> R.
igniteUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
igniteUrl() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteUuid - Class in org.apache.ignite.lang
This is a faster performing version of UUID.
IgniteUuid() - Constructor for class org.apache.ignite.lang.IgniteUuid
Empty constructor required for Externalizable.
IgniteUuid(UUID, long) - Constructor for class org.apache.ignite.lang.IgniteUuid
Constructs GridUuid from a global and local identifiers.
igniteVer() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteWorkDir() - Method in class org.apache.ignite.mesos.ClusterProperties
 
igniteWorkDir() - Method in class org.apache.ignite.yarn.ClusterProperties
 
IgniteYarnClient - Class in org.apache.ignite.yarn
Ignite yarn client.
IgniteYarnClient() - Constructor for class org.apache.ignite.yarn.IgniteYarnClient
 
IgniteYarnUtils - Class in org.apache.ignite.yarn.utils
Utils.
IgniteYarnUtils() - Constructor for class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
Ignition - Class in org.apache.ignite
This class defines a factory for the main Ignite API.
Ignition() - Constructor for class org.apache.ignite.Ignition
Enforces singleton.
IgnitionListener - Interface in org.apache.ignite
Listener for gird state change notifications.
IgnitionMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on Ignition.
IgnoreIfPeerClassLoadingDisabled - Annotation Type in org.apache.ignite.spi.deployment
This annotation is for all implementations of DeploymentSpi that may be ignored if peer class loading is disabled.
impl - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
impl() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Implementation object.
implicit() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
implicit() - Method in interface org.apache.ignite.transactions.Transaction
Flag indicating whether transaction was started automatically by the system or not.
implicitSingle() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
impurity() - Method in class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasure
Calculates impurity measure as a single double value.
impurity() - Method in interface org.apache.ignite.ml.tree.impurity.ImpurityMeasure
Calculates impurity measure as a single double value.
impurity() - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
Calculates impurity measure as a single double value.
ImpurityComputer<T,H extends Histogram<T,H>> - Interface in org.apache.ignite.ml.tree.randomforest.data.impurity
Interface represents an object that can compute best splitting point using features histograms.
ImpurityHistogram - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Helper class for ImpurityHistograms.
ImpurityHistogram(int) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogram
Creates an instance of ImpurityHistogram.
ImpurityHistogramsComputer<S extends ImpurityComputer<BootstrappedVector,S>> - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Class containing logic of aggregation impurity statistics within learning dataset.
ImpurityHistogramsComputer() - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer
 
ImpurityHistogramsComputer.NodeImpurityHistograms<S extends ImpurityComputer<BootstrappedVector,S>> - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Class represents per feature statistics for impurity computing.
ImpurityMeasure<T extends ImpurityMeasure<T>> - Interface in org.apache.ignite.ml.tree.impurity
Base interface for impurity measures that can be used in distributed decision tree algorithm.
ImpurityMeasureCalculator<T extends ImpurityMeasure<T>> - Class in org.apache.ignite.ml.tree.impurity
Base interface for impurity measure calculators that calculates all impurity measures required to find a best split.
ImpurityMeasureCalculator(boolean) - Constructor for class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Constructs an instance of ImpurityMeasureCalculator.
ImputerPartitionData - Class in org.apache.ignite.ml.preprocessing.imputing
Partition data used in imputing preprocessor.
ImputerPartitionData() - Constructor for class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Constructs a new instance of imputing partition data.
ImputerPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.imputing
Preprocessing function that makes imputing.
ImputerPreprocessor(Vector, Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.imputing.ImputerPreprocessor
Constructs a new instance of imputing preprocessor.
ImputerTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.imputing
Trainer of the imputing preprocessor.
ImputerTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.imputing.ImputerTrainer
 
ImputingStrategy - Enum in org.apache.ignite.ml.preprocessing.imputing
This enum contains settings for imputing preprocessor.
in(String, Collection<?>) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
In.
includedScopes() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
 
includeNotReadyAddresses(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
incomeConnLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
increment(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Increments value at given index.
increment(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Increments value at given index.
increment(int, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Increments value at given index.
incrementalStateTransfer(String, long, byte) - Method in interface org.gridgain.grid.GridDr
Starts incremental state transfer for given cache.
incrementAndGet() - Method in interface org.apache.ignite.client.ClientAtomicLong
Increments and gets current value of atomic long.
incrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Increments and gets current value of atomic long.
incrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicSequence
Increments and returns the value of atomic sequence.
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.
incrementX(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Increments value at given index without checking for index boundaries.
incrementX(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Increments value at given index without checking for index boundaries.
incrementX(int, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Increments value at given index without checking for index boundaries.
index() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector.Element
Gets element's index in the vector.
index() - Method in enum org.apache.ignite.ShutdownPolicy
 
indexes() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
Indexes of non-default elements.
indexes() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
 
indexesMap() - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
 
indexesMap() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
 
IndexException - Exception in org.apache.ignite.ml.math.exceptions
Indicates an invalid, i.e. out of bound, index on matrix or vector operations.
IndexException(int) - Constructor for exception org.apache.ignite.ml.math.exceptions.IndexException
 
IndexingQueryCacheFilter - Class in org.apache.ignite.spi.indexing
Indexing query filter for specific cache.
IndexingQueryCacheFilter(GridCacheAffinityManager, Set<Integer>, AffinityTopologyVersion, ClusterNode) - Constructor for class org.apache.ignite.spi.indexing.IndexingQueryCacheFilter
Constructor.
IndexingQueryFilter - Interface in org.apache.ignite.spi.indexing
Cache entry filter.
IndexingQueryFilterImpl - Class in org.apache.ignite.spi.indexing
Indexing query filter.
IndexingQueryFilterImpl(GridKernalContext, AffinityTopologyVersion, int[], boolean) - Constructor for class org.apache.ignite.spi.indexing.IndexingQueryFilterImpl
Constructor.
IndexingQueryFilterImpl(GridKernalContext, AffinityTopologyVersion, int[]) - Constructor for class org.apache.ignite.spi.indexing.IndexingQueryFilterImpl
Constructor.
IndexingSpi - Interface in org.apache.ignite.spi.indexing
Indexing SPI allows user to index cache content.
indexName() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns index name.
IndexQuery<K,V> - Class in org.apache.ignite.cache.query
Index query is a high-level API that allows user to retrieve cache entries that match specified criteria.
IndexQuery(Class<?>) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value class.
IndexQuery(String) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value type.
IndexQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value class and index name.
IndexQuery(String, String) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value type and index name.
IndexQueryCriteriaBuilder - Class in org.apache.ignite.cache.query
IndexQueryCriteriaBuilder() - Constructor for class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
 
IndexQueryCriterion - Interface in org.apache.ignite.cache.query
Basic interface for IndexQuery criterion.
indexReadyFuture() - Method in interface org.apache.ignite.IgniteCache
Returns future that will be completed when all indexes for this cache are ready to use.
indexStream(int, BitSet) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
indexStream(int, String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
indexType() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns index type.
info(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out information message.
info(String, String) - Method in interface org.apache.ignite.IgniteLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.EchoingLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out information message.
info(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out information message.
info(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out information message.
init() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Class instance initialization.
init(FilterConfig) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
init(ClusterProperties, IgniteProvider, String) - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
init(DeployingContext) - Method in interface org.apache.ignite.ml.environment.deploy.DeployingContext
Inits context by other context.
init(DeployingContext) - Method in class org.apache.ignite.ml.environment.deploy.DeployingContextImpl
Inits context by other context.
init(M, IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>) - Method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovUpdateCalculator
Initializes the update calculator.
init(M, IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>) - Method in interface org.apache.ignite.ml.optimization.updatecalculators.ParameterUpdateCalculator
Initializes the update calculator.
init(SmoothParametrized, IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>) - Method in class org.apache.ignite.ml.optimization.updatecalculators.RPropUpdateCalculator
Initializes the update calculator.
init(SmoothParametrized, IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>) - Method in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Initializes the update calculator.
init(Dataset<EmptyContext, BootstrappedDatasetPartition>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Aggregates all unique labels from dataset and assigns integer id value for each label.
init(Dataset<EmptyContext, BootstrappedDatasetPartition>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Init-step before learning.
init(PlatformAffinityFunction) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Initializes this instance.
init(ServiceContext) - Method in interface org.apache.ignite.services.Service
Pre-initializes service before execution.
init() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionService
For initialization operations.
init() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
For initialization operations.
init() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.EncryptionService
For initialization operations.
init() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionService
For initialization operations.
init() - Method in class org.apache.ignite.startup.servlet.ServletStartup
init(ServiceContext) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterMaintainer
Pre-initializes service before execution.
init() - Method in class org.apache.ignite.yarn.ApplicationMaster
 
initBiases(Vector) - Method in interface org.apache.ignite.ml.nn.initializers.MLPInitializer
In-place change values of vector representing vectors.
initBiases(Vector) - Method in class org.apache.ignite.ml.nn.initializers.RandomInitializer
In-place change values of vector representing vectors.
initByClientObject(Object) - Method in interface org.apache.ignite.ml.environment.deploy.DeployingContext
Inits context by any client-defined object.
initByClientObject(Object) - Method in class org.apache.ignite.ml.environment.deploy.DeployingContextImpl
Inits context by any client-defined object.
initContext(Ignite, String, UpstreamTransformerBuilder, IgniteBiPredicate<K, V>, String, PartitionContextBuilder<K, V, C>, LearningEnvironmentBuilder, int, int, boolean, DeployingContext) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Initializes partition context by loading it from a partition upstream.
initDeployingContext(Object) - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Initializes deploying context by object representing current client computation with classes unknown for server side.
initExtensions(PluginContext, ExtensionRegistry) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Registers extensions.
initExtensions(PluginContext, ExtensionRegistry) - Method in interface org.apache.ignite.plugin.PluginProvider
Registers extensions.
initFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Initiates and checks failure detection timeout value.
initFuture() - Method in interface org.gridgain.grid.persistentstore.SnapshotFuture
 
initialCount() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets initial count value of the latch.
initialCount() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
initializeLocalAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Initializes addresses discovery SPI binds to.
initializeLocalAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Initializes addresses discovery SPI binds to.
initializeLocalAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Initializes addresses discovery SPI binds to.
initialVersion() - Method in class org.gridgain.grid.ru.GridRollingUpgradeStatus
Returns the version that is used as starting point for Rolling Upgrade.
initiatorId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
Returns query initiator ID.
initiatorId() - Method in class org.gridgain.grid.events.DrCacheReplicationEvent
Returns id of the initiator node.
initiatorNode() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Gets UUID of the node which originated the snapshot.
initiatorNodeId() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
Snapshot initiator node ID.
initLearningState(GDBTrainer.GDBModel) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Restores state of already learned model if can and sets learning parameters according to this state.
initLocalNode(int, boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
initTrees(Queue<TreeNode>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Creates list of trees.
initWeights(Matrix) - Method in interface org.apache.ignite.ml.nn.initializers.MLPInitializer
In-place change values of matrix representing weights.
initWeights(Matrix) - Method in class org.apache.ignite.ml.nn.initializers.RandomInitializer
In-place change values of matrix representing weights.
injectables() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method returns SPI internal instances that need to be injected as well.
injectables() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method returns SPI internal instances that need to be injected as well.
injectResources(Ignite) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Inject ignite instance.
injectResources(Ignite) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Inject resources
injectResources(Ignite) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Inject ignite instance.
inlineSize() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns inline size in bytes.
InMemoryModelReader - Class in org.apache.ignite.ml.inference.reader
Model reader that reads predefined array of bytes.
InMemoryModelReader(byte[]) - Constructor for class org.apache.ignite.ml.inference.reader.InMemoryModelReader
Constructs a new instance of in-memory model reader that returns specified byte array.
InMemoryModelReader(T) - Constructor for class org.apache.ignite.ml.inference.reader.InMemoryModelReader
Constructs a new instance of in-memory model reader that returns serialized specified object.
innerModel() - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetModel
Get inner model.
inProgress() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Get defragmentation status.
input - Variable in class org.apache.ignite.ml.nn.MLPState
Input.
inputIterator(Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns iterator of input records.
inputSize() - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Size of input of MLP.
inputStream() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Opens input stream for this file.
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.
insert(SharedSessionContractImplementor, Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
insert(SharedSessionContractImplementor, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
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.
install() - Static method in class org.apache.ignite.logger.log4j2.Log4jBridgeHandler
Adds a new Log4jBridgeHandler instance to JUL's root logger.
INSTANCE - Static variable in class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
Singleton instance to use.
INSTANCE - Static variable in class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer
Singleton instance to use.
INSTANCE - Static variable in class org.apache.ignite.logger.NullLogger
Singleton instance.
INSTANCE - Static variable in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy
Instance.
instance() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
instance() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestRegressionTrainer
instance() - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
INSTANCE - Static variable in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Instance.
INSTANCE - Static variable in class org.apache.ignite.yarn.IgniteProvider.VersionComparator
 
INSTANCE_NAME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
INSTANCE_NAME_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite instance name.
instances() - Method in class org.apache.ignite.mesos.ClusterProperties
 
instances() - Method in class org.apache.ignite.yarn.ClusterProperties
 
instances(int) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets instance count limit.
INT - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
INT - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
INT() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
 
INT() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
 
INT() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
INT(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
INT() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
 
IntCoordVectorizer(Integer...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.IntCoordVectorizer
Creates an instance of Vectorizer.
IntDoubleToVoidFunction - Interface in org.apache.ignite.ml.math.functions
Setter function for the vector.
intercept() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Gets the intercept.
intercept() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Gets the intercept.
interceptor() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
internal() - Method in class org.apache.ignite.events.TaskEvent
Returns true if task is created by Ignite and is used for system needs.
internal() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
internal() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
INTERNAL_ISSUE_MSG - Static variable in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
Internal issue.
internalLabelToExternal(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBBinaryClassifierTrainer
Maps internal representation of label to external.
internalLabelToExternal(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBRegressionTrainer
Maps internal representation of label to external.
internalLabelToExternal(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Maps internal representation of label to external.
InteropConfiguration - Interface in org.gridgain.grid.configuration
Interop configuration marker interface.
InteropCppConfiguration - Class in org.gridgain.grid.interop.cpp
Interop CPP configuration.
InteropCppConfiguration() - Constructor for class org.gridgain.grid.interop.cpp.InteropCppConfiguration
Default constructor.
InteropCppConfiguration(InteropCppConfiguration) - Constructor for class org.gridgain.grid.interop.cpp.InteropCppConfiguration
Copying constructor.
interval() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
IntIntDoubleToVoidFunction - Interface in org.apache.ignite.ml.math.functions
Setter function for matrices.
IntIntToDoubleFunction - Interface in org.apache.ignite.ml.math.functions
Getters functions for matrices.
IntMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds int primitive.
INV - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns 1 / a
INVALID_ALGO_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
Error message when the snapshot digest registry contains invalid digest algorithm.
INVALID_CONSISTENT_ID_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
Error message when the snapshot digest registry constains invalid consistent id.
INVALID_SNAPSHOT_ID_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
Error message when the snapshot digest registry contains invalid snapshot id.
inverse() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Returns the inverse matrix of this matrix
inverse() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Returns the inverse matrix of this matrix
invoke(AffinityTopologyVersion, Object, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invoke(Object, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySetToSetSpringAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySetToValueSpringAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringAspect
Aspect implementation which executes grid-enabled methods on remote nodes.
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Please refer to documentation for CacheAtomicityMode.ATOMIC for information on system behavior in crash scenarios for atomic caches.
invoke(K, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Invokes an CacheEntryProcessor against the Cache.Entry specified by the provided key.
invoke(String, Object[], String[]) - Method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
invoke(String, Object[], String[]) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
invokeAll(Map, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAll(Set, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAll(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes each EntryProcessor from map's values against the correspondent Cache.Entry specified by map's key set.
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
/** Invokes an EntryProcessor against the set of Entrys specified by the set of keys.
invokeAll(Set<? extends K>, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Invokes an CacheEntryProcessor against the set of Cache.Entrys specified by the set of keys.
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAllAsync(Map, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAllAsync(Set, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAllAsync(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronous version of the IgniteCache.invokeAll(Map, Object...) method.
invokeAllAsync(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an EntryProcessor against the set of Cache.Entrys specified by the set of keys.
invokeAllAsync(Set<? extends K>, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an CacheEntryProcessor against the set of Cache.Entrys specified by the set of keys.
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAsync(Object, EntryProcessor, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
invokeAsync(K, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an EntryProcessor against the Cache.Entry specified by the provided key.
invokeAsync(K, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an CacheEntryProcessor against the Cache.Entry specified by the provided key.
ioFactory(FileIOFactory) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
IoPool - Interface in org.apache.ignite.plugin.extensions.communication
The interface of IO Messaging Pool Extension.
IoStatisticsMetricsMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view for IO statistics.
ipFinder - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
IP finder.
ipFinderCleanFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
The frequency with which coordinator cleans IP finder and keeps it in the correct state, which means that coordinator unregisters addresses of the nodes that have left the topology and re-registries missing addresses.
IS_NODE_BASELINE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
IS_PEER_CLS_LOADING_ENABLED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
IS_REBALANCE_ENABLED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
isActiveOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
isAffinityAwarenessEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether partition awareness should be enabled.
isAllowDuplicateRegistrations() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
* @return The value of this flag.
isAllSegmentationResolversPassRequired() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets all segmentation resolvers pass required flag.
isAlwaysWriteFullPages() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
isAlwaysWriteFullPages() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
Checks if implementation is based on Java arrays.
isArrayBased() - Method in interface org.apache.ignite.ml.math.StorageOpsMetrics
Checks if implementation is based on Java arrays.
isAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Deprecated.
since 2.0. Please use new specialized async method e.g.
     IgniteFuture f = cache.getAsync();
 
instead of old-style async API:
     IgniteCache asyncCache = cache.withAsync();
     asyncCache.get(key);
     IgniteFuture fut = asyncCache.future();
 
isAttemptToEstablishDirectConnectionWhenOnlyInverseIsAllowed(Throwable) - Static method in class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
Returns true if the exception that is provided is thrown because an attempt to open a direct connection was made while only inverse connections are allowed.
isAuthenticationEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns true if user authentication is enabled for cluster.
isAutoActivationEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
isAutoAdjustEnabled() - Method in class org.apache.ignite.events.BaselineConfigurationChangedEvent
Auto-adjust "enabled" flag value.
isAutoAdjustmentEnabled() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
isAutoBinaryConfigurationEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether automatic binary configuration retrieval should be enabled.
isAutoCloseServerCursor() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isAutogenerated() - Method in class org.apache.ignite.springdata22.repository.query.IgniteQuery
Returns true if it's autogenerated, false otherwise.
isAutoUnsubscribe() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets automatic unsubscription flag value.
isAwaitAcknowledge() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Gets await acknowledge flag.
isBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if local node is one of the backup nodes for given key.
isBaselineAutoAdjustEnabled() - Method in interface org.apache.ignite.IgniteCluster
 
isBroken() - Method in interface org.apache.ignite.IgniteLock
Returns true if any node that owned the locked failed before releasing the lock.
isBroken() - Method in interface org.apache.ignite.IgniteSemaphore
Gets broken status of the semaphore.
isCached() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Checks whether entry is currently present in cache or not.
isCacheSanityCheckEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets flag indicating whether cache sanity check is enabled.
isCancelled() - Method in class org.apache.ignite.compute.ComputeJobAdapter
This method tests whether or not this job was cancelled.
isCancelled() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets job cancellation status.
isCancelled() - Method in interface org.apache.ignite.lang.IgniteFuture
Returns true if this task was cancelled before it completed normally.
isCancelled() - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy.FutureWrapper
isCancelled() - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy.Stub
isCancelled() - Method in interface org.apache.ignite.services.ServiceContext
Get flag indicating whether service has been cancelled or not.
isCassandraCompatibleTypes(Class, Class) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if two Java classes are Cassandra compatible - mapped to the same Cassandra type.
isCategoricalFeature() - Method in class org.apache.ignite.ml.dataset.feature.FeatureMeta
 
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.
isChecksum() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Gets whether checksum calculation is enabled.
isChecksumEnabled() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets checksum enabled flag.
isChiefCompleted(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Checks if chief completed and returns result.
isClient() - Method in interface org.apache.ignite.cluster.ClusterNode
Whether this node is cache client (see IgniteConfiguration.isClientMode()).
isClient() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
 
isClient() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Whether this node is cache client (see IgniteConfiguration.isClientMode()).
isClient() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
isClientMode() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets client mode flag.
isClientMode() - Static method in class org.apache.ignite.Ignition
Gets client mode thread-local flag.
isClientMode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Whether or not discovery is started in client mode.
isClientMode() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Whether or not discovery is started in client mode.
isClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Whether or not discovery is started in client mode.
isClientMode() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Whether or not discovery is started in client mode.
isClientMode() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Whether or not discovery is started in client mode.
isClientNodeTopologyException(Throwable, ClusterNode) - Static method in class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
Returns true if the exception relates to cluster topology change that prevents a connection, AND the given node is client.
isClientReconnectDisabled() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
If true client does not try to reconnect after server detected client node failure.
isClientReconnectDisabled() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
If true client does not try to reconnect.
isClosed() - Method in class org.apache.ignite.cache.CacheManager
isClusterDiscoveryEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether cluster discovery should be enabled.
isCollocated() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Checks if this query is collocated.
isCollocated() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
isCollocated() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isColocated() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
isCompactFooter() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Get whether to write footers in compact form.
isCompleted() - Method in class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Checks if process is already completed.
isCompressionCodecSupported(CompressionOption) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Checks whether given compression codec is supported by this configuration.
isCompressKeys() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Gets flag indicating whether cache keys will be considered for compression.
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.
isConverged(LearningEnvironmentBuilder, DatasetBuilder<K, V>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceChecker
Checks convergency on dataset.
isConverged(Dataset<EmptyContext, ? extends FeatureMatrixWithLabelsOnHeapData>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceChecker
Checks convergency on dataset.
isConverged(LearningEnvironmentBuilder, DatasetBuilder<K, V>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.simple.ConvergenceCheckerStub
Checks convergency on dataset.
isConverged(Dataset<EmptyContext, ? extends FeatureMatrixWithLabelsOnHeapData>, ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.convergence.simple.ConvergenceCheckerStub
Checks convergency on dataset.
isCopyOnRead() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isCopyOnRead() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets the flag indicating whether a copy of the value stored in the on-heap cache (see CacheConfiguration.isOnheapCacheEnabled() should be created for a cache operation return the value.
isCopyOnRead() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isCopyRequired(long, SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Method checks whether copy is required or not.
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.
isDaemon() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Tests whether or not this node is a daemon.
isDaemon() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
isDebugEnabled() - Method in interface org.apache.ignite.IgniteLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.EchoingLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.NullLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether debug level is enabled.
isDefaultKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Gets default keep deserialized flag.
isDefaultPath() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
 
isDense() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDense() - Method in interface org.apache.ignite.ml.math.StorageOpsMetrics
Checks if this implementation should be considered dense so that it explicitly represents every value.
isDirectBuffer() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets flag indicating whether REST TCP server should use direct buffers.
isDirectBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets flag that indicates whether direct or heap allocated buffer is used.
isDirectBuffer() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets direct buffer flag in receiver hub's TCP server.
isDirectBuffer() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Whether to use direct buffer when processing sender hub requests.
isDirectory(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Returns true if the specified path associated with a directory.
isDirectory() - Method in interface org.apache.ignite.ml.inference.storage.model.FileOrDirectory
Return true if this object is a directory, otherwise false.
isDirectory() - Method in class org.apache.ignite.ml.inference.storage.model.FileStat
 
isDirectory(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Returns true if the specified path associated with a directory.
isDirectory() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Checks that this is a folder.
isDirectSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets flag defining whether direct send buffer should be used.
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed() - Method in interface org.apache.ignite.ml.math.StorageOpsMetrics
Checks whether implementation is JVM-local or distributed (multi-JVM).
isDistributed - Variable in class org.apache.ignite.ml.structures.Dataset
 
isDistributed() - Method in class org.apache.ignite.ml.structures.Dataset
 
isDistributedJoins() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Check if distributed joins are enabled for this query.
isDistributedJoins() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Check if distributed joins are enabled for this query.
isDistributedJoins() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isDone() - Method in interface org.apache.ignite.lang.IgniteFuture
Returns true if this task completed.
isDone() - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy.FutureWrapper
isDone() - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy.Stub
isDrReceiverEnabled() - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
isDrUseCacheNames() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Compatibility flag.
isEagerTtl() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
isEagerTtl() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
isEagerTtl() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isEmpty() - Method in interface org.apache.ignite.cache.CacheMetrics
Returns true if this cache is empty.
isEmpty() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.apache.ignite.cache.QueryEntityPatch
 
isEmpty() - Method in interface org.apache.ignite.client.ClientIgniteSet
isEmpty() - Method in interface org.apache.ignite.IgniteQueue
isEmpty() - Method in interface org.apache.ignite.IgniteSet
isEmpty() - Method in class org.apache.ignite.lang.IgniteBiTuple
isEmpty() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Returns true if this cache is empty.
isEmptyDirectory() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Checks that directory is empty.
isEnabled(int) - Method in interface org.apache.ignite.IgniteEvents
Check if event is enabled.
isEnabled() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Returns true if Rolling Upgrade is enabled and is in progress.
isEncryptionEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether data must be encrypted.
isEncryptionEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isEnded() - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
isEnded() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
isEnded() - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
 
isEnforceJoinOrder() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Checks if join order of tables if enforced.
isEnforceJoinOrder() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isEnum() - Method in interface org.apache.ignite.binary.BinaryType
Check whether type represents enum or not.
isEnum() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets whether this is enum type.
isEnum() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Gets whether this is enum type.
isEqualTo(H) - Method in interface org.apache.ignite.ml.dataset.feature.Histogram
Compares histogram with other and returns true if they are equals
isEqualTo(ObjectHistogram<T>) - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
Compares histogram with other and returns true if they are equals
isEqualTo(GiniHistogram) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
Compares histogram with other and returns true if they are equals
isEqualTo(MSEHistogram) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
Compares histogram with other and returns true if they are equals
isEventRecordable(int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Checks whether all provided event types are recordable.
isEvents() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
isEventsDisabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Checks whether events are disabled for this cache.
isEventsDisabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isExcluded(Class<?>) - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Checks whether or not given class should be excluded from marshalling.
isExcludeNeighbors() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Checks flag to exclude same-host-neighbors from being backups of each other (default is false).
isExclusiveOperation() - Method in enum org.gridgain.grid.persistentstore.SnapshotOperationType
Checking if the operation is exclusive, i.e. cannot run in parallel with others.
isExistingTransaction(Object) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
isFailoverSafe() - Method in interface org.apache.ignite.IgniteLock
Returns true if this lock is safe to use after node failure.
isFailoverSafe() - Method in interface org.apache.ignite.IgniteSemaphore
Returns true if this semaphore is safe to use after node failure.
isFair() - Method in interface org.apache.ignite.IgniteLock
Returns true if this lock is fair.
isFieldQuery() - Method in class org.apache.ignite.springdata22.repository.query.IgniteQuery
Returns true if it's Ignite SQL fields query, false otherwise.
isFieldQuery(String) - Static method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactory
 
isFile(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Returns true if the specified path associated with a regular file.
isFile() - Method in interface org.apache.ignite.ml.inference.storage.model.FileOrDirectory
Returns true if this object is a regular file, otherwise false.
isFile(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Returns true if the specified path associated with a regular file.
isFile() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Checks that this is a file.
isFinishing() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isForbiddenToRequestBinaryMetadata() - Method in class org.apache.ignite.thread.IgniteThread
 
isForceServerMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Deprecated.
Will be removed at 3.0.
isGlobalNodeAuthentication() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
Gets global node authentication flag.
isGlobalNodeAuthentication() - Method in interface org.gridgain.grid.security.Authenticator
Flag indicating whether node authentication should be run on coordinator only or on all nodes in current topology.
isGlobalNodeAuthentication() - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
Flag indicating whether node authentication should be run on coordinator only or on all nodes in current topology.
isGlobalNodeAuthentication() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Flag indicating whether node authentication should be run on coordinator only or on all nodes in current topology.
isGlobalNodeAuthentication() - Method in class org.gridgain.grid.security.passcode.IgniteAuthenticator
Flag indicating whether node authentication should be run on coordinator only or on all nodes in current topology.
isGlobalNodeAuthentication() - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Flag indicating whether node authentication should be run on coordinator only or on all nodes in current topology.
isGlobalStore() - Method in interface org.gridgain.grid.dr.DrSender
Check whether configured DR store is global and is shared between all connections.
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
 
isHeartbeatEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether heartbeats are enabled.
isHeldByCurrentThread() - Method in interface org.apache.ignite.IgniteLock
Queries if this lock is held by the current thread.
isHigherFitnessValFitter() - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
 
isHostsAvailabilityError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra host availability error occur, thus host became unavailable.
isIdempotent() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
isIncludeExpired() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets the flag value defining whether to notify about EventType.EXPIRED events.
isIndexed() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Indicates if secondary index should be created for the field.
isIndexRebuildInProgress() - Method in interface org.apache.ignite.cache.CacheMetrics
Return true if index rebuild is in progress.
isIndexRebuildInProgress() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Return true if index rebuild is in progress.
isIndexRebuildInProgress() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
 
isInfoEnabled() - Method in interface org.apache.ignite.IgniteLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.EchoingLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.NullLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether info level is enabled.
isInstalled() - Static method in class org.apache.ignite.logger.log4j2.Log4jBridgeHandler
Returns true if Log4jBridgeHandler has been previously installed, returns false otherwise.
isInternal() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isInvalidate() - Method in class org.apache.ignite.configuration.CacheConfiguration
Invalidation flag.
isInvalidate() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isInvalidate() - Method in interface org.apache.ignite.transactions.Transaction
Get invalidation flag for this transaction.
isJdbcEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether access through JDBC is enabled.
isJoiningNodeClient() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
isKeepBinary() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Gets a value indicating whether platform cache should store keys and values in binary form.
isKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
isKeepingRawLabels() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Gets the output label format mode.
isKeepingRawLabels() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Gets the output label format mode.
isKeyBinary() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Checks the key is binary object.
isKeyspaceAbsenceError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra keyspace absence error occur.
isLastRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Tells whether last invocation of any of readXXX(...)
isLateAffinityAssignment() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Starting from Ignite 2.1 late affinity assignment is always enabled.
isLazy() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets lazy query execution flag.
isLazy() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isLazyBinaryMetadataRegistration() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets metadata registration mode flag: - true metadata is registered on the received cluster only when data that is replicated; - false all metadata received from the master cluster are registered.
isLazyMemoryAllocation() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
 
isLoadPreviousValue() - Method in class org.apache.ignite.configuration.CacheConfiguration
isLoadPreviousValue() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isLocal() - Method in class org.apache.ignite.cache.query.Query
Returns true if this query should be executed on local node only.
isLocal() - Method in interface org.apache.ignite.cluster.ClusterNode
Tests whether or not this node is a local node.
isLocal() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Tests whether or not this node is a local node.
isLocal() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
isLocalLocked(K, boolean) - Method in interface org.apache.ignite.IgniteCache
Deprecated.
It is recommended to use the lock instance obtained via Ignite.reentrantLock(String, boolean, boolean, boolean) method.
isLocalNodeCoordinator() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Checks whether local node is coordinator.
isLocalSender() - Method in interface org.gridgain.grid.GridDr
Checks whether current node is sender.
isLocked(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks if any node owns a lock for this key.
isLocked() - Method in interface org.apache.ignite.IgniteLock
Queries if this lock is held by any thread on any node.
isLockedByThread(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Checks if current thread owns a lock on this key.
isLoggable(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
isLowerCase() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Gets whether to use strings in lower case or not.
isMaintenanceMode() - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
 
isManagementEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether cache management via MBean is enabled.
isManagementEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Checks whether cache management via MBean is enabled.
isManagementEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isMarshalLocalJobs() - Method in class org.apache.ignite.configuration.IgniteConfiguration
If this flag is set to true, jobs mapped to local node will be marshalled as if it was remote node.
isMessaging() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
isMetricsEnabled() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets whether memory metrics are enabled by default on node startup.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets flag indicating whether persistence metrics collection is enabled.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets whether memory metrics are enabled by default on node startup.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets flag indicating whether persistence metrics collection is enabled.
isMinimalPutsEnabledByDefault() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
isMutable() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
 
isNear() - Method in class org.apache.ignite.events.CacheEvent
Gets flag indicating whether event happened on near or partitioned cache.
isNearCacheEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isNodeInBaseline() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
isNoDelay() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets flag indicating whether TCP_NODELAY option should be set for accepted client connections.
isNodeStopping() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
isNumeric() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
isNumeric() - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
isNumeric() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
isNumeric() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
isNumeric() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
isNumeric() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
isNumeric() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
isNumeric() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
isNumeric() - Method in interface org.apache.ignite.ml.math.StorageOpsMetrics
 
isOdbcEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether access through ODBC is enabled.
IsolatedDiscoverySpi - Class in org.apache.ignite.spi.discovery.isolated
Special discovery SPI implementation to start a single-node cluster in "isolated" mode.
IsolatedDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
 
IsolatedNode - Class in org.apache.ignite.spi.discovery.isolated
Special isolated node.
IsolatedNode(UUID, Map<String, Object>, IgniteProductVersion) - Constructor for class org.apache.ignite.spi.discovery.isolated.IsolatedNode
 
isolation() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
isolation() - Method in interface org.apache.ignite.transactions.Transaction
Cache transaction isolation level.
isOnheapCacheEnabled() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isOnheapCacheEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Checks if the on-heap cache is enabled for the off-heap based page memory.
isOnheapCacheEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isOverflow() - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Get overflow state of the store.
isOverflow() - Method in interface org.gridgain.grid.dr.store.DrSenderStore
Get overflow state of the store.
isPeerClassLoadingEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns true if peer class loading is enabled, false otherwise.
isPeerClassLoadingEnabled() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
isPersistenceEnabled() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets whether persistence is enabled for this data region.
isPersistentStoreEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Part of legacy configuration API. Doesn't work if new configuration API is used.
isPerTask() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
isPerTask() - Method in interface org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpiMBean
Configuration parameter indicating whether a new round robin order should be created for every task.
isPk() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns boolean value which indicates whether this index is for primary key or not.
isPointInTimeRecoveryEnabled() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
isPreferLocalSender() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Whether to prefer the local sender hub (if available) ignoring the load balancing policy.
isPreparedStatementClusterError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra error occur because of prepared statement created in one session was used in another session.
isPresent() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
Is snapshot present.
isPrimary(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if given node is the primary node for given key.
isPrimaryOrBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if local node is primary or one of the backup nodes This method is essentially equivalent to calling "Affinity.isPrimary(ClusterNode, Object) || Affinity.isBackup(ClusterNode, Object))", however it is more efficient as it makes both checks at once.
isQuery() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
isQuiet() - Method in interface org.apache.ignite.IgniteLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.EchoingLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.NullLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether Logger is in "Quiet mode".
isReadFromBackup() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets flag indicating whether data can be read from backup.
isReadFromBackup() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether data can be read from backup.
isReadFromBackup() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isReadOnly() - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Indicates if it's read-only field.
isReadThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines if a Cache should operate in read-through mode.
isReadThrough() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Determines if a Cache should operate in read-through mode.
isReadThrough() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isRebalanceEnabled() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Use GridMetricManager instead.
isReplicatedOnly() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
isReplicatedOnly() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
isReplicatedOnly() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isRequireDictionary() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Flag indicating that compression without dictionary, such as before the dictionary is trained, is enabled.
isROCAUCenabled() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
isRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
If transaction was marked as rollback-only.
isRollingUpdatesEnabled() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Gets rolling updates enabled flag.
isRunning() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Returns true if scheduled task is currently running.
isRunningOnPipeline - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Execution over the pipeline or the chain of preprocessors and separate trainer, otherwise.
isRunningOnPipeline(boolean) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
isShared() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Checks whether IP finder is shared or not.
isShared() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Checks whether IP finder is shared or not.
isShared() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
isShutdown() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
 
isShutdown() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
Returns true if this executor has been shut down.
isShutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
isSimpleName() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Gets whether to use simple name of class or not.
isSingleton() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
isSkipReducerOnUpdate() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets server side update flag.
isSkipReducerOnUpdate() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isSnapshotInProgress() - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets flag indicating if there is an ongoing snapshot operation.
isSqlEscapeAll() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
isSqlEscapeAll() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
isSqlEscapeAll() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isSqlEscapeAll() - Method in class org.apache.ignite.configuration.CacheConfiguration
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
isSqlEscapeAll() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isSqlOffloadingEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
isSqlOffloadingEnabled() - Method in class org.apache.ignite.configuration.SqlConfiguration
Returns flag whether disk offloading is enabled.
isSqlOnheapCacheEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets whether SQL on-heap cache is enabled.
isSqlOnheapCacheEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isSslClientAuth() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets a flag indicating whether or not remote clients will be required to have a valid SSL certificate which validity will be verified with trust manager.
isSslClientAuth() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets a flag indicating whether or not remote clients will be required to have a valid SSL certificate which validity will be verified with trust manager.
isSslEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Whether secure socket layer should be enabled on client connector.
isSslEnabled() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Whether secure socket layer should be enabled on binary rest server.
isSslTrustAll() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
isSslTrustAll() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets trust any server certificate flag.
isStarted() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isStarvationPreventionEnabled() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets flag indicating whether job starvation prevention is enabled.
isStarvationPreventionEnabled() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets flag indicating whether job starvation prevention is enabled.
isStatisticsEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether statistics collection is enabled in this cache.
isStatisticsEnabled() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isStatisticsEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Checks whether statistics collection is enabled in this cache.
isStatisticsEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isStealingEnabled() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
isStealingEnabled() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
isStopping() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
isStoreByValue() - Method in interface org.apache.ignite.cache.CacheMetrics
Whether storeByValue true or storeByReference false.
isStoreByValue() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Whether storeByValue true or storeByReference false.
isStoreKeepBinary() - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating that CacheStore implementation is working with binary objects instead of Java objects.
isStoreKeepBinary() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isStoreOverflow() - Method in interface org.gridgain.grid.dr.DrSenderConnection
Get store overflow flag.
isSuccess() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets result of success or failure.
issueDate() - Method in interface org.gridgain.grid.product.ProductLicense
Gets issue date.
issueMessage() - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
 
issueOrganization() - Method in interface org.gridgain.grid.product.ProductLicense
Gets issue organization.
IssuerRegexPredicate - Class in org.gridgain.grid.security.certificate
This predicate checks X.509 certificates' Issuer Distinguished Names to match supplied regular expression Pattern.
IssuerRegexPredicate(String) - Constructor for class org.gridgain.grid.security.certificate.IssuerRegexPredicate
Constructs X.509 Issuer DN regular expression predicate.
isSupported(OptionalFeature) - Method in class org.apache.ignite.cache.CachingProvider
isSyncronousWrites() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets synchronous mode flag.
isSystemType(String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Checks whether the given type is a system one - JDK class or Ignite class.
isTableAbsenceError(Throwable) - Static method in class org.apache.ignite.cache.store.cassandra.common.CassandraHelper
Checks if Cassandra table absence error occur.
isTcpNoDelay() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
isTcpNoDelay() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get TCP NO_DELAY flag.
isTcpNoDelay() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get TCP NO_DELAY flag.
isTcpNoDelay() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isTcpNoDelay() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets value for TCP_NODELAY socket option.
isTcpNodelay() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets TCP_NODELAY flag in receiver hub's TCP server.
isTcpNodelay() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Whether to use TCP_NODELAY mode.
isTerminated() - Method in interface org.apache.ignite.mxbean.StripedExecutorMXBean
Note that isTerminated() is never true unless either shutdown() or shutdownNow() was called first.
isTerminated() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
Deprecated.
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
Deprecated.
Returns true if this executor is in the process of terminating after shutdown() or shutdownNow() but has not completely terminated.
isTerminationConditionMet(Chromosome, double, int) - Method in interface org.apache.ignite.ml.genetic.parameter.ITerminateCriteria
 
isTextQuery() - Method in class org.apache.ignite.springdata22.repository.query.IgniteQuery
Returns true if it's Ignite Text query, false otherwise.
isThinClientEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether access through thin client is enabled.
isTimedOut() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isTraceEnabled() - Method in interface org.apache.ignite.IgniteLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.EchoingLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.NullLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether trace level is enabled.
isTracing() - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
isTransactionAware() - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
isTxSerializableEnabled() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
isUnique() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns boolean value which indicates whether this index is unique or not.
isUpdateable(GmmModel) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
isUpdateable(KMeansModel) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
isUpdateable(BaggedModel) - Method in class org.apache.ignite.ml.composition.bagging.BaggedTrainer
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(M) and DatasetTrainer.updateModel(M, org.apache.ignite.ml.dataset.DatasetBuilder<K, V>, org.apache.ignite.ml.preprocessing.Preprocessor<K, V>) in this class we explicitly override update method.
isUpdateable(ModelsComposition) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
isUpdateable(IgniteModel<I, List<O>>) - Method in class org.apache.ignite.ml.composition.combinators.parallel.TrainersParallelComposition
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(M) and DatasetTrainer.updateModel(M, org.apache.ignite.ml.dataset.DatasetBuilder<K, V>, org.apache.ignite.ml.preprocessing.Preprocessor<K, V>) in this class we explicitly override update method.
isUpdateable(ModelsSequentialComposition<I, O1, O2>) - Method in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(M) and DatasetTrainer.updateModel(M, org.apache.ignite.ml.dataset.DatasetBuilder<K, V>, org.apache.ignite.ml.preprocessing.Preprocessor<K, V>) in this class we explicitly override update method.
isUpdateable(StackedModel<IS, IA, O, AM>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(M) and DatasetTrainer.updateModel(M, org.apache.ignite.ml.dataset.DatasetBuilder<K, V>, org.apache.ignite.ml.preprocessing.Preprocessor<K, V>) in this class we explicitly override update method.
isUpdateable(ANNClassificationModel) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
isUpdateable(M) - Method in class org.apache.ignite.ml.knn.KNNTrainer
isUpdateable(MultiClassModel<M>) - Method in class org.apache.ignite.ml.multiclass.OneVsRestTrainer
isUpdateable(DiscreteNaiveBayesModel) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
isUpdateable(GaussianNaiveBayesModel) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
isUpdateable(MultilayerPerceptron) - Method in class org.apache.ignite.ml.nn.MLPTrainer
isUpdateable(LinearRegressionModel) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionLSQRTrainer
isUpdateable(LinearRegressionModel) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
isUpdateable(LogisticRegressionModel) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
isUpdateable(SVMLinearClassificationModel) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
isUpdateable(AdaptableDatasetModel<I, O, IW, OW, M>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
isUpdateable(M) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
 
isUpdateable(DecisionTreeNode) - Method in class org.apache.ignite.ml.tree.DecisionTree
isUpdateable(ModelsComposition) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Gets flag indicating whether to use average CPU load vs. current.
isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Gets flag indicating whether to use average job counts vs. current.
isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Gets flag indicating whether to use average execution time vs. current.
isUseIgniteSslContextFactory() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether to use Ignite SSL context factory configured through IgniteConfiguration.getSslContextFactory() if ClientConnectorConfiguration.getSslContextFactory() is not set.
isUseIgniteSslContextFactory() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Gets whether to use Ignite SSL context factory configured through IgniteConfiguration.getSslContextFactory() if DrReceiverConfiguration.getSslContextFactory() is not set.
isUseIgniteSslContextFactory() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Gets whether to use Ignite SSL context factory configured through IgniteConfiguration.getSslContextFactory() if DrSenderConfiguration.getSslContextFactory() is not set.
isUseJtaSynchronization() - Method in class org.apache.ignite.configuration.TransactionConfiguration
 
isUsePairedConnections() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Returns true if TcpCommunicationSpi should maintain connection for outgoing and incoming messages separately.
isUseProcessors() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Gets flag indicating whether to use average CPU load vs. current (default is true).
isUserScriptCompleted(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Checks if user script completed and returns result.
isUseWeights() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
isUseWeights() - Method in interface org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpiMBean
Checks whether node weights are considered when doing random load balancing.
isUsingIdx() - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Get the using index structure property instead of using sorting during the learning process.
isUsingIdx() - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Get the using index structure property instead of using sorting during the learning process.
isValidForReading() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether cache topology is valid for read operations.
isValidForReading() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Checks whether cache topology is valid for read operations.
isValidForWriting() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether cache topology is valid for write operations.
isValidForWriting() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Checks whether cache topology is valid for write operations.
isValidSegment() - Method in interface org.apache.ignite.plugin.segmentation.SegmentationResolver
Checks whether segment is valid.
isValidSegment() - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Checks whether segment is valid.
isValidSegment() - Method in class org.gridgain.grid.segmentation.sharedfs.SharedFsSegmentationResolver
Checks whether segment is valid.
isValidSegment() - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Checks whether segment is valid.
isValueBinary() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Checks the value is binary object.
isWaitForSegmentOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets wait for segment on startup flag.
isWalCompactionEnabled() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
isWalEnabled(String) - Method in interface org.apache.ignite.client.ClientCluster
Checks if write-ahead logging is enabled for specified cache.
isWalEnabled(String) - Method in interface org.apache.ignite.IgniteCluster
Checks if write-ahead logging is enabled for specified cache.
isWalHistorySizeParameterUsed() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
If WalHistorySize was set by user will use this parameter for compatibility.
isWeighted() - Method in class org.apache.ignite.ml.knn.ann.KNNModelFormat
Weighted or not.
isWithinTransaction() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Returns true if performing store operation within a transaction, false otherwise.
isWithMdlDescStorage() - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
isWithMdlStorage() - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
isWrapperFor(Class<?>) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
isWriteBehindEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Returns true if write-behind is enabled.
isWriteBehindEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating whether Ignite should use write-behind behaviour for the cache store.
isWriteBehindEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Returns true if write-behind is enabled.
isWriteBehindEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isWriteThrottlingEnabled() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
isWriteThrottlingEnabled() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets flag indicating whether write throttling 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
Deprecated.
Determines if a Cache should operate in "write-through" mode.
isWriteThrough() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isZero(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Tests if given value is considered a zero value.
iter(double, double[]) - Method in class org.apache.ignite.ml.math.isolve.lsqr.AbstractLSQR
Perform LSQR iteration.
iter(double, double[]) - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQROnHeap
Perform LSQR iteration.
iteration() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the current iteration number (zero-based).
IterativeSolverResult - Class in org.apache.ignite.ml.math.isolve
Base class for iterative solver results.
IterativeSolverResult(double[], int) - Constructor for class org.apache.ignite.ml.math.isolve.IterativeSolverResult
Constructs a new instance of iterative solver result.
iterator() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
iterator() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
iterator() - Method in interface org.apache.ignite.client.ClientIgniteSet
Returns an iterator over the elements in this collection.
iterator() - Method in interface org.apache.ignite.IgniteQueue
iterator() - Method in interface org.apache.ignite.IgniteSet
iterator() - Method in class org.apache.ignite.lang.IgniteBiTuple
iterator() - Method in class org.apache.ignite.lang.IgniteUuid
iterator() - Method in class org.apache.ignite.ml.dataset.impl.bootstrapping.BootstrappedDatasetPartition
iterator() - Method in class org.apache.ignite.ml.inference.storage.descriptor.IgniteModelDescriptorStorage
Returns iterator of model descriptors stored in this model descriptor storage.
iterator() - Method in class org.apache.ignite.ml.inference.storage.descriptor.LocalModelDescriptorStorage
Returns iterator of model descriptors stored in this model descriptor storage.
iterator() - Method in interface org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorage
Returns iterator of model descriptors stored in this model descriptor storage.
iterator() - Method in class org.apache.ignite.ml.selection.scoring.cursor.CacheBasedLabelPairCursor
iterator() - Method in class org.apache.ignite.ml.selection.scoring.cursor.LocalLabelPairCursor
iterator(Map<String, Object>) - Method in interface org.apache.ignite.spi.systemview.view.FiltrableSystemView
 
iterator() - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
iterator() - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
iterator() - Method in class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery.QueryCursorWrapper
iterator() - Method in class org.gridgain.grid.persistentstore.snapshot.file.PreviousSnapshotsIterable
iterator(IteratorParametersBuilder, SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.GridGainWalIteratorFactory
 
IteratorParametersBuilder - Class in org.gridgain.grid.persistentstore.snapshot.file.remote.wal
Short version of IgniteWalIteratorFactory.IteratorParametersBuilder.
IteratorParametersBuilder() - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
IteratorWithConcurrentModificationChecker<T> - Class in org.apache.ignite.ml.dataset.impl.cache.util
Iterator wrapper that checks if number of entries in iterator is equal to expected.
IteratorWithConcurrentModificationChecker(Iterator<T>, long, String) - Constructor for class org.apache.ignite.ml.dataset.impl.cache.util.IteratorWithConcurrentModificationChecker
Constructs a new instance of iterator checked wrapper.
ITerminateCriteria - Interface in org.apache.ignite.ml.genetic.parameter
Represents the terminate condition for a genetic algorithm.

J

JaasAuthenticator - Class in org.gridgain.grid.security.jaas
JAAS-based implementation of the authentication.
JaasAuthenticator() - Constructor for class org.gridgain.grid.security.jaas.JaasAuthenticator
 
JaasAuthenticatorMBean - Interface in org.gridgain.grid.security.jaas
Management bean for JaasAuthenticator.
JaasBasicPermissionsProvider - Class in org.gridgain.grid.security.jaas
Basic implementation of JaasPermissionsProvider allows to provide simple mapping from multiple principles to corresponding permission sets.
JaasBasicPermissionsProvider(Map<String, SecurityPermissionSet>) - Constructor for class org.gridgain.grid.security.jaas.JaasBasicPermissionsProvider
Constructor with permission map.
JaasCallbackHandlerFactory - Interface in org.gridgain.grid.security.jaas
Callback handler factory for Jaas login module.
JaasJsonPermissionProvider - Class in org.gridgain.grid.security.jaas
Implementation of JaasPermissionsProvider try to parse principal as JSON permission set.
JaasJsonPermissionProvider() - Constructor for class org.gridgain.grid.security.jaas.JaasJsonPermissionProvider
 
JaasPermissionsProvider - Interface in org.gridgain.grid.security.jaas
Pluggable interface that allows to provide custom logic for converting principle returned from JAAS to the SecurityPermissionSet that will be then assigned to user.
JAR_NAME - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
JavaLogger - Class in org.apache.ignite.logger.java
Logger to use with Java logging.
JavaLogger() - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger.
JavaLogger(boolean) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger.
JavaLogger(Logger) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger with given implementation.
JavaLoggerFileHandler - Class in org.apache.ignite.logger.java
File logging handler which skips all the messages until node ID is set.
JavaLoggerFileHandler() - Constructor for class org.apache.ignite.logger.java.JavaLoggerFileHandler
 
JavaLoggerFormatter - Class in org.apache.ignite.logger.java
Formatter for JUL logger.
JavaLoggerFormatter() - Constructor for class org.apache.ignite.logger.java.JavaLoggerFormatter
 
JavaSerializer - Class in org.apache.ignite.cache.store.cassandra.serializer
Serializer based on standard Java serialization.
JavaSerializer() - Constructor for class org.apache.ignite.cache.store.cassandra.serializer.JavaSerializer
 
JclLogger - Class in org.apache.ignite.logger.jcl
This logger wraps any JCL (Jakarta Commons Logging) loggers.
JclLogger() - Constructor for class org.apache.ignite.logger.jcl.JclLogger
Creates new logger.
JclLogger(Log) - Constructor for class org.apache.ignite.logger.jcl.JclLogger
Creates new logger with given implementation.
JdbcCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.jdbc
This class defines JDBC checkpoint SPI implementation.
JdbcCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
 
JdbcCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.jdbc
Management bean that provides general administrative and configuration information about jdbc checkpoint SPI.
jdbcCompliant() - Method in class org.apache.ignite.IgniteJdbcDriver
jdbcCompliant() - Method in class org.apache.ignite.IgniteJdbcThinDriver
JdbcDialect - Interface in org.apache.ignite.cache.store.jdbc.dialect
Represents a dialect of SQL implemented by a particular RDBMS.
JdbcIpFinderDialect - Interface in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
SQL dialect to use with TcpDiscoveryJdbcIpFinder.
JdbcType - Class in org.apache.ignite.cache.store.jdbc
Description for type that could be stored into database by store.
JdbcType() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcType
Empty constructor (all values are initialized to their defaults).
JdbcType(JdbcType) - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcType
Copy constructor.
JdbcTypeDefaultHasher - Class in org.apache.ignite.cache.store.jdbc
Default implementation of JdbcTypeHasher.
JdbcTypeDefaultHasher() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
 
JdbcTypeField - Class in org.apache.ignite.cache.store.jdbc
Description of how field declared in database and in cache.
JdbcTypeField() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeField
Default constructor.
JdbcTypeField(int, String, Class<?>, String) - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeField
Full constructor.
JdbcTypeField(JdbcTypeField) - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeField
Copy constructor.
JdbcTypeHasher - Interface in org.apache.ignite.cache.store.jdbc
API for implementing custom hashing logic for binary objects on server side.
JdbcTypesDefaultTransformer - Class in org.apache.ignite.cache.store.jdbc
Default implementation of JdbcTypesTransformer.
JdbcTypesDefaultTransformer() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer
 
JdbcTypesTransformer - Interface in org.apache.ignite.cache.store.jdbc
API for implementing custom mapping logic for loaded from store data.
JDK_CLS_NAMES_FILE - Static variable in class org.apache.ignite.marshaller.MarshallerUtils
Jdk class names file.
JDK_INFO_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
JdkMarshaller - Class in org.apache.ignite.marshaller.jdk
Implementation of Marshaller based on JDK serialization mechanism.
JdkMarshaller() - Constructor for class org.apache.ignite.marshaller.jdk.JdkMarshaller
Default constructor.
JdkMarshaller(IgnitePredicate<String>) - Constructor for class org.apache.ignite.marshaller.jdk.JdkMarshaller
 
jdkMarshaller() - Method in interface org.apache.ignite.marshaller.MarshallerContext
Returns JDK marshaller instance.
jdkMarshaller(String) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Create JDK marshaller with provided node name.
JettyServer - Class in org.apache.ignite.mesos.resource
Embedded jetty server.
JettyServer() - Constructor for class org.apache.ignite.mesos.resource.JettyServer
 
jmvOpts() - Method in class org.apache.ignite.mesos.ClusterProperties
 
JmxMetricExporterSpi - Class in org.apache.ignite.spi.metric.jmx
This SPI implementation exports metrics as JMX beans.
JmxMetricExporterSpi() - Constructor for class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
 
JobContextResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeJobContext instance.
JobEvent - Class in org.apache.ignite.events
Grid job event.
JobEvent() - Constructor for class org.apache.ignite.events.JobEvent
No-arg constructor.
JobEvent(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.JobEvent
Creates job event with given parameters.
jobId() - Method in class org.apache.ignite.events.JobEvent
Gets job ID.
jobId(IgniteUuid) - Method in class org.apache.ignite.events.JobEvent
Sets job ID.
jobId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
jobReceiverVersion(IgniteProductVersion) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Sets thread local job receiver node version.
jobReceiverVersion() - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns thread local job receiver node version.
jobSenderVersion(IgniteProductVersion) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Sets thread local job sender node version.
jobSenderVersion() - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns thread local job sender node version.
JobStealingCollisionSpi - Class in org.apache.ignite.spi.collision.jobstealing
Collision SPI that supports job stealing from over-utilized nodes to under-utilized nodes.
JobStealingCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
 
JobStealingCollisionSpiMBean - Interface in org.apache.ignite.spi.collision.jobstealing
Management MBean for job stealing based collision SPI.
JobStealingDisabled - Annotation Type in org.apache.ignite.spi.collision.jobstealing
This annotation disables job stealing if corresponding feature is configured.
JobStealingFailoverSpi - Class in org.apache.ignite.spi.failover.jobstealing
Job stealing failover SPI needs to always be used in conjunction with JobStealingCollisionSpi SPI.
JobStealingFailoverSpi() - Constructor for class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
 
JobStealingFailoverSpiMBean - Interface in org.apache.ignite.spi.failover.jobstealing
Management bean for JobStealingFailoverSpi.
JobStealingRequest - Class in org.apache.ignite.spi.collision.jobstealing
Job stealing request.
JobStealingRequest() - Constructor for class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Required by Externalizable.
JobSubmitter - Class in org.apache.ignite.tensorflow.submitter
Main class of the job submitter application that allows to submit TensorFlow jobs to be run within Ignite cluster.
JobSubmitter() - Constructor for class org.apache.ignite.tensorflow.submitter.JobSubmitter
 
joiningNodeData(Map<Integer, Serializable>) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
joiningNodeData() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
joiningNodeData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData
 
joiningNodeId() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData
 
joiningNodeId() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData
 
joiningNodeId() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
joinTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Join timeout, in milliseconds.
jvmOpts() - Method in class org.apache.ignite.yarn.ClusterProperties
 

K

k - Variable in class org.apache.ignite.ml.knn.ann.KNNModelFormat
Amount of nearest neighbors.
k - Variable in class org.apache.ignite.ml.knn.KNNModel
Number of neighbours.
k - Variable in class org.apache.ignite.ml.knn.KNNTrainer
Number of neighbours.
k - Variable in class org.apache.ignite.ml.knn.NNClassificationModel
Amount of nearest neighbors.
KDTreeSpatialIndex<L> - Class in org.apache.ignite.ml.knn.utils.indices
KD tree based implementation of SpatialIndex.
KDTreeSpatialIndex(List<LabeledVector<L>>, DistanceMeasure) - Constructor for class org.apache.ignite.ml.knn.utils.indices.KDTreeSpatialIndex
Constructs a new instance of KD tree spatial index.
keepBinary() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Creates projection that will operate with binary objects.
keepBinary() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag indicating that objects should be kept in binary format when passed to the stream receiver.
keepBinary(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag indicating that objects should be kept in binary format when passes to the steam receiver.
keepBinary() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
keepBinary() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
key() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Gets wrapped key.
key(K) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Sets wrapped key.
key() - Method in class org.apache.ignite.events.CacheEvent
Gets cache entry associated with event.
key() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry key.
key() - Method in class org.apache.ignite.events.CheckpointEvent
Gets checkpoint key associated with this event.
key(String) - Method in class org.apache.ignite.events.CheckpointEvent
Sets checkpoint key.
key() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
Encryption key.
key() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's key.
key() - Method in interface org.gridgain.grid.cache.dr.CacheDrEntry
Gets entry's key.
KEY_FOR_NULL_VALUES - Static variable in class org.apache.ignite.ml.preprocessing.encoding.EncoderPreprocessor
 
keyAlias() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns alias for key column.
keyAlias() - Method in class org.gridgain.grid.persistentstore.SnapshotPath
 
keyAlias(String) - Method in class org.gridgain.grid.persistentstore.SnapshotPath.SftpSnapshotPathBuilder
Sets key alias for JKS.
keyBinary() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's key as binary object without unmarshaling.
keyColumns() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Gets key columns.
keyKind() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
KeyPersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings for Ignite cache key
KeyPersistenceSettings(Element) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyPersistenceSettings
Creates key persistence settings object based on it's XML configuration.
keysCount() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
keySet() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Set of keys cached on this node.
keySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
KeystoreEncryptionKey - Class in org.apache.ignite.spi.encryption.keystore
EncryptionKey implementation based on java security.
KeystoreEncryptionSpi - Class in org.apache.ignite.spi.encryption.keystore
EncryptionSPI implementation base on JDK provided cipher algorithm implementations.
KeystoreEncryptionSpi() - Constructor for class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
 
keyTransformer() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
 
keyType() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
keyTypeName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns name of key type.
KeyValuePersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings for Ignite cache key and value
KeyValuePersistenceSettings(String) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Constructs Ignite cache key/value persistence settings.
KeyValuePersistenceSettings(File) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Constructs Ignite cache key/value persistence settings.
KeyValuePersistenceSettings(Resource) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings
Constructs Ignite cache key/value persistence settings.
kill(boolean) - Static method in class org.apache.ignite.Ignition
Stops all started grids.
KILL_EXIT_CODE - Static variable in class org.apache.ignite.Ignition
This is kill code that can be used by external tools, like Shell scripts, to auto-stop the Ignite JVM process without restarting.
killNode(ClusterNode) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
kindForName(String, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
kindForName(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
KMeansModel - Class in org.apache.ignite.ml.clustering.kmeans
This class encapsulates result of clusterization by KMeans algorithm.
KMeansModel(Vector[], DistanceMeasure) - Constructor for class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Construct KMeans model with given centers and distanceMeasure measure.
KMeansModelFormat - Class in org.apache.ignite.ml.clustering.kmeans
K-means model representation.
KMeansModelFormat(Vector[], DistanceMeasure) - Constructor for class org.apache.ignite.ml.clustering.kmeans.KMeansModelFormat
 
KMeansTrainer - Class in org.apache.ignite.ml.clustering.kmeans
The trainer for KMeans algorithm.
KMeansTrainer() - Constructor for class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
 
KMeansTrainer.TotalCostAndCounts - Class in org.apache.ignite.ml.clustering.kmeans
Service class used for statistics.
KNNClassificationModel - Class in org.apache.ignite.ml.knn.classification
KNN classification model.
KNNClassificationTrainer - Class in org.apache.ignite.ml.knn.classification
KNN classification model trader that trains model on top of distribtued spatial indices.
KNNClassificationTrainer() - Constructor for class org.apache.ignite.ml.knn.classification.KNNClassificationTrainer
 
KNNModel<L> - Class in org.apache.ignite.ml.knn
KNN model build on top of distribtued spatial indices.
KNNModel(Dataset<EmptyContext, SpatialIndex<L>>, DistanceMeasure, int, boolean) - Constructor for class org.apache.ignite.ml.knn.KNNModel
Constructs a new instance of KNN model.
KNNModelFormat - Class in org.apache.ignite.ml.knn.ann
kNN model representation.
KNNModelFormat() - Constructor for class org.apache.ignite.ml.knn.ann.KNNModelFormat
 
KNNModelFormat(int, DistanceMeasure, boolean) - Constructor for class org.apache.ignite.ml.knn.ann.KNNModelFormat
Creates an instance.
KNNPartitionDataBuilder<K,V> - Class in org.apache.ignite.ml.knn
Partition data builder for KNN algorithms based on SpatialIndex.
KNNPartitionDataBuilder(Preprocessor<K, V>, SpatialIndexType, DistanceMeasure) - Constructor for class org.apache.ignite.ml.knn.KNNPartitionDataBuilder
Constructs a new instance of KNN partition data builder.
KNNRegressionModel - Class in org.apache.ignite.ml.knn.regression
KNN regression model.
KNNRegressionTrainer - Class in org.apache.ignite.ml.knn.regression
KNN regression model trader that trains model on top of distribtued spatial indices.
KNNRegressionTrainer() - Constructor for class org.apache.ignite.ml.knn.regression.KNNRegressionTrainer
 
KNNTrainer<M extends KNNModel<Double>,Self extends KNNTrainer<M,Self>> - Class in org.apache.ignite.ml.knn
KNN model trader that trains model on top of distribtued spatial indices.
KNNTrainer() - Constructor for class org.apache.ignite.ml.knn.KNNTrainer
 
KNNUtils - Class in org.apache.ignite.ml.knn.utils
Helper class for KNNRegression.
KNNUtils() - Constructor for class org.apache.ignite.ml.knn.utils.KNNUtils
 
kNorm(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the k-norm of the vector.
kNorm(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the k-norm of the vector.
kNorm(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the k-norm of the vector.
knownNode(UUID) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
knownNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
knownNode(UUID) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
KryoSerializer - Class in org.apache.ignite.cache.store.cassandra.serializer
Serializer based on Kryo serialization.
KryoSerializer() - Constructor for class org.apache.ignite.cache.store.cassandra.serializer.KryoSerializer
 
KubernetesConnectionConfiguration - Class in org.apache.ignite.kubernetes.configuration
Configuration for Kubernetes connection.
KubernetesConnectionConfiguration() - Constructor for class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 

L

L1 - Static variable in class org.apache.ignite.ml.optimization.LossFunctions
L1 loss function.
L2 - Static variable in class org.apache.ignite.ml.optimization.LossFunctions
L2 loss function.
label(C, K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.DefaultLabelVectorizer
Extract label value by given coordinate.
label(Integer, K, LabeledVector<L>) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.LabeledDummyVectorizer
Extract label value by given coordinate.
label(C, K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Extract label value by given coordinate.
label(C, K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.VectorizerAdapter
Extract label value by given coordinate.
label() - Method in class org.apache.ignite.ml.structures.LabeledVector
Get the label.
label(int) - Method in class org.apache.ignite.ml.structures.LabeledVectorSet
Returns label if label is attached or null if label is missed.
label() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
label() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
 
label() - Method in interface org.apache.ignite.transactions.Transaction
Returns transaction's label.
labeled(C) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Sets label coordinate for Vectorizer.
labeled(Vectorizer.LabelCoordinate) - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Sets label coordinate for Vectorizer.
labeled(L) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates LabeledVector instance.
labeled() - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
 
labeled(IgniteFunction<Vector, Double>) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
 
labeled() - Method in class org.apache.ignite.ml.util.generators.standard.GaussianMixtureDataStream
labeled() - Method in class org.apache.ignite.ml.util.generators.standard.RegressionDataStream
labeled() - Method in class org.apache.ignite.ml.util.generators.standard.RingsDataStream
labeled() - Method in class org.apache.ignite.ml.util.generators.standard.TwoSeparableClassesDataStream
LabeledDatasetLoader - Class in org.apache.ignite.ml.structures.preprocessing
Data pre-processing step which loads data from different file types.
LabeledDatasetLoader() - Constructor for class org.apache.ignite.ml.structures.preprocessing.LabeledDatasetLoader
 
LabeledDatasetPartitionDataBuilderOnHeap<K,V,C extends Serializable> - Class in org.apache.ignite.ml.structures.partition
Partition data builder that builds LabeledVectorSet.
LabeledDatasetPartitionDataBuilderOnHeap(Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.structures.partition.LabeledDatasetPartitionDataBuilderOnHeap
Constructs a new instance of SVM partition data builder.
LabeledDummyVectorizer<K,L> - Class in org.apache.ignite.ml.dataset.feature.extractor.impl
Vectorizer on LabeledVector.
LabeledDummyVectorizer(Integer...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.impl.LabeledDummyVectorizer
Creates an instance of Vectorizer.
LabeledVector<L> - Class in org.apache.ignite.ml.structures
Class for vector with label.
LabeledVector() - Constructor for class org.apache.ignite.ml.structures.LabeledVector
Default constructor.
LabeledVector(Vector, L) - Constructor for class org.apache.ignite.ml.structures.LabeledVector
Construct labeled vector.
LabeledVectorSet<Row extends LabeledVector> - Class in org.apache.ignite.ml.structures
The set of labeled vectors used in local partition calculations.
LabeledVectorSet() - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Default constructor (required by Externalizable).
LabeledVectorSet(int, int, boolean) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new Labeled Dataset and initialized with empty data structure.
LabeledVectorSet(int, int) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new local Labeled Dataset and initialized with empty data structure.
LabeledVectorSet(int, int, String[], boolean) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new Labeled Dataset and initialized with empty data structure.
LabeledVectorSet(Row[]) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new Labeled Dataset by given data.
LabeledVectorSet(Row[], int) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new Labeled Dataset by given data.
LabeledVectorSet(double[][], double[]) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new local Labeled Dataset by matrix and vector of labels.
LabeledVectorSet(double[][], double[], String[], boolean) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSet
Creates new Labeled Dataset by matrix and vector of labels.
LabeledVectorSetTestTrainPair - Class in org.apache.ignite.ml.structures
Class for splitting Labeled Dataset on train and test sets.
LabeledVectorSetTestTrainPair(LabeledVectorSet, double) - Constructor for class org.apache.ignite.ml.structures.LabeledVectorSetTestTrainPair
Creates two subsets of given dataset.
labelInSortedOrder(int, int) - Method in class org.apache.ignite.ml.tree.data.TreeDataIndex
Returns label for kth order statistic for target feature.
LabelPair<L> - Class in org.apache.ignite.ml.selection.scoring
Pair of truth value and predicated by model.
LabelPair(L, L) - Constructor for class org.apache.ignite.ml.selection.scoring.LabelPair
Constructs a new instance of truth with prediction.
LabelPairCursor<L> - Interface in org.apache.ignite.ml.selection.scoring.cursor
Closeable iterable that supplies pairs of truth and predictions (abstraction that hides a difference between querying data from Ignite cache and from local Map).
LabelPartitionDataBuilderOnHeap<K,V,C extends Serializable> - Class in org.apache.ignite.ml.structures.partition
Partition data builder that builds LabelPartitionDataOnHeap.
LabelPartitionDataBuilderOnHeap(Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.structures.partition.LabelPartitionDataBuilderOnHeap
Constructs a new instance of Label partition data builder.
LabelPartitionDataOnHeap - Class in org.apache.ignite.ml.structures.partition
On Heap partition data that keeps part of a labels.
LabelPartitionDataOnHeap(double[]) - Constructor for class org.apache.ignite.ml.structures.partition.LabelPartitionDataOnHeap
Constructs a new instance of linear system partition data.
labels() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer.CentroidStat
 
labels() - Method in class org.apache.ignite.ml.structures.LabeledVectorSet
Returns new copy of labels of all labeled vectors NOTE: This method is useful for copying labels from test dataset.
last() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets result of the last execution of scheduled task, or null if task has not been executed, or has not produced a result yet.
LAST_CLUSTER_STATE_CHANGE_TIME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
lastClusterStateChangeTime() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Gets last cluster state change operation.
lastFinishTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets finish time of last execution (0 if first execution has not finished).
lastIdleTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets last interval between scheduled executions.
lastLocalId() - Static method in class org.apache.ignite.lang.IgniteUuid
Gets last generated local ID.
lastSendTime() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
lastStartTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets latest query start time.
lastStartTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets start time of last execution (0 if never started).
lastStartTime() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
LayerArchitecture - Class in org.apache.ignite.ml.nn.architecture
Layer architecture.
LayerArchitecture(int) - Constructor for class org.apache.ignite.ml.nn.architecture.LayerArchitecture
Construct LayerArchitecture.
layerArchitecture(int) - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Get architecture of layer with given index.
layers - Variable in class org.apache.ignite.ml.nn.MultilayerPerceptron
List containing layers parameters.
layersCount() - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Count of layers in MLP.
layersCount() - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get count of layers in this MLP.
lazy() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
lazy() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
lazy() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets lazy query execution flag.
LBRACK - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
LBRACK - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
LBRACK() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
 
LBRACK() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
LEAF - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
LEAF - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
LEAF() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
 
LeafValuesComputer<T> - Class in org.apache.ignite.ml.tree.randomforest.data.statistics
Class containing logic of leaf values computing after building of all trees in random forest.
LeafValuesComputer() - Constructor for class org.apache.ignite.ml.tree.randomforest.data.statistics.LeafValuesComputer
 
LearningEnvironment - Interface in org.apache.ignite.ml.environment
Specifies a set of utility-objects helpful at runtime but optional for learning algorithm (like thread pool for parallel learning in bagging model or logger).
learningEnvironment(Preprocessor<K, V>) - Method in interface org.apache.ignite.ml.preprocessing.PreprocessingTrainer
Returns local learning environment with initialized deploying context by base preptocessor.
learningEnvironment() - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Get learning environment.
LearningEnvironmentBuilder - Interface in org.apache.ignite.ml.environment
Builder of learning environment.
learnLabels(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBBinaryClassifierTrainer
Defines unique labels in dataset if need (useful in case of classification).
learnLabels(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBRegressionTrainer
Defines unique labels in dataset if need (useful in case of classification).
learnLabels(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Defines unique labels in dataset if need (useful in case of classification).
learnModels(DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Implementation of gradient boosting iterations.
length() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
 
length() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Gets file length.
LG - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns Math.log(a) / Math.log(b).
LIBS_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
 
LICENCE_PATH - Static variable in class org.apache.ignite.yarn.ClusterProperties
 
LICENCE_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
licencePath() - Method in class org.apache.ignite.yarn.ClusterProperties
 
licenceUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
license() - Method in interface org.gridgain.grid.GridProduct
Gets license descriptor for enterprise edition or null for Community Edition.
LicenseEvent - Class in org.gridgain.grid.events
Grid license event.
LicenseEvent() - Constructor for class org.gridgain.grid.events.LicenseEvent
No-arg constructor.
LicenseEvent(ClusterNode, String, int) - Constructor for class org.gridgain.grid.events.LicenseEvent
Creates license event with given parameters.
licenseId() - Method in class org.gridgain.grid.events.LicenseEvent
Gets license ID.
licenseId(UUID) - Method in class org.gridgain.grid.events.LicenseEvent
Sets license ID.
licenseNote() - Method in interface org.gridgain.grid.product.ProductLicense
Gets license note.
licViolInfoHld() - Method in exception org.gridgain.grid.product.ProductLicenseException
 
LIFECYCLE_BEANS_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LifecycleAware - Interface in org.apache.ignite.lifecycle
All components provided in Ignite configuration can implement this interface.
LifecycleBean - Interface in org.apache.ignite.lifecycle
A bean that reacts to node lifecycle events defined in LifecycleEventType.
LifecycleEventType - Enum in org.apache.ignite.lifecycle
Node lifecycle event types.
like(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
Creates new empty matrix of the same underlying class but of different size.
like(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
Creates new empty matrix of the same underlying class but of different size.
like(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.ViewMatrix
Creates new empty matrix of the same underlying class but of different size.
like(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new empty matrix of the same underlying class but of different size.
like(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new empty vector of the same underlying class but of different cardinality.
like(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
Creates new empty vector of the same underlying class but of different cardinality.
like(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
Creates new empty vector of the same underlying class but of different cardinality.
like(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
Creates new empty vector of the same underlying class but of different cardinality.
like(int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
Creates new empty vector of the same underlying class but of different cardinality.
like(int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new empty vector of the same underlying class but of different cardinality.
like(Matrix) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Create the like matrix with read-only matrices support.
like(Matrix, int, int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Create the like matrix with specified size with read-only matrices support.
likeIdentity() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
 
likelihood(Vector) - Method in class org.apache.ignite.ml.math.stat.DistributionMixture
 
likeMatrix(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new matrix of compatible flavor with given size.
likeMatrix(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DenseVector
Creates new matrix of compatible flavor with given size.
likeMatrix(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
Creates new matrix of compatible flavor with given size.
likeMatrix(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
Creates new matrix of compatible flavor with given size.
likeMatrix(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
Creates new matrix of compatible flavor with given size.
likeMatrix(int, int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new matrix of compatible flavor with given size.
likeVector(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.DenseMatrix
Creates new empty vector of compatible properties (similar or the same flavor) to this matrix.
likeVector(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
Creates new empty vector of compatible properties (similar or the same flavor) to this matrix.
likeVector(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.ViewMatrix
Creates new empty vector of compatible properties (similar or the same flavor) to this matrix.
likeVector(int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new empty vector of compatible properties (similar or the same flavor) to this matrix.
likeVector(Matrix, int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Create the like vector with read-only matrices support.
likeVector(Matrix) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Create the like vector with read-only matrices support.
limit() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Gets limit to response records count for TextQuery.
LINE_SEPARATOR - Static variable in class org.apache.ignite.cache.store.cassandra.common.SystemHelper
System line separator.
LINEAR - Static variable in class org.apache.ignite.ml.nn.Activators
Linear unit activation function.
linearOutput - Variable in class org.apache.ignite.ml.nn.MLPState
Output of linear transformations.
linearOutput(int) - Method in class org.apache.ignite.ml.nn.MLPState
Output of linear transformation of given layer.
LinearRegressionLSQRTrainer - Class in org.apache.ignite.ml.regressions.linear
Trainer of the linear regression model based on LSQR algorithm.
LinearRegressionLSQRTrainer() - Constructor for class org.apache.ignite.ml.regressions.linear.LinearRegressionLSQRTrainer
 
LinearRegressionModel - Class in org.apache.ignite.ml.regressions.linear
Simple linear regression model which predicts result value Y as a linear combination of input variables: Y = weights * X + intercept.
LinearRegressionModel(Vector, double) - Constructor for class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
 
LinearRegressionSGDTrainer<P extends Serializable> - Class in org.apache.ignite.ml.regressions.linear
Trainer of the linear regression model based on stochastic gradient descent algorithm.
LinearRegressionSGDTrainer(UpdatesStrategy<? super MultilayerPerceptron, P>, int, int, int, long) - Constructor for class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Constructs a new instance of linear regression SGD trainer.
LinearRegressionSGDTrainer(UpdatesStrategy<? super MultilayerPerceptron, P>) - Constructor for class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Constructs a new instance of linear regression SGD trainer.
list() - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Lists all previously created snapshots with basic info.
list(ListSnapshotParams) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Lists all previously created snapshots with basic info.
listen(IgniteInClosure<? super IgniteFuture<V>>) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers listener closure to be asynchronously notified whenever future completes.
listenAsync(IgniteInClosure<? super IgniteFuture<V>>, Executor) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers listener closure to be asynchronously notified whenever future completes.
listenToClusterUserScript(UUID, Consumer<String>, Consumer<String>) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGatewayManager
Listens to TensorFlow cluster user script.
listFiles(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Returns list of files in the specified directory.
listFiles(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Returns list of files in the specified directory.
listRemoteSnapshots(SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Returns all completed snapshots that can be restored.
ListSnapshotParams - Class in org.gridgain.grid.persistentstore
Parameters for list snapshot operation.
ListSnapshotParams() - Constructor for class org.gridgain.grid.persistentstore.ListSnapshotParams
 
listSnapshots(Collection<File>) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
listStateTransfers(String) - Method in interface org.gridgain.grid.GridDr
List all currently active state transfer for the given sender cache.
listStateTransfers() - Method in interface org.gridgain.grid.GridDr
List all currently active state transfers.
load(K) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
load(K) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
load(K) - Method in class org.apache.ignite.cache.store.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
load(P) - Method in interface org.apache.ignite.ml.Exporter
Load model representation object from p.
load(String) - Method in class org.apache.ignite.ml.FileExporter
Load model representation object from p.
load(K) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
LOAD_BALANCING_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
loadAll(Iterable<? extends K>) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
LoadAllWarmUpConfiguration - Class in org.apache.ignite.configuration
"Load All" warm-up configuration that loads data into persistent data region until it reaches DataRegionConfiguration.getMaxSize() with index priority.
LoadAllWarmUpConfiguration() - Constructor for class org.apache.ignite.configuration.LoadAllWarmUpConfiguration
 
LoadBalancerResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeLoadBalancer.
LoadBalancingSpi - Interface in org.apache.ignite.spi.loadbalancing
Load balancing SPI provides the next best balanced node for job execution.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Loads all values from underlying persistent storage.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in interface org.apache.ignite.cache.store.CacheStore
Loads all values from underlying persistent storage.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
Default empty implementation.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
Loads all values from underlying persistent storage.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Loads all values from underlying persistent storage.
loadCache(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
loadCache(IgniteBiInClosure<K, IgniteBiTuple<V, ?>>, Object...) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Loads all values from underlying persistent storage.
loadCacheAsync(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously executes IgniteCache.localLoadCache(IgniteBiPredicate, Object...) on all cache nodes.
LoadCacheCustomQueryWorker<K,V> - Class in org.apache.ignite.cache.store.cassandra.session
Worker for load cache using custom user query.
LoadCacheCustomQueryWorker(CassandraSession, String, PersistenceController, IgniteLogger, IgniteBiInClosure<K, V>) - Constructor for class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
 
LoadCacheCustomQueryWorker(CassandraSession, Statement, PersistenceController, IgniteLogger, IgniteBiInClosure<K, V>) - Constructor for class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
 
loadCacheQuery(String, Iterable<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct load cache query.
loadCacheQuery(String, Iterable<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct load cache query.
loadCacheRangeQuery(boolean, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Construct query for select values in range.
loadCacheRangeQuery(String, Collection<String>, Iterable<String>, boolean, boolean) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct load cache query over specified range.
loadCacheRangeQuery(String, Collection<String>, Iterable<String>, boolean, boolean) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct load cache query over specified range.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
Construct query to get ranges bounds.
loadCheckpoint(String) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Loads job's state previously saved via ComputeTaskSession.saveCheckpoint(String, Object, ComputeTaskSessionScope, long) method from an underlying storage for a given key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Loads checkpoint from storage by its unique key.
loadDataset(MLSandboxDatasets) - Method in class org.apache.ignite.ml.util.SandboxMLCache
Loads dataset as a list of rows.
loadFromTxtFile(Path, String, boolean, boolean) - Static method in class org.apache.ignite.ml.structures.preprocessing.LabeledDatasetLoader
Datafile should keep class labels in the first column.
loadQuery(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Construct query for select values with key count less or equal maxKeysPerStmt
loadQuery(String, Collection<String>, Iterable<String>, int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct load query.
loadQuery(String, Collection<String>, Iterable<String>, int) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct load query.
loadSpringBean(String, String) - Static method in class org.apache.ignite.Ignition
Loads Spring bean by its name from given Spring XML configuration file.
loadSpringBean(URL, String) - Static method in class org.apache.ignite.Ignition
Loads Spring bean by its name from given Spring XML configuration file.
loadSpringBean(InputStream, String) - Static method in class org.apache.ignite.Ignition
Loads Spring bean by its name from given Spring XML configuration file.
LOC_NODE_ID_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
locAddr - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local address.
local() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
local() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
local() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
local() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
local() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets whether this query should be executed on local node only.
localActiveTransactions() - Method in interface org.apache.ignite.IgniteTransactions
Returns a list of active transactions initiated by this node.
localAddress() - Method in class org.apache.ignite.client.events.ConnectionDescription
Gets local address of this connection.
localAddress() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
localClear(K) - Method in interface org.apache.ignite.IgniteCache
Clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
localClearAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
localCopyOf(Vector) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
TODO: IGNITE-5723, rewrite in a more optimal way.
LocalDataset<C extends Serializable,D extends AutoCloseable> - Class in org.apache.ignite.ml.dataset.impl.local
An implementation of dataset based on local data structures such as Map and List and doesn't require Ignite environment.
LocalDatasetBuilder<K,V> - Class in org.apache.ignite.ml.dataset.impl.local
A dataset builder that makes LocalDataset.
LocalDatasetBuilder(Map<K, V>, int) - Constructor for class org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder
Constructs a new instance of local dataset builder that makes LocalDataset with default predicate that passes all upstream entries to dataset.
LocalDatasetBuilder(Map<K, V>, IgniteBiPredicate<K, V>, int, UpstreamTransformerBuilder) - Constructor for class org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder
Constructs a new instance of local dataset builder that makes LocalDataset.
LocalDatasetBuilder(Map<K, V>, IgniteBiPredicate<K, V>, int) - Constructor for class org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder
Constructs a new instance of local dataset builder that makes LocalDataset.
LocalDeploymentSpi - Class in org.apache.ignite.spi.deployment.local
Local deployment SPI that implements only within VM deployment on local node via LocalDeploymentSpi.register(ClassLoader, Class) method.
LocalDeploymentSpi() - Constructor for class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
 
LocalDeploymentSpiMBean - Interface in org.apache.ignite.spi.deployment.local
Management MBean for LocalDeploymentSpi SPI.
localDeployTask(Class<? extends ComputeTask>, ClassLoader) - Method in interface org.apache.ignite.IgniteCompute
Explicitly deploys a task with given class loader on the local node.
localEntries(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localEntries(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Allows for iteration over local cache entries.
localEntrySize(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Returns approximate number of bytes that required by the given key and corresponding value in the off-heap storage.
localEntrySize(K) - Method in interface org.apache.ignite.IgniteCache
Returns approximate number of bytes that required by the given key and corresponding value in the off-heap storage.
localEvents(IgnitePredicate<T>) - Method in interface org.apache.ignite.spi.eventstorage.EventStorageSpi
Queries locally-stored events only.
localEvents(IgnitePredicate<T>) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Queries locally-stored events only.
localEvents(IgnitePredicate<T>) - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
Queries locally-stored events only.
localEvict(Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Attempts to evict all entries associated with keys.
localId() - Method in class org.apache.ignite.lang.IgniteUuid
Gets local ID portion of this GridUuid.
localIgnite() - Static method in class org.apache.ignite.Ignition
This method is used to address a local Ignite instance, principally from closure.
LocalLabelPairCursor<L,K,V,T> - Class in org.apache.ignite.ml.selection.scoring.cursor
Truth with prediction cursor based on a locally stored data.
LocalLabelPairCursor(Map<K, V>, IgniteBiPredicate<K, V>, Preprocessor<K, V>, IgniteModel<Vector, L>) - Constructor for class org.apache.ignite.ml.selection.scoring.cursor.LocalLabelPairCursor
Constructs a new instance of local truth with prediction cursor.
localListen(IgnitePredicate<? extends Event>, int...) - Method in interface org.apache.ignite.IgniteEvents
Adds an event listener for local events.
localListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Adds local listener for given topic on local node only.
localListener() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
localLoadCache(IgniteBiPredicate, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Delegates to CacheStore.loadCache(IgniteBiInClosure, Object...) method to load state from the underlying persistent storage.
localLoadCache(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
Delegates to CacheStore.loadCache(IgniteBiInClosure,Object...) method to load state from the underlying persistent storage.
localLoadCacheAsync(IgniteBiPredicate, Object...) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously delegates to CacheStore.loadCache(IgniteBiInClosure, Object...) method to reload state from the underlying persistent storage.
localLoadCacheAsync(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously loads state from the underlying persistent storage by delegating to CacheStore.loadCache(IgniteBiInClosure,Object...) method.
localMetrics() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets local metrics (statistics) for this cache.
localMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets local snapshot metrics (statistics) for this cache.
LocalModelDescriptorStorage - Class in org.apache.ignite.ml.inference.storage.descriptor
Model descriptor storage based on local hash map.
LocalModelDescriptorStorage() - Constructor for class org.apache.ignite.ml.inference.storage.descriptor.LocalModelDescriptorStorage
 
LocalModelStorageProvider - Class in org.apache.ignite.ml.inference.storage.model
Implementation of ModelStorageProvider based on local ConcurrentHashMap.
LocalModelStorageProvider() - Constructor for class org.apache.ignite.ml.inference.storage.model.LocalModelStorageProvider
 
localMxBean() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets local metrics (statistics) for this cache.
localMxBean() - Method in interface org.apache.ignite.IgniteCache
Gets local MxBean for this cache.
localNode() - Method in interface org.apache.ignite.IgniteCluster
Gets local grid node.
localNode() - Method in interface org.apache.ignite.plugin.CachePluginContext
Gets local grid node.
localNode() - Method in interface org.apache.ignite.plugin.PluginContext
Gets local grid node.
localNode() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets local grid node.
localNodeId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
localNodeSpecificData() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
localOrder() - Method in interface org.apache.ignite.events.Event
Gets locally unique ID that is atomically incremented for each event.
localOrder() - Method in class org.apache.ignite.events.EventAdapter
Gets locally unique ID that is atomically incremented for each event.
localPeek(Object, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localPeek(K, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Peeks at a value in the local storage using an optional peek mode.
localPreloadPartition(int) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Preloads cache partition if it exists on local node.
localPreloadPartition(int) - Method in interface org.apache.ignite.IgniteCache
Efficiently preloads cache partition into page memory if it exists on the local node.
localQuery(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Queries local node for events using passed-in predicate filter for event selection.
localSender() - Method in interface org.gridgain.grid.GridDr
Gets sender facade for current node.
localSize(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localSize(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node.
localSizeLong(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localSizeLong(int, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
localSizeLong(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node as a long value.
localSizeLong(int, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node for the partition as a long value.
localSnapshots(boolean) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Returns all completed snapshots that can be restored.
localTasks() - Method in interface org.apache.ignite.IgniteCompute
Gets map of all locally deployed tasks keyed by their task name .
localTransformedListener() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
locHost - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local host.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Synchronously acquires lock on a cached object with given key only if the passed in filter (if any) passes.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called during database transaction execution before Hibernate attempts to update or remove given key.
lock(K) - Method in interface org.apache.ignite.IgniteCache
Deprecated.
It is recommended to use Ignite.reentrantLock(String, boolean, boolean, boolean) instead. This method will be removed in future releases.
lock() - Method in interface org.apache.ignite.IgniteLock
Acquires the distributed reentrant lock.
lock(String) - Method in class org.apache.ignite.ml.inference.storage.model.IgniteModelStorageProvider
Locks the specified path.
lock(String) - Method in class org.apache.ignite.ml.inference.storage.model.LocalModelStorageProvider
Locks the specified path.
lock(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorageProvider
Locks the specified path.
LOCK_FILENAME - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Lock filename.
lockAll(Collection, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
All or nothing synchronous lock for passed in keys.
lockAll(Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Deprecated.
It is recommended to use Ignite.reentrantLock(String, boolean, boolean, boolean) instead. This method will be removed in future releases.
lockAllAsync(Collection, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
All or nothing synchronous lock for passed in keys.
lockAsync(Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously acquires lock on a cached object with given key only if the passed in filter (if any) passes.
locked() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
lockId() - Method in class org.apache.ignite.events.CacheEvent
ID of the lock if held or null if no lock held.
lockInterruptibly() - Method in interface org.apache.ignite.IgniteLock
Acquires the lock unless the current thread is interrupted.
lockItem(SessionImplementor, Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
lockItem(SharedSessionContractImplementor, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
lockPaths(Supplier<T>, String...) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Locks paths in model storage and call passed method.
lockPaths(Supplier<T>, String...) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Locks paths in model storage and call passed method.
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.
lockRegion() - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
locNode - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local node.
locNodeAddrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Internal and external addresses of local node.
locNodeAttrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local node attributes.
locNodeVer - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local node version.
locPort - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local port which node uses.
locPortRange - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local port range.
locStepUpdatesReducer() - Method in class org.apache.ignite.ml.nn.UpdatesStrategy
Get function used to reduce updates in one training (for example, sum all sequential gradient updates to get one gradient update).
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(Vector) - Method in class org.apache.ignite.ml.environment.logging.ConsoleLogger
Log vector.
log(MLLogger.VerboseLevel, IgniteModel<K, V>) - Method in class org.apache.ignite.ml.environment.logging.ConsoleLogger
Log model according to toString method.
log(MLLogger.VerboseLevel, String, Object...) - Method in class org.apache.ignite.ml.environment.logging.ConsoleLogger
Log line with formatting.
log(Vector) - Method in class org.apache.ignite.ml.environment.logging.CustomMLLogger
Log vector.
log(MLLogger.VerboseLevel, IgniteModel<K, V>) - Method in class org.apache.ignite.ml.environment.logging.CustomMLLogger
Log model according to toString method.
log(MLLogger.VerboseLevel, String, Object...) - Method in class org.apache.ignite.ml.environment.logging.CustomMLLogger
Log line with formatting.
log(Vector) - Method in interface org.apache.ignite.ml.environment.logging.MLLogger
Log vector.
log(MLLogger.VerboseLevel, IgniteModel<K, V>) - Method in interface org.apache.ignite.ml.environment.logging.MLLogger
Log model according to toString method.
log(MLLogger.VerboseLevel, String, Object...) - Method in interface org.apache.ignite.ml.environment.logging.MLLogger
Log line with formatting.
log(Vector) - Method in class org.apache.ignite.ml.environment.logging.NoOpLogger
Log vector.
log(MLLogger.VerboseLevel, IgniteModel<K, V>) - Method in class org.apache.ignite.ml.environment.logging.NoOpLogger
Log model according to toString method.
log(MLLogger.VerboseLevel, String, Object...) - Method in class org.apache.ignite.ml.environment.logging.NoOpLogger
Log line with formatting.
LOG - Static variable in class org.apache.ignite.ml.optimization.LossFunctions
Log loss function.
log(Class<?>) - Method in interface org.apache.ignite.plugin.CachePluginContext
Gets logger for given class.
log(Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Gets logger for given class.
log - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Logger.
log - Variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Logger.
log - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
 
log - Static variable in class org.apache.ignite.yarn.ApplicationMaster
 
log - Static variable in class org.apache.ignite.yarn.IgniteYarnClient
 
log - Variable in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
 
LOG2 - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns Math.log(a) / Math.log(2).
LOG2 - Static variable in class org.apache.ignite.ml.tree.randomforest.data.FeaturesCountSelectionStrategies
 
Log4J2Logger - Class in org.apache.ignite.logger.log4j2
Log4j2-based implementation for logging.
Log4J2Logger() - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with default implementation.
Log4J2Logger(String) - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with given configuration path.
Log4J2Logger(File) - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with given configuration cfgFile.
Log4J2Logger(URL) - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with given configuration cfgUrl.
Log4jBridgeHandler - Class in org.apache.ignite.logger.log4j2
Bridge from JUL to log4j2.
Log4jBridgeHandler() - Constructor for class org.apache.ignite.logger.log4j2.Log4jBridgeHandler
Default constructor.
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(String, long) - 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(File, long) - 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.
Log4JLogger(URL, long) - 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.
logDirectory(String) - Static method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Resolves logging directory.
LogExporterSpi - Class in org.apache.ignite.spi.metric.log
This SPI implementation exports metrics to Ignite log.
LogExporterSpi() - Constructor for class org.apache.ignite.spi.metric.log.LogExporterSpi
 
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.ml.environment.LearningEnvironment
Returns an instance of logger.
logger(Class<T>) - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Returns an instance of logger for specific class.
LoggerNodeIdAndApplicationAware - Interface in org.apache.ignite.logger
Interface for Ignite file appenders to attach postfix to log file names.
LoggerNodeIdAware - Interface in org.apache.ignite.logger
Deprecated.
LoggerResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of IgniteLogger.
login() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Login provided via subject security credentials.
login() - Method in class org.gridgain.grid.events.AuthenticationEvent
Gets login that triggered event.
login(Object) - Method in class org.gridgain.grid.events.AuthenticationEvent
Sets login that triggered event.
login() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
Login provided via subject security credentials.
LogisticRegressionModel - Class in org.apache.ignite.ml.regressions.logistic
Logistic regression (logit model) is a generalized linear model used for binomial regression.
LogisticRegressionModel(Vector, double) - Constructor for class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
 
LogisticRegressionSGDTrainer - Class in org.apache.ignite.ml.regressions.logistic
Trainer of the logistic regression model based on stochastic gradient descent algorithm.
LogisticRegressionSGDTrainer() - Constructor for class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
 
LogLoss - Class in org.apache.ignite.ml.composition.boosting.loss
Logistic regression loss function.
LogLoss() - Constructor for class org.apache.ignite.ml.composition.boosting.loss.LogLoss
 
logNormalize() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing the log(1 + entry) / L_2 norm values of this vector.
logNormalize(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector with a normalized value calculated as log_power(1 + entry) / L_power norm.
logNormalize() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing the log(1 + entry) / L_2 norm values of this vector.
logNormalize(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector with a normalized value calculated as log_power(1 + entry) / L_power norm.
logNormalize() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing the log(1 + entry) / L_2 norm values of this vector.
logNormalize(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector with a normalized value calculated as log_power(1 + entry) / L_power norm.
LONG_JVM_PAUSE_LAST_EVENTS_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LONG_JVM_PAUSES_CNT_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LONG_JVM_PAUSES_TOTAL_DURATION_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LongMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds long primitive.
LongRunningProcess - Class in org.apache.ignite.tensorflow.core.longrunning
Long running process specification that contains identifier of a node where the process should be running on and the task to be run.
LongRunningProcess(UUID, IgniteRunnable) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcess
Constructs a new instance of long running process specification.
LongRunningProcessClearTask - Class in org.apache.ignite.tensorflow.core.longrunning.task
Task that clears process metadata on the node where the process has run.
LongRunningProcessClearTask(List<UUID>) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessClearTask
Constructs a new instance of clear task.
LongRunningProcessManager - Class in org.apache.ignite.tensorflow.core.longrunning
Long running process manager that allows to start, stop and make other actions with long running processes.
LongRunningProcessManager(Ignite) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcessManager
Constructs a new instance of long running process manager.
LongRunningProcessPingTask - Class in org.apache.ignite.tensorflow.core.longrunning.task
Task that pings processes to check their statuses.
LongRunningProcessPingTask(List<UUID>) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessPingTask
Constructs a new instance of ping task.
LongRunningProcessStartTask - Class in org.apache.ignite.tensorflow.core.longrunning.task
Task that starts long running processes by their specifications.
LongRunningProcessStartTask(List<LongRunningProcess>) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessStartTask
Constructs a new instance of start task.
LongRunningProcessState - Enum in org.apache.ignite.tensorflow.core.longrunning.task.util
Long running process state.
LongRunningProcessStatus - Class in org.apache.ignite.tensorflow.core.longrunning.task.util
Long running process status that includes state and exception if exists.
LongRunningProcessStatus(LongRunningProcessState) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.util.LongRunningProcessStatus
Constructs a new instance of long running process status.
LongRunningProcessStatus(LongRunningProcessState, Exception) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.util.LongRunningProcessStatus
Constructs a new instance of long running process status.
LongRunningProcessStopTask - Class in org.apache.ignite.tensorflow.core.longrunning.task
Task that stops long running processes.
LongRunningProcessStopTask(List<UUID>, boolean) - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessStopTask
Constructs a new instance of stop task.
LongRunningProcessTask<T> - Class in org.apache.ignite.tensorflow.core.longrunning.task
Task that can be executed on a cluster using the LongRunningProcessManager.
LongRunningProcessTask() - Constructor for class org.apache.ignite.tensorflow.core.longrunning.task.LongRunningProcessTask
 
loss - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Loss of gradient.
loss - Variable in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Loss function.
Loss - Interface in org.apache.ignite.ml.composition.boosting.loss
Loss interface of computing error or gradient of error on specific row in dataset.
loss - Variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropUpdateCalculator
Loss function.
loss - Variable in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Loss function.
LossFunctions - Class in org.apache.ignite.ml.optimization
Class containing popular loss functions.
LossFunctions() - Constructor for class org.apache.ignite.ml.optimization.LossFunctions
 
lostPartitions() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
lostPartitions() - Method in interface org.apache.ignite.IgniteCache
Gets a collection of lost partition IDs.
LOW - Static variable in class org.apache.ignite.ml.environment.logging.ConsoleLogger.Factory
Low.
LRUCache<K,V> - Class in org.apache.ignite.ml.util
LRU cache with fixed size and expiration listener.
LRUCache(int) - Constructor for class org.apache.ignite.ml.util.LRUCache
Constructs a new instance of LRU cache.
LRUCache(int, LRUCacheExpirationListener<V>) - Constructor for class org.apache.ignite.ml.util.LRUCache
Constructs a new instance of LRU cache.
LRUCacheExpirationListener<V> - Interface in org.apache.ignite.ml.util
LRU cache expiration listener.
LruEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.lru
Eviction policy based on Least Recently Used (LRU) algorithm and supports batch eviction.
LruEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Constructs LRU eviction policy with all defaults.
LruEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Constructs LRU eviction policy with maximum size.
LruEvictionPolicyFactory<K,V> - Class in org.apache.ignite.cache.eviction.lru
Factory class for LruEvictionPolicy.
LruEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
 
LruEvictionPolicyFactory(int) - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
 
LruEvictionPolicyFactory(int, int, long) - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
 
LruEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.lru
MBean for LRU eviction policy.
lsnr - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Grid discovery listener.
LSQROnHeap<K,V> - Class in org.apache.ignite.ml.math.isolve.lsqr
Distributed implementation of LSQR algorithm based on AbstractLSQR and Dataset.
LSQROnHeap(DatasetBuilder<K, V>, LearningEnvironmentBuilder, PartitionDataBuilder<K, V, LSQRPartitionContext, SimpleLabeledDatasetData>, LearningEnvironment) - Constructor for class org.apache.ignite.ml.math.isolve.lsqr.LSQROnHeap
Constructs a new instance of OnHeap LSQR algorithm implementation.
LSQRPartitionContext - Class in org.apache.ignite.ml.math.isolve.lsqr
Partition context of the LSQR algorithm.
LSQRPartitionContext() - Constructor for class org.apache.ignite.ml.math.isolve.lsqr.LSQRPartitionContext
 
LSQRResult - Class in org.apache.ignite.ml.math.isolve.lsqr
LSQR iterative solver result.
LSQRResult(double[], int, int, double, double, double, double, double, double, double[]) - Constructor for class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
Constructs a new instance of LSQR result.
lt(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Less Than.
LT - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
LT - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
LT() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
lte(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Less Than or Equal To.
LUDecomposition - Class in org.apache.ignite.ml.math.primitives.matrix
Calculates the LU-decomposition of a square matrix.
LUDecomposition(Matrix) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Calculates the LU-decomposition of the given matrix.
LUDecomposition(Matrix, double) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
Calculates the LUP-decomposition of the given matrix.

M

mae() - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues
Returns mean absolute error.
main(String[]) - Static method in class org.apache.ignite.cache.store.cassandra.utils.DDLGenerator
DDLGenerator entry point.
main(String[]) - Static method in class org.apache.ignite.mesos.IgniteFramework
Main methods has only one optional parameter - path to properties files.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
Main method.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineStartup
Main entry point.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
Main method being triggered in step 3 of the Workaround.
main(String...) - Static method in class org.apache.ignite.tensorflow.submitter.JobSubmitter
Main method.
main(String[]) - Static method in class org.apache.ignite.yarn.ApplicationMaster
 
main(String[]) - Static method in class org.apache.ignite.yarn.IgniteYarnClient
Main methods has one mandatory parameter and one optional parameter.
maintenance() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets maintenance version number.
MaintenanceAction<T> - Interface in org.apache.ignite.maintenance
Maintenance action interface enables user to execute operations related to a particular MaintenanceTask.
MaintenanceRegistry - Interface in org.apache.ignite.maintenance
MaintenanceRegistry is a service local to each Ignite node that allows to request performing maintenance actions on that particular node.
MaintenanceTask - Class in org.apache.ignite.maintenance
Represents request to handle maintenance situation.
MaintenanceTask(String, String, String) - Constructor for class org.apache.ignite.maintenance.MaintenanceTask
 
maintenanceTime() - Method in interface org.gridgain.grid.product.ProductLicense
Gets maintenance time in months.
MaintenanceWorkflowCallback - Interface in org.apache.ignite.maintenance
Abstraction to decouple interaction between MaintenanceRegistry and components that may require maintenance.
major() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets major version number.
makeBagged(DatasetTrainer<? extends IgniteModel, L>, int, double, PredictionsAggregator) - Static method in class org.apache.ignite.ml.trainers.TrainerTransformers
Add bagging logic to a given trainer.
makeBagged(DatasetTrainer<M, L>, int, double, int, int, PredictionsAggregator) - Static method in class org.apache.ignite.ml.trainers.TrainerTransformers
Add bagging logic to a given trainer.
makeElement(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
makeInputStream(SnapshotPath, int, int, int, String, boolean) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotInputStreamFactory
 
makeMessageType(byte, byte) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Concatenates the two parameter bytes to form a message type value.
makeOutputStream(FsSnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotOutputStreamFactory
Creates a stream for writing the snapshot file.
makeOutputStream(FsSnapshotPath, Integer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotOutputStreamFactory
Creates opened SnapshotOutputStream.
makePatch(QueryEntity) - Method in class org.apache.ignite.cache.QueryEntity
Make query entity patch.
ManhattanDistance - Class in org.apache.ignite.ml.math.distances
Calculates the L1 (sum of abs) distance between two points.
ManhattanDistance() - Constructor for class org.apache.ignite.ml.math.distances.ManhattanDistance
 
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(Object, Double) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer.Mapping
Add mapping.
map(List<ClusterNode>, List<Long>) - Method in class org.apache.ignite.ml.genetic.CrossOverTask
This method is called to map or split grid task into multiple grid jobs.
map(List<ClusterNode>, List<Long>) - Method in class org.apache.ignite.ml.genetic.FitnessTask
This method is called to map or split grid task into multiple grid jobs.
map(List<ClusterNode>, List<Long>) - Method in class org.apache.ignite.ml.genetic.MutateTask
This method is called to map or split grid task into multiple grid jobs.
map(List<ClusterNode>, LinkedHashMap<Long, Double>) - Method in class org.apache.ignite.ml.genetic.RouletteWheelSelectionTask
 
map(List<ClusterNode>, List<Long>) - Method in class org.apache.ignite.ml.genetic.TruncateSelectionTask
This method is called to map or split grid task into multiple grid jobs.
map(IgniteDoubleFunction<Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Maps all values in this matrix through a given function.
map(Matrix, IgniteBiFunction<Double, Double, Double>) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Maps all values in this matrix through a given function.
map(IgniteDoubleFunction<Double>) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Maps all values in this matrix through a given function.
map(Matrix, IgniteBiFunction<Double, Double, Double>) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Maps all values in this matrix through a given function.
map(IgniteDoubleFunction<Double>) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Maps all values in this vector through a given function.
map(Vector, IgniteBiFunction<Double, Double, Double>) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Maps all values in this vector through a given function.
map(IgniteBiFunction<Double, Double, Double>, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Maps all elements of this vector by applying given function to each element with a constant second parameter y.
map(IgniteDoubleFunction<Double>) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Maps all values in this vector through a given function.
map(Vector, IgniteBiFunction<Double, Double, Double>) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Maps all values in this vector through a given function.
map(IgniteBiFunction<Double, Double, Double>, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Maps all elements of this vector by applying given function to each element with a constant second parameter y.
map(IgniteDoubleFunction<Double>) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Maps all values in this vector through a given function.
map(Vector, IgniteBiFunction<Double, Double, Double>) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Maps all values in this vector through a given function.
map(IgniteBiFunction<Double, Double, Double>, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Maps all elements of this vector by applying given function to each element with a constant second parameter y.
map(IgniteFunction<LabeledVector<L1>, LabeledVector<L2>>) - Method in interface org.apache.ignite.ml.preprocessing.Preprocessor
Map vectorizer answer.
map(K, V) - Method in class org.apache.ignite.ml.selection.split.mapper.SHA256UniformMapper
Maps key-value pair to a point on the segment (0, 1).
map(K, V) - Method in interface org.apache.ignite.ml.selection.split.mapper.UniformMapper
Maps key-value pair to a point on the segment (0, 1).
map(IgniteFunction<Vector, Vector>) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Maps values of vector generator using mapper.
map(IgniteFunction<VectorGenerator, VectorGenerator>) - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.Builder
Adds map function for all generators in family.
mapFeatures(Vector) - Method in interface org.apache.ignite.ml.composition.DatasetMapping
Method used to map feature vectors.
mapFuture() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets future that will be completed when task "map" step has completed (which means that ComputeTask.map(List, Object) method has finished).
mapKeysToNodes(Collection<? extends K>) - Method in interface org.apache.ignite.cache.affinity.Affinity
This method provides ability to detect which keys are mapped to which nodes.
mapKeyToNode(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
This method provides ability to detect to which primary node the given key is mapped.
mapKeyToPrimaryAndBackups(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary and backup nodes for the key.
mapLabels(L1) - Method in interface org.apache.ignite.ml.composition.DatasetMapping
Method used to map labels.
mapPartitionsToNodes(Collection<Integer>) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary nodes for the given partitions.
mapPartitionToNode(int) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary node for the given partition.
mapPartitionToPrimaryAndBackups(int) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary and backup nodes for partition.
MappedPreprocessor<K,V,L0,L1> - Class in org.apache.ignite.ml.preprocessing.developer
Mapped Preprocessor.
MappedPreprocessor(Preprocessor<K, V>, IgniteFunction<LabeledVector<L0>, LabeledVector<L1>>) - Constructor for class org.apache.ignite.ml.preprocessing.developer.MappedPreprocessor
Creates an instance of MappedPreprocessor.
mapper - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Mapper.
Mapping() - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer.Mapping
 
mappingFeatures(IgniteFunction<Vector, Vector>) - Static method in interface org.apache.ignite.ml.composition.DatasetMapping
Dataset mapping which maps features, leaving labels unaffected.
mapToBucket(T) - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
Bucket mapping.
mapToBucket(BootstrappedVector) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.BootstrappedVectorsHistogram
Bucket mapping.
mapToCounter(T) - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
Counter mapping.
mapToCounter(BootstrappedVector) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.CountersHistogram
Counter mapping.
MapUtil - Class in org.apache.ignite.ml.math.util
Some Map related utils.
MapUtil() - Constructor for class org.apache.ignite.ml.math.util.MapUtil
 
mapVectors(IgniteFunction<Vector, Vector>) - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
Apply user defined mapper to vectors stream without labels hiding.
marshal(Object) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to byte array.
marshal(Object, OutputStream) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to the output stream.
marshal(Object, OutputStream) - Method in interface org.apache.ignite.marshaller.Marshaller
Marshals object to the output stream.
marshal(Object) - Method in interface org.apache.ignite.marshaller.Marshaller
Marshals object to byte array.
marshal0(Object, OutputStream) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to the output stream.
marshal0(Object) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to byte array.
marshal0(Object, OutputStream) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Marshals object to the output stream.
marshal0(Object) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Marshals object to byte array.
Marshaller - Interface in org.apache.ignite.marshaller
Marshaller allows to marshal or unmarshal objects in grid.
marshaller() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
MarshallerContext - Interface in org.apache.ignite.marshaller
Marshaller context.
marshallerContext() - Method in interface org.apache.ignite.plugin.PluginContext
 
MarshallerExclusions - Class in org.apache.ignite.marshaller
Controls what classes should be excluded from marshalling by default.
marshallerMappingFileStoreDir(File) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
MarshallerUtils - Class in org.apache.ignite.marshaller
Utility marshaller methods.
masterKeyDigest() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Returns master key digest.
masterKeyDigest(String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Returns master key digest by name.
masterKeyDigest() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Returns master key digest.
masterKeyDigest(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Returns master key digest by name.
masterKeyDigest() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Returns master key digest.
masterKeyDigest(String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Returns master key digest by name.
masterKeyName() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfoEx
Returns a name of master key that is used for encrypting cache's encryption keys or null if there are no encrypted caches in this snapshot.
masterUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
match(SpanStatus) - Static method in class org.apache.ignite.spi.tracing.opencensus.StatusMatchTable
 
matches(ConditionContext, AnnotatedTypeMetadata) - Method in class org.apache.ignite.springdata22.repository.support.ConditionFalse
MathIllegalArgumentException - Exception in org.apache.ignite.ml.math.exceptions
Base class for all preconditions violation exceptions.
MathIllegalArgumentException(String, Object...) - Constructor for exception org.apache.ignite.ml.math.exceptions.MathIllegalArgumentException
 
MathRuntimeException - Exception in org.apache.ignite.ml.math.exceptions
This class is based on the corresponding class from Apache Common Math lib.
MathRuntimeException(String, Object...) - Constructor for exception org.apache.ignite.ml.math.exceptions.MathRuntimeException
 
MathRuntimeException(Throwable, String, Object...) - Constructor for exception org.apache.ignite.ml.math.exceptions.MathRuntimeException
 
Matrix - Interface in org.apache.ignite.ml.math.primitives.matrix
A matrix interface.
Matrix.Element - Interface in org.apache.ignite.ml.math.primitives.matrix
Holder for matrix's element.
MatrixFactorizationGradient<O extends Serializable,S extends Serializable> - Class in org.apache.ignite.ml.recommendation.util
Gradient of matrix factorization loss function.
MatrixFactorizationGradient(Map<O, Vector>, Map<S, Vector>, int) - Constructor for class org.apache.ignite.ml.recommendation.util.MatrixFactorizationGradient
Constructs a new instance of matrix factorization gradient.
MatrixStorage - Interface in org.apache.ignite.ml.math.primitives.matrix
Data storage support for Matrix.
MatrixUtil - Class in org.apache.ignite.ml.math.util
Utility class for various matrix operations.
MatrixUtil() - Constructor for class org.apache.ignite.ml.math.util.MatrixUtil
 
max() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
 
MAX_ABS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns max(abs(a), abs(b)).
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_GENERIC(T, T, Comparator<T>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Generic 'max' function.
MAX_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Max memory page size.
MAX_PARTITIONS_COUNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Maximum number of partitions.
MAX_STEALING_ATTEMPT_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Maximum stealing attempts attribute name.
MAX_TAG_LENGTH - Static variable in interface org.apache.ignite.IgniteCluster
Maximum length of IgniteCluster.tag() tag.
MaxAbsScalerPartitionData - Class in org.apache.ignite.ml.preprocessing.maxabsscaling
Partition data used in maxabsscaling preprocessor.
MaxAbsScalerPartitionData(double[]) - Constructor for class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPartitionData
Constructs a new instance of maxabsscaling partition data.
MaxAbsScalerPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.maxabsscaling
The preprocessing function that makes maxabsscaling, transforms features to the scale [-1,+1].
MaxAbsScalerPreprocessor(double[], Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerPreprocessor
Constructs a new instance of maxabsscaling preprocessor.
MaxAbsScalerTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.maxabsscaling
Trainer of the maxabsscaling preprocessor.
MaxAbsScalerTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.maxabsscaling.MaxAbsScalerTrainer
 
maxComputers() - Method in interface org.gridgain.grid.product.ProductLicense
Gets maximum number of physical computers or virtual instances.
maxConcurrentAsyncOperations() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
maxCpus() - Method in interface org.gridgain.grid.product.ProductLicense
Gets maximum number of CPUs.
maxElement() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the maximum element in this matrix.
maxElement() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the maximum element in this matrix.
maxElement() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets maximum element in this vector.
maxElement() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets maximum element in this vector.
maxElement() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets maximum element in this vector.
maximumTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets maximum execution time of query.
maximumTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets maximum execution time of query.
maxNodes() - Method in interface org.gridgain.grid.product.ProductLicense
Gets maximum number of nodes.
maxParamsCnt - Variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Max query parameters count.
maxPerNodeCnt - Variable in class org.apache.ignite.services.ServiceConfiguration
Max per-node count.
maxPerNodeCount() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets maximum allowed number of deployed services on each node, 0 for unlimited.
maxPerNodeCount() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets maximum allowed number of deployed services on each node, 0 for unlimited.
maxPerNodeCount() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
maxQueryIteratorsCount() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
maxUpTime() - Method in interface org.gridgain.grid.product.ProductLicense
Gets maximum up time in minutes.
maxValue() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the maximum value in this matrix.
maxValue() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the maximum value in this matrix.
maxValue() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets maximum value in this vector.
maxValue() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets maximum value in this vector.
maxValue() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets maximum value in this vector.
MBEAN_SERVER_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
mean() - Method in class org.apache.ignite.ml.clustering.gmm.NewComponentStatisticsAggregator
 
mean() - Method in class org.apache.ignite.ml.dataset.primitive.SimpleDataset
Calculates mean value by all columns.
mean() - Method in class org.apache.ignite.ml.math.stat.MultivariateGaussianDistribution
 
mean() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.MeanValueStatistic
 
mean() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
 
MeanAbsValueConvergenceChecker<K,V> - Class in org.apache.ignite.ml.composition.boosting.convergence.mean
Use mean value of errors for estimating error on dataset.
MeanAbsValueConvergenceChecker(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>, double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.mean.MeanAbsValueConvergenceChecker
Creates an instance of MeanAbsValueConvergenceChecker.
MeanAbsValueConvergenceCheckerFactory - Class in org.apache.ignite.ml.composition.boosting.convergence.mean
MeanAbsValueConvergenceCheckerFactory(double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.mean.MeanAbsValueConvergenceCheckerFactory
 
MeanDecisionTreeLeafBuilder - Class in org.apache.ignite.ml.tree.leaf
Decision tree leaf node builder that chooses mean value as a leaf value.
MeanDecisionTreeLeafBuilder() - Constructor for class org.apache.ignite.ml.tree.leaf.MeanDecisionTreeLeafBuilder
 
meanLbVal - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Mean label value.
MeanValuePredictionsAggregator - Class in org.apache.ignite.ml.composition.predictionsaggregator
Predictions aggregator returning the mean value of predictions.
MeanValuePredictionsAggregator() - Constructor for class org.apache.ignite.ml.composition.predictionsaggregator.MeanValuePredictionsAggregator
 
MeanValueStatistic - Class in org.apache.ignite.ml.tree.randomforest.data.statistics
Statistics for mean value computing container.
MeanValueStatistic(double, long) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.statistics.MeanValueStatistic
Creates an instance of MeanValueStatistic.
MedianOfMedianConvergenceChecker<K,V> - Class in org.apache.ignite.ml.composition.boosting.convergence.median
Use median of median on partitions value of errors for estimating error on dataset.
MedianOfMedianConvergenceChecker(long, IgniteFunction<Double, Double>, Loss, DatasetBuilder<K, V>, Preprocessor<K, V>, double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.median.MedianOfMedianConvergenceChecker
Creates an instance of MedianOfMedianConvergenceChecker.
MedianOfMedianConvergenceCheckerFactory - Class in org.apache.ignite.ml.composition.boosting.convergence.median
MedianOfMedianConvergenceCheckerFactory(double) - Constructor for class org.apache.ignite.ml.composition.boosting.convergence.median.MedianOfMedianConvergenceCheckerFactory
 
MEM - Static variable in class org.apache.ignite.mesos.IgniteScheduler
Mem.
mem - Variable in class org.apache.ignite.mesos.IgniteTask
 
mem() - Method in class org.apache.ignite.mesos.IgniteTask
 
mem - Variable in class org.apache.ignite.yarn.IgniteContainer
 
mem() - Method in class org.apache.ignite.yarn.IgniteContainer
 
memory() - Method in class org.apache.ignite.mesos.ClusterProperties
 
memory(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets mem limit.
MemoryAllocator - Interface in org.apache.ignite.mem
Base interface for offheap memory allocator.
MemoryConfiguration - Class in org.apache.ignite.configuration
Deprecated.
MemoryConfiguration() - Constructor for class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
 
memoryCurrent() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
Returns current size of reserved memory.
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.
memoryMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
Returns maximum size of reserved memory.
memoryMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
Returns maximum size of reserved memory.
memoryMetrics() - Method in interface org.apache.ignite.Ignite
Deprecated.
memoryMetrics(String) - Method in interface org.apache.ignite.Ignite
Deprecated.
memoryMetrics() - Method in class org.apache.ignite.IgniteSpringBean
memoryMetrics(String) - Method in class org.apache.ignite.IgniteSpringBean
MemoryMetrics - Interface in org.apache.ignite
Deprecated.
Use DataRegionMetrics instead.
MemoryMetricsMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Part of old API. Metrics are accessible through DataRegionMetricsMXBean.
memoryMin() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
Returns minimum size of reserved memory.
memoryOverHeadPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
memoryOverHeadPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets memory overhead requested to YARN.
memoryPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
memoryPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets mem limit.
memoryPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
memoryPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets mem limit.
MemoryPolicyConfiguration - Class in org.apache.ignite.configuration
Deprecated.
MemoryPolicyConfiguration() - Constructor for class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
 
memSize - Variable in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Memory size occupied by elements in container.
merge(V, long) - Method in interface org.gridgain.grid.cache.conflict.CacheConflictContext
Force cache to use neither old, nor new, but some other value passed as argument.
mergeLeafStats(ObjectHistogram<BootstrappedVector>, ObjectHistogram<BootstrappedVector>) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.ClassifierLeafValuesComputer
Merge statistics for same leafs.
mergeLeafStats(T, T) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.LeafValuesComputer
Merge statistics for same leafs.
mergeLeafStats(MeanValueStatistic, MeanValueStatistic) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.RegressionLeafValuesComputer
Merge statistics for same leafs.
mergeMaps(M, M, BinaryOperator<V>, Supplier<M>) - Static method in class org.apache.ignite.ml.math.util.MapUtil
 
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
Construct merge query.
MESOS_MASTER_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
 
message() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets optional message for this event.
message() - Method in interface org.apache.ignite.events.Event
Gets optional message for this event.
message(String) - Method in class org.apache.ignite.events.EventAdapter
Sets optional event message.
message() - Method in class org.apache.ignite.events.EventAdapter
Gets optional message for this event.
message() - Method in interface org.apache.ignite.Ignite
Gets messaging facade over all cluster nodes.
message(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets messaging facade over nodes within the cluster group.
message() - Method in class org.apache.ignite.IgniteSpringBean
Gets messaging facade over all cluster nodes.
message(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets messaging facade over nodes within the cluster group.
Message - Interface in org.apache.ignite.plugin.extensions.communication
Base class for all communication messages.
message() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
message() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
message(String) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets additional optional user message that will be printed out to the log and will be saved in snapshot catalog.
message() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
message(String) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets additional user message to log.
message() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
message(String) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets additional user message to log.
message() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
message(String) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets user message.
message() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Optional message associated with the snapshot.
message() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
 
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Full message size (with message type) in bytes.
MessageCollectionItemType - Enum in org.apache.ignite.plugin.extensions.communication
Enum representing possible types of collection items.
MessageDigestFactory - Interface in org.gridgain.grid.persistentstore
A factory of message digest objects.
MessageFactory - Interface in org.apache.ignite.plugin.extensions.communication
Deprecated.
messageFactory() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets message factory.
MessageFactoryProvider - Interface in org.apache.ignite.plugin.extensions.communication
Provider of communication message factories.
MessageFormatter - Interface in org.apache.ignite.plugin.extensions.communication
Provides a custom format for communication messages.
messageFormatter() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets message formatter.
messageQueueSizeBytes() - Method in interface org.gridgain.grid.dr.DrReceiverInMetrics
Deprecated.
Because this is a receiver metric. It doesn't have any relations to per cache, per-DC receiver inputs metrics.
MessageReader - Interface in org.apache.ignite.plugin.extensions.communication
Communication message reader.
messageTemplate(String) - Method in class org.apache.ignite.events.DiscoveryEvent
Template to generate DiscoveryEvent.message() lazily.
MessageWriter - Interface in org.apache.ignite.plugin.extensions.communication
Communication message writer.
MessagingListenActor<T> - Class in org.apache.ignite.messaging
Convenience actor-base adapter for IgniteMessaging.localListen(Object, IgniteBiPredicate) method.
MessagingListenActor() - Constructor for class org.apache.ignite.messaging.MessagingListenActor
 
meta() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Gets metadata added by eviction policy.
meta - Variable in class org.apache.ignite.ml.structures.Dataset
Metadata to identify feature.
meta() - Method in class org.apache.ignite.ml.structures.Dataset
 
MetaAttributes - Interface in org.apache.ignite.ml.math
Interface provides support for meta attributes on vectors and matrices.
METADATA - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Tags metadata.
metadata(SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
 
metadata() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
Getting local metadata and merging it into one for multiple consistentId.
metadata(boolean) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
Prepares and returns a snapshot metadata.
metadata(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
Getting local metadata by consistent id.
methodName() - Method in class org.apache.ignite.events.ServiceEvent
Gets name of service method that triggered this event.
metric - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Metric.
metric - Variable in class org.apache.ignite.ml.selection.scoring.metric.AbstractMetrics
The main metric to get individual score.
Metric<L> - Interface in org.apache.ignite.ml.selection.scoring.metric
Base interface for score calculators.
Metric - Interface in org.apache.ignite.spi.metric
Base interface for all metrics.
MetricExporterSpi - Interface in org.apache.ignite.spi.metric
Exporter of metric information to the external recepient.
metricRegistries() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns all registered metric registries.
metricRegistry() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Metrics registry.
MetricRegistryMBean - Class in org.apache.ignite.spi.metric.jmx
MBean for exporting values of metric registry.
MetricRegistryMBean(ReadOnlyMetricRegistry) - Constructor for class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
 
metrics() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a metrics snapshot for this cluster group.
metrics() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets metrics snapshot for this node.
metrics() - Method in interface org.apache.ignite.IgniteCache
Gets whole cluster snapshot metrics (statistics) for this cache.
metrics(ClusterGroup) - Method in interface org.apache.ignite.IgniteCache
Gets cluster group snapshot metrics for caches in cluster group.
metrics() - Method in interface org.apache.ignite.IgniteTransactions
 
metrics() - Method in interface org.apache.ignite.spi.discovery.DiscoveryMetricsProvider
This method always returns up-to-date metrics data about local node.
metrics() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets metrics snapshot for this node.
metricsFormatted() - Method in interface org.gridgain.grid.dr.DrReceiverMBean
Get metrics (statistics) for this receiver hub.
metricsFormatted() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets metrics (statistics) for this sender hub.
MetricsMxBean - Interface in org.apache.ignite.mxbean
Metrics MXBean interface.
metricsProvider - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Metrics provider.
metricsUpdateFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Metrics update messages issuing frequency.
MetricValues - Interface in org.apache.ignite.ml.selection.scoring.metric
Common interface to present metric values for different ML tasks.
MIN - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns min(a, b).
min() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
 
MIN_ABS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns min(abs(a), abs(b)).
MIN_DELTA_BYTES - Static variable in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
 
MIN_GENERIC(T, T, Comparator<T>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Generic 'min' function.
MIN_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Min memory page size.
minCpuPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
minCpuPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets min cpu count per node.
minElement() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the minimum element in this matrix.
minElement() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the minimum element in this matrix.
minElement() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets minimal element in this vector.
minElement() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets minimal element in this vector.
minElement() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets minimal element in this vector.
minimumTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets minimum execution time of query.
minimumTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets minimum execution time of query.
MinMaxScalerPartitionData - Class in org.apache.ignite.ml.preprocessing.minmaxscaling
Partition data used in minmaxscaling preprocessor.
MinMaxScalerPartitionData(double[], double[]) - Constructor for class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPartitionData
Constructs a new instance of minmaxscaling partition data.
MinMaxScalerPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.minmaxscaling
Preprocessing function that makes minmaxscaling.
MinMaxScalerPreprocessor(double[], double[], Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerPreprocessor
Constructs a new instance of minmaxscaling preprocessor.
MinMaxScalerTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.minmaxscaling
Trainer of the minmaxscaling preprocessor.
MinMaxScalerTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.minmaxscaling.MinMaxScalerTrainer
 
minMemoryPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
 
minMemoryPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
Sets min memory.
minor() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets minor version number.
MINUS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns a - b.
minus(Matrix) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix where each value is a difference between corresponding value of this matrix and passed in argument matrix.
minus(Matrix) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix where each value is a difference between corresponding value of this matrix and passed in argument matrix.
minus(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing element by element difference between this vector and the argument one.
minus(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing element by element difference between this vector and the argument one.
minus(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing element by element difference between this vector and the argument one.
MINUS - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
MINUS - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
MINUS_ABS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns abs(a - b).
MINUS_SQUARED - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns (a - b) * (a - b)
minusMult(double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns a - b*constant.
minValue() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets the minimum value in this matrix.
minValue() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets the minimum value in this matrix.
minValue() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets minimal value in this vector.
minValue() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets minimal value in this vector.
minValue() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets minimal value in this vector.
MISSING - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
MISSING - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
MISSING() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
MISSING_PART_HASH_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotInputStreamFactory
Error message when data or index partition hash is missing in snapshot digest registry.
missRate() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Miss Rate or False Negative Rate (FNR).
mkdir(String, boolean) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Creates directory.
mkdir(String, boolean) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Creates directory.
mkdir(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Creates directory.
mkdirs(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Creates directory and all required parent directories in the path.
mkdirs(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Creates directory and all required parent directories in the path.
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.
MLeapModel - Class in org.apache.ignite.ml.mleap
MLeap model imported and wrapped to be compatible with Apache Ignite infrastructure.
MLeapModel(Transformer, List<String>, String) - Constructor for class org.apache.ignite.ml.mleap.MLeapModel
Constructs a new instance of MLeap model.
MLeapModelParser - Class in org.apache.ignite.ml.mleap
MLeap model parser.
MLeapModelParser() - Constructor for class org.apache.ignite.ml.mleap.MLeapModelParser
 
MLLogger - Interface in org.apache.ignite.ml.environment.logging
Helper for ML-specific objects logging.
MLLogger.Factory - Interface in org.apache.ignite.ml.environment.logging
MLLogger factory interface.
MLLogger.VerboseLevel - Enum in org.apache.ignite.ml.environment.logging
Logging verbose level.
MLPArchitecture - Class in org.apache.ignite.ml.nn.architecture
Class containing information about architecture of MLP.
MLPArchitecture(int) - Constructor for class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Construct an MLP architecture.
MLPInitializer - Interface in org.apache.ignite.ml.nn.initializers
Interface for classes encapsulating logic for initialization of weights and biases of MLP.
MLPLayer - Class in org.apache.ignite.ml.nn
Class containing information about layer.
MLPLayer(Matrix, Vector) - Constructor for class org.apache.ignite.ml.nn.MLPLayer
Construct MLPLayer from weights and biases.
MLPluginConfiguration - Class in org.apache.ignite.ml.util.plugin
Configuration of ML plugin that defines which ML inference services should be start up on Ignite startup.
MLPluginConfiguration() - Constructor for class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
MLPluginProvider - Class in org.apache.ignite.ml.util.plugin
Machine learning inference plugin provider.
MLPluginProvider() - Constructor for class org.apache.ignite.ml.util.plugin.MLPluginProvider
 
MLPState - Class in org.apache.ignite.ml.nn
State of MLP after computation.
MLPState(Matrix) - Constructor for class org.apache.ignite.ml.nn.MLPState
Construct MLP state.
MLPTrainer<P extends Serializable> - Class in org.apache.ignite.ml.nn
Multilayer perceptron trainer based on partition based Dataset.
MLPTrainer(MLPArchitecture, IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>, UpdatesStrategy<? super MultilayerPerceptron, P>, int, int, int, long) - Constructor for class org.apache.ignite.ml.nn.MLPTrainer
Constructs a new instance of multilayer perceptron trainer.
MLPTrainer(IgniteFunction<Dataset<EmptyContext, SimpleLabeledDatasetData>, MLPArchitecture>, IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>, UpdatesStrategy<? super MultilayerPerceptron, P>, int, int, int, long) - Constructor for class org.apache.ignite.ml.nn.MLPTrainer
Constructs a new instance of multilayer perceptron trainer.
MLSandboxDatasets - Enum in org.apache.ignite.ml.util
The names of popular datasets used in examples.
mnistAsList(String, String, Random, int) - Static method in class org.apache.ignite.ml.util.MnistUtils
Read random count samples from MNIST dataset from two files (images and labels) into a stream of labeled vectors.
mnistAsListFromResource(String, String, Random, int) - Static method in class org.apache.ignite.ml.util.MnistUtils
Read random count samples from MNIST dataset from two resources (images and labels) into a stream of labeled vectors.
mnistAsStream(String, String, Random, int) - Static method in class org.apache.ignite.ml.util.MnistUtils
Read random count samples from MNIST dataset from two files (images and labels) into a stream of labeled vectors.
MnistImage(double[]) - Constructor for class org.apache.ignite.ml.util.MnistUtils.MnistImage
Construct a new instance of MNIST image.
MnistLabeledImage(double[], int) - Constructor for class org.apache.ignite.ml.util.MnistUtils.MnistLabeledImage
Constructs a new instance of MNIST labeled image.
MnistUtils - Class in org.apache.ignite.ml.util
Utility class for reading MNIST dataset.
MnistUtils() - Constructor for class org.apache.ignite.ml.util.MnistUtils
 
MnistUtils.MnistImage - Class in org.apache.ignite.ml.util
MNIST image.
MnistUtils.MnistLabeledImage - Class in org.apache.ignite.ml.util
MNIST labeled image.
MOD - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns a % b.
Model<I,O> - Interface in org.apache.ignite.ml.inference
Inference model that can be used to make predictions.
MODEL_DESCRIPTOR_STORAGE_CACHE_NAME - Static variable in class org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorageFactory
Model descriptor storage cache name.
MODEL_STORAGE_CACHE_NAME - Static variable in class org.apache.ignite.ml.inference.storage.model.ModelStorageFactory
Model storage cache name.
ModelDescriptor - Class in org.apache.ignite.ml.inference
Model descriptor that encapsulates information about model, ModelReader and ModelParser which is required to build the model.
ModelDescriptor(String, String, ModelSignature, ModelReader, ModelParser<byte[], byte[], ?>) - Constructor for class org.apache.ignite.ml.inference.ModelDescriptor
Constructs a new instance of model descriptor.
ModelDescriptorStorage - Interface in org.apache.ignite.ml.inference.storage.descriptor
Storage that allows to load, keep and get access to model descriptors (see ModelDescriptor).
ModelDescriptorStorageFactory - Class in org.apache.ignite.ml.inference.storage.descriptor
Model descriptor storage factory.
ModelDescriptorStorageFactory() - Constructor for class org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorageFactory
 
ModelOnFeaturesSubspace - Class in org.apache.ignite.ml.composition
Model trained on a features subspace with mapping from original features space to subspace.
ModelParser<I,O,M extends Model<I,O>> - Interface in org.apache.ignite.ml.inference.parser
Model parser that accepts a serialized model represented by byte array, parses it and returns Model.
ModelReader - Interface in org.apache.ignite.ml.inference.reader
Model reader that reads model from external or internal storage and returns it in serialized form as byte array.
models() - Method in class org.apache.ignite.ml.composition.ModelsCompositionFormat
 
ModelsComposition - Class in org.apache.ignite.ml.composition
Model consisting of several models and prediction aggregation strategy.
ModelsComposition(List<? extends IgniteModel<Vector, Double>>, PredictionsAggregator) - Constructor for class org.apache.ignite.ml.composition.ModelsComposition
Constructs a new instance of composition of models.
ModelsCompositionFormat - Class in org.apache.ignite.ml.composition
ModelsComposition representation.
ModelsCompositionFormat(List<IgniteModel<Vector, Double>>, PredictionsAggregator) - Constructor for class org.apache.ignite.ml.composition.ModelsCompositionFormat
Creates an instance of ModelsCompositionFormat.
ModelSignature - Class in org.apache.ignite.ml.inference
Signature that defines input/output types in Protobuf.
ModelSignature(String, String, String) - Constructor for class org.apache.ignite.ml.inference.ModelSignature
Constructs a new instance of model signature.
ModelsParallelComposition<I,O> - Class in org.apache.ignite.ml.composition.combinators.parallel
Parallel composition of models.
ModelsParallelComposition(List<IgniteModel<I, O>>) - Constructor for class org.apache.ignite.ml.composition.combinators.parallel.ModelsParallelComposition
Construc an instance of this class from list of submodels.
ModelsSequentialComposition<I,O1,O2> - Class in org.apache.ignite.ml.composition.combinators.sequential
Sequential composition of models.
ModelsSequentialComposition(IgniteModel<I, O1>, IgniteModel<O1, O2>) - Constructor for class org.apache.ignite.ml.composition.combinators.sequential.ModelsSequentialComposition
Construct instance of this class from two given models.
ModelStorage - Interface in org.apache.ignite.ml.inference.storage.model
Storage that allows to load, keep and get access to model in byte representation.
ModelStorageFactory - Class in org.apache.ignite.ml.inference.storage.model
Model storage factory.
ModelStorageFactory() - Constructor for class org.apache.ignite.ml.inference.storage.model.ModelStorageFactory
 
ModelStorageModelReader - Class in org.apache.ignite.ml.inference.reader
Model reader that reads directory or file from model storage and serializes it using DirectorySerializer.
ModelStorageModelReader(String, IgniteSupplier<ModelStorage>) - Constructor for class org.apache.ignite.ml.inference.reader.ModelStorageModelReader
Constructs a new instance of model storage inference model builder.
ModelStorageModelReader(String) - Constructor for class org.apache.ignite.ml.inference.reader.ModelStorageModelReader
Constructs a new instance of model storage inference model builder.
ModelStorageProvider - Interface in org.apache.ignite.ml.inference.storage.model
Model storage provider that keeps files and directories presented as FileOrDirectory files and correspondent locks.
ModelStorateThinClientProcessor - Class in org.apache.ignite.ml.inference.storage.model.thinclient
Processor for model storage commands in thin client.
ModelStorateThinClientProcessor(ModelStorage) - Constructor for class org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor
Creates an instance of model storage commands processor.
ModelStorateThinClientProcessor.Method - Enum in org.apache.ignite.ml.inference.storage.model.thinclient
Operations of model storage for GGFS client.
ModelTrace - Class in org.apache.ignite.ml.util
Helper for model tracing.
modeNames - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Mode names.
momentum - Variable in class org.apache.ignite.ml.optimization.updatecalculators.NesterovUpdateCalculator
Momentum constant.
MostCommonDecisionTreeLeafBuilder - Class in org.apache.ignite.ml.tree.leaf
Decision tree leaf node builder that chooses most common value as a leaf node value.
MostCommonDecisionTreeLeafBuilder() - Constructor for class org.apache.ignite.ml.tree.leaf.MostCommonDecisionTreeLeafBuilder
 
move(Vector) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Moves all vectors to other position by summing with input vector.
move(MoveSnapshotParams) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Copy a snapshot with the given ID to the given destination folder and delete snapshot locally.
moveSnapshot(long, File, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
moveSnapshot(long, File, boolean, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
moveSnapshot(long, File, boolean, SnapshotUpdateOperationParameters, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
moveSnapshot(long, File, boolean, SnapshotUpdateOperationParams, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
MoveSnapshotParams - Class in org.gridgain.grid.persistentstore
Parameters for move snapshot operation.
MoveSnapshotParams() - Constructor for class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
MSE - Static variable in class org.apache.ignite.ml.optimization.LossFunctions
Mean squared error loss function.
mse() - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues
Returns mean squared error.
MSEHistogram - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Class contains implementation of splitting point finding algorithm based on MSE metric (see https://en.wikipedia.org/wiki/Mean_squared_error) and represents a set of histograms in according to this metric.
MSEHistogram(int, BucketMeta) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
Creates an instance of MSEHistogram.
MSEHistogramComputer - Class in org.apache.ignite.ml.tree.randomforest.data.impurity
Histogram computer realization for MSE impurity metric.
MSEHistogramComputer() - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogramComputer
 
MSEImpurityMeasure - Class in org.apache.ignite.ml.tree.impurity.mse
Mean squared error (variance) impurity measure which is calculated the following way: \frac{1}{L}\sum_{i=0}^{n}(y_i - \mu)^2.
MSEImpurityMeasure(double, double, long, double, double, long) - Constructor for class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
Constructs a new instance of mean squared error (variance) impurity measure.
MSEImpurityMeasureCalculator - Class in org.apache.ignite.ml.tree.impurity.mse
Meas squared error (variance) impurity measure calculator.
MSEImpurityMeasureCalculator(boolean) - Constructor for class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasureCalculator
Constructs an instance of MSEImpurityMeasureCalculator.
MSG_EXPIRE_TIME_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Stealing request expiration time attribute name.
MULT - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns a * b.
mult(double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns a * b.
MultiClassModel<M extends IgniteModel<Vector,Double>> - Class in org.apache.ignite.ml.multiclass
Base class for multi-classification model for set of classifiers.
MultiClassModel() - Constructor for class org.apache.ignite.ml.multiclass.MultiClassModel
 
MultiLabelDatasetTrainer<M extends IgniteModel> - Class in org.apache.ignite.ml.trainers
Interface for trainers that trains on dataset with multiple label per object.
MultiLabelDatasetTrainer() - Constructor for class org.apache.ignite.ml.trainers.MultiLabelDatasetTrainer
 
MultilayerPerceptron - Class in org.apache.ignite.ml.nn
Class encapsulating logic of multilayer perceptron.
MultilayerPerceptron(MLPArchitecture, MLPInitializer) - Constructor for class org.apache.ignite.ml.nn.MultilayerPerceptron
Construct MLP from given architecture and parameters initializer.
MultilayerPerceptron(MLPArchitecture) - Constructor for class org.apache.ignite.ml.nn.MultilayerPerceptron
Construct MLP from given architecture.
MultilayerPerceptron(MultilayerPerceptron, MultilayerPerceptron) - Constructor for class org.apache.ignite.ml.nn.MultilayerPerceptron
Create MLP from two MLPs: first stacked on second.
MultivariateGaussianDistribution - Class in org.apache.ignite.ml.math.stat
Distribution represents multidimentional gaussian distribution.
MultivariateGaussianDistribution(Vector, Matrix) - Constructor for class org.apache.ignite.ml.math.stat.MultivariateGaussianDistribution
Constructs an instance of MultivariateGaussianDistribution.
MutateJob - Class in org.apache.ignite.ml.genetic
Responsible for applying mutation on respective Chromosome based on mutation Rate
MutateJob(Long, List<Long>, double) - Constructor for class org.apache.ignite.ml.genetic.MutateJob
 
MutateTask - Class in org.apache.ignite.ml.genetic
Responsible for applying mutation on respective chromosomes.
MutateTask(GAConfiguration) - Constructor for class org.apache.ignite.ml.genetic.MutateTask
 
Mutation - Interface in org.apache.ignite.cache.store.cassandra.session.transaction
Provides information about particular mutation operation performed withing transaction.
mxBean() - Method in interface org.apache.ignite.IgniteCache
Gets whole cluster MxBean for this cache.
MXBeanDescription - Annotation Type in org.apache.ignite.mxbean
Provides description for MBean classes and methods.
MXBeanParameter - Annotation Type in org.apache.ignite.mxbean
Provides name and description for MBean method parameter.
MXBeanParametersDescriptions - Annotation Type in org.apache.ignite.mxbean
Deprecated.
Use MXBeanParameter instead.
MXBeanParametersNames - Annotation Type in org.apache.ignite.mxbean
Deprecated.
Use MXBeanParameter instead.
MySQLDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the MySQL database.
MySQLDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
 

N

name() - Method in interface org.apache.ignite.binary.BinaryField
Get field's name.
name() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets name of this cache.
name() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets name of this cache (null for default cache).
name() - Method in interface org.apache.ignite.client.ClientAtomicLong
Name of atomic long.
name() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets set name.
name() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets service name.
name() - Method in interface org.apache.ignite.events.Event
Gets name of this event.
name() - Method in class org.apache.ignite.events.EventAdapter
Gets event type name.
name() - Method in interface org.apache.ignite.Ignite
Gets the name of the Ignite instance.
name() - Method in interface org.apache.ignite.IgniteAtomicLong
Name of atomic long.
name() - Method in interface org.apache.ignite.IgniteAtomicReference
Name of atomic reference.
name() - Method in interface org.apache.ignite.IgniteAtomicSequence
Name of atomic sequence.
name() - Method in interface org.apache.ignite.IgniteAtomicStamped
Name of atomic stamped.
name() - Method in interface org.apache.ignite.IgniteCondition
Name of ignite condition.
name() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets name of the latch.
name() - Method in interface org.apache.ignite.IgniteLock
Name of atomic reentrant lock.
name() - Method in interface org.apache.ignite.IgniteQueue
Gets queue name.
name() - Method in interface org.apache.ignite.IgniteSemaphore
Gets name of the semaphore.
name() - Method in interface org.apache.ignite.IgniteSet
Gets set name.
name() - Method in class org.apache.ignite.IgniteSpringBean
Gets the name of the Ignite instance.
name() - Method in interface org.apache.ignite.maintenance.MaintenanceAction
Mandatory human-readable name of maintenance action.
name() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Accuracy
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Fmeasure
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Precision
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Recall
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Returns the metric's name.
name() - Method in interface org.apache.ignite.ml.selection.scoring.metric.Metric
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetrics
Returns the metric's name.
name() - Method in class org.apache.ignite.ml.structures.FeatureMetadata
 
name() - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
name() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
Deprecated.
Gets name of this cache.
name() - Method in interface org.apache.ignite.plugin.PluginProvider
 
name - Variable in class org.apache.ignite.services.ServiceConfiguration
Service name.
name() - Method in interface org.apache.ignite.services.ServiceContext
Gets service name.
name() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service name.
name() - Method in interface org.apache.ignite.spi.metric.Metric
 
name() - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricRegistry
 
name() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
name() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
name() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
name() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
name() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
name() - Method in class org.apache.ignite.spi.systemview.view.SqlViewView
View name.
name() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
NamedVector - Interface in org.apache.ignite.ml.math.primitives.vector
A named vector interface based on Vector.
NativeProcess - Class in org.apache.ignite.tensorflow.core.nativerunning
Native process specification.
NativeProcess(SerializableSupplier<ProcessBuilder>, String, UUID) - Constructor for class org.apache.ignite.tensorflow.core.nativerunning.NativeProcess
Constructs a new instance of native process specification.
NativeProcessManager - Class in org.apache.ignite.tensorflow.core.nativerunning
Native process manager that allows to start, stop and make other actions with native processes.
NativeProcessManager(Ignite) - Constructor for class org.apache.ignite.tensorflow.core.nativerunning.NativeProcessManager
Constructs a new native process manager.
NativeProcessManager(ProcessManager<LongRunningProcess>) - Constructor for class org.apache.ignite.tensorflow.core.nativerunning.NativeProcessManager
Constructs a new native process manager.
NativeProcessRunner - Class in org.apache.ignite.tensorflow.core.util
Utils class that helps to start native processes.
NativeProcessRunner(ProcessBuilder, String, Consumer<String>, Consumer<String>) - Constructor for class org.apache.ignite.tensorflow.core.util.NativeProcessRunner
Constructs a new instance of native process runner.
NativeProcessStartTask - Class in org.apache.ignite.tensorflow.core.nativerunning.task
Task that starts native process by its specification.
NativeProcessStartTask(NativeProcess) - Constructor for class org.apache.ignite.tensorflow.core.nativerunning.task.NativeProcessStartTask
Constructs a new instance of native process start task.
near() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
NearCacheConfiguration<K,V> - Class in org.apache.ignite.configuration
Client (near) cache configuration.
NearCacheConfiguration() - Constructor for class org.apache.ignite.configuration.NearCacheConfiguration
Empty constructor.
NearCacheConfiguration(NearCacheConfiguration<K, V>) - Constructor for class org.apache.ignite.configuration.NearCacheConfiguration
Creates near cache configuration copying properties from passed in configuration.
nearCacheEvictionPolicyFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
nearCacheStartSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
nearSize() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets size of near cache key set.
NEED_WAIT - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Need wait.
NEGATE - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns -a.
negativeClsLb() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
negativeClsLb() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Get the negative label.
nestedCauses() - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
Gets nested causes for this multi-exception.
NesterovParameterUpdate - Class in org.apache.ignite.ml.optimization.updatecalculators
Data needed for Nesterov parameters updater.
NesterovParameterUpdate(int) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Construct NesterovParameterUpdate.
NesterovParameterUpdate(Vector) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Construct NesterovParameterUpdate.
NesterovUpdateCalculator<M extends SmoothParametrized<M>> - Class in org.apache.ignite.ml.optimization.updatecalculators
Class encapsulating Nesterov algorithm for MLP parameters updateCache.
NesterovUpdateCalculator(double, double) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.NesterovUpdateCalculator
Construct NesterovUpdateCalculator.
netTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Network timeout.
neuronsCount() - Method in class org.apache.ignite.ml.nn.architecture.LayerArchitecture
Get count of neurons in layer.
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.
NewComponentStatisticsAggregator - Class in org.apache.ignite.ml.clustering.gmm
Class for aggregate statistics for finding new mean for GMM.
NewComponentStatisticsAggregator(long, long, Vector) - Constructor for class org.apache.ignite.ml.clustering.gmm.NewComponentStatisticsAggregator
Creates an instance of NewComponentStatisticsAggregator.
NewComponentStatisticsAggregator() - Constructor for class org.apache.ignite.ml.clustering.gmm.NewComponentStatisticsAggregator
Creates an instance of NewComponentStatisticsAggregator.
newCondition() - Method in interface org.apache.ignite.IgniteLock
This method is not supported in IgniteLock, Any invocation of this method will result in UnsupportedOperationException.
newEntry() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictContext
Gets new cache entry.
newId() - Method in class org.apache.ignite.events.ClusterIdUpdatedEvent
Value of cluster ID after update request that triggered this event.
newInstance() - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
Creates an instance of ObjectHistogram from child class.
newInstance() - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.basic.CountersHistogram
Creates an instance of ObjectHistogram from child class.
newInstance(AuthenticationContext) - Method in interface org.gridgain.grid.security.jaas.JaasCallbackHandlerFactory
Create new authentication callbacks handler.
newJoinerDiscoveryData(int) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
NEWLINE - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
NEWLINE - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
NEWLINE() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
NEWLINE(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
newTag() - Method in class org.apache.ignite.events.ClusterTagUpdatedEvent
Value of cluster tag after update request that triggered this event.
newThread(Runnable) - Method in class org.apache.ignite.spi.IgniteSpiThreadFactory
newThread(Runnable) - Method in class org.apache.ignite.tensorflow.core.util.CustomizableThreadFactory
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.
next() - Method in class org.apache.ignite.ml.dataset.impl.cache.util.IteratorWithConcurrentModificationChecker
next() - Method in interface org.gridgain.grid.dr.store.DrSenderStoreCursor
Get next entry from that cursor.
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.
nextLocalSnapshot(long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Search for meta of next ascending snapshot, or null if not found.
nextTimeout(long) - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Get next timeout based on previously timeout calculated by strategy.
nextTimeout(long) - Method in interface org.apache.ignite.spi.TimeoutStrategy
Get next timeout based on previously timeout calculated by strategy.
nextTimeout() - Method in interface org.apache.ignite.spi.TimeoutStrategy
Get next timeout.
nextTimeoutChunk(long) - Method in class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Returns a timeout value to use for the next network operation.
nextTimestamp() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
NNClassificationModel - Class in org.apache.ignite.ml.knn
Common methods and fields for all kNN and aNN models to predict label based on neighbours' labels.
NNClassificationModel() - Constructor for class org.apache.ignite.ml.knn.NNClassificationModel
 
NO - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
NO - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
NO() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
NO_PARALLELISM - Static variable in interface org.apache.ignite.ml.environment.parallelism.ParallelismStrategy
No parallelism.
NoDataException - Exception in org.apache.ignite.ml.math.exceptions
This class is based on the corresponding class from Apache Common Math lib.
NoDataException() - Constructor for exception org.apache.ignite.ml.math.exceptions.NoDataException
Construct the exception.
NoDataException(String) - Constructor for exception org.apache.ignite.ml.math.exceptions.NoDataException
Construct the exception with a specific message.
node() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
node(UUID) - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets a node for given ID from this cluster group.
node() - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets first node from the list of nodes in this cluster group.
node(UUID) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a node for given ID from this cluster group.
node() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets first node from the list of nodes in this cluster group.
node() - Method in interface org.apache.ignite.events.Event
Node where event occurred and was recorded
node(ClusterNode) - Method in class org.apache.ignite.events.EventAdapter
Sets node where even is occurred (i.e. node local to the event).
node() - Method in class org.apache.ignite.events.EventAdapter
Node where event occurred and was recorded
node(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a node instance based on its ID.
NODE_ID_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node ID message type.
NODE_ID_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite node id.
NODE_STOPPING - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
NODE_WEIGHT_ATTR_NAME - Static variable in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Name of node attribute used to indicate load weight of a node (value is "ignite.node.weight.attr.name").
nodeAddresses(ClusterNode, boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
nodeAttributes() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets node attributes.
nodeAttributes(Map<String, ?>) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets node attributes.
nodeAttributes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
nodeAuth - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Node authenticator.
nodeCnt() - Method in class org.gridgain.grid.events.DrRemoteDcNodeEvent
Returns count of the available nodes in the remote data center.
nodeFilter - Variable in class org.apache.ignite.services.ServiceConfiguration
Node filter.
nodeFilter() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
nodeFilter(CacheConfiguration<?, ?>) - Static method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
nodeFilter() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
nodeFilter() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
nodeId(UUID, String) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Sets Node id and instantiates FileHandler delegate.
nodeId(String, UUID, String) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Sets Node id and instantiates FileHandler delegate.
NodeId - Class in org.apache.ignite.ml.tree.randomforest.data
Class represents Node id in Random Forest consisting of tree id and node id in tree in according to breadth-first search in tree.
NodeId(int, long) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.NodeId
Create an instance of NodeId.
nodeId() - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeId
 
nodeId() - Method in exception org.apache.ignite.plugin.PluginValidationException
 
nodeId() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
nodeId() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
nodeId() - Method in interface org.apache.ignite.transactions.Transaction
ID of the node on which this transaction started.
nodeId - Variable in class org.apache.ignite.yarn.IgniteContainer
 
nodeId() - Method in class org.apache.ignite.yarn.IgniteContainer
 
nodeId() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets ID of the initiator node.
nodeId() - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
 
nodeIdBytes() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
nodeIdBytesWithType(UUID) - Static method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
NodeIdMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Node ID message.
NodeIdMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
NodeIdMessage(UUID) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
nodeIdsForAttribute(String, String, boolean, boolean) - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get node IDs with the given attribute value.
NodeImpurityHistograms(NodeId) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer.NodeImpurityHistograms
Create an instance of NodeImpurityHistograms.
nodeLocalMap() - Method in interface org.apache.ignite.IgniteCluster
Gets node-local storage instance.
nodeName(String) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Set node name.
nodeOrder() - Method in interface org.apache.ignite.cache.CacheEntryVersion
 
nodeOrder() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
nodes() - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets the read-only collection of nodes in this cluster group.
nodes() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets the read-only collection of nodes in this cluster group.
nodes() - Method in interface org.apache.ignite.plugin.PluginContext
Gets a collection of all grid nodes.
nodes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a collection of all grid nodes.
nodeSpecificData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData
 
nodeSpecificData(Map<UUID, Map<Integer, Serializable>>) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
NodeSplit - Class in org.apache.ignite.ml.tree.randomforest.data
Class represents a split point for decision tree.
NodeSplit(int, double, double, double) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.NodeSplit
Creates an instance of NodeSplit.
noisify(RandomProducer) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Adds noize to all components of generated vectors.
noizify(IgniteFunction<Double, Double>) - Method in interface org.apache.ignite.ml.util.generators.primitives.scalar.RandomProducer
Adds value generated by random producer to function value.
noizify(Vector) - Method in interface org.apache.ignite.ml.util.generators.primitives.scalar.RandomProducer
Adds values generated by random producer to each vector value.
NoLabelVectorException - Exception in org.apache.ignite.ml.math.exceptions.knn
Shows Labeled Dataset index with non-existing Labeled Vector.
NoLabelVectorException(int) - Constructor for exception org.apache.ignite.ml.math.exceptions.knn.NoLabelVectorException
Creates new exception.
NonSquareMatrixException - Exception in org.apache.ignite.ml.math.exceptions
Indicates that given matrix is not a square matrix.
NonSquareMatrixException(int, int) - Constructor for exception org.apache.ignite.ml.math.exceptions.NonSquareMatrixException
Creates new square size violation exception.
nonZeroElements() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets number of non-zero elements in this matrix.
nonZeroElements() - Method in class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
Gets number of non-zero elements in this matrix.
nonZeroElements() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets number of non-zero elements in this matrix.
nonZeroElements() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets number of non-zero elements in this vector.
nonZeroElements() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets number of non-zero elements in this vector.
nonZeroElements() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets number of non-zero elements in this vector.
nonZeroes() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Iterates ove all non-zero elements in this vector.
nonZeroes() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Iterates ove all non-zero elements in this vector.
nonZeroes() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Iterates ove all non-zero elements in this vector.
nonZeroSpliterator() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets spliterator for all non-zero values in this matrix.
nonZeroSpliterator() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets spliterator for all non-zero values in this matrix.
nonZeroSpliterator() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets spliterator for all non-zero values in this vector.
nonZeroSpliterator() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets spliterator for all non-zero values in this vector.
nonZeroSpliterator() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
Gets spliterator for all non-zero values in this vector.
nonZeroSpliterator() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets spliterator for all non-zero values in this vector.
NOOP_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default noop configuration.
NoopCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.noop
No-op implementation of CheckpointSpi.
NoopCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
 
NoopCollisionSpi - Class in org.apache.ignite.spi.collision.noop
No-op implementation of CollisionSpi.
NoopCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
 
NoopEncryptionSpi - Class in org.apache.ignite.spi.encryption.noop
No operation EncryptionSPI implementation.
NoopEncryptionSpi() - Constructor for class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
 
NoopEventStorageSpi - Class in org.apache.ignite.spi.eventstorage
No-op implementation of EventStorageSpi.
NoopEventStorageSpi() - Constructor for class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
 
NoOpFailureHandler - Class in org.apache.ignite.failure
Just ignores any failure.
NoOpFailureHandler() - Constructor for class org.apache.ignite.failure.NoOpFailureHandler
 
NoopIndexingSpi - Class in org.apache.ignite.spi.indexing.noop
Default implementation of IndexingSpi which does not index cache.
NoopIndexingSpi() - Constructor for class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
 
NoOpLogger - Class in org.apache.ignite.ml.environment.logging
MLLogger implementation skipping all logs.
NoOpLogger() - Constructor for class org.apache.ignite.ml.environment.logging.NoOpLogger
 
NoopMetricExporterSpi - Class in org.apache.ignite.spi.metric.noop
No-op implementation of metric exporter SPI.
NoopMetricExporterSpi() - Constructor for class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
 
NoopSpiSpecificSpan - Class in org.apache.ignite.spi.tracing
Noop and null-safe implementation of SpiSpecificSpan.
NoopTracingSpi - Class in org.apache.ignite.spi.tracing
Noop and null-safe implementation of Tracing SPI.
NoopTracingSpi() - Constructor for class org.apache.ignite.spi.tracing.NoopTracingSpi
 
NoOpWarmUpConfiguration - Class in org.apache.ignite.configuration
Noop warm-up configuration.
NoOpWarmUpConfiguration() - Constructor for class org.apache.ignite.configuration.NoOpWarmUpConfiguration
 
NoParallelismStrategy - Class in org.apache.ignite.ml.environment.parallelism
All tasks should be processed in one thread.
NoParallelismStrategy.Stub<T> - Class in org.apache.ignite.ml.environment.parallelism
Stub for Future interface implementation.
NormalDistributionStatistics - Class in org.apache.ignite.ml.tree.randomforest.data.statistics
Aggregator of normal distribution statistics for continual features.
NormalDistributionStatistics(double, double, double, double, long) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
Creates an instance of NormalDistributionStatistics.
NormalDistributionStatisticsComputer - Class in org.apache.ignite.ml.tree.randomforest.data.statistics
Normal distribution parameters computer logic.
NormalDistributionStatisticsComputer() - Constructor for class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatisticsComputer
 
NormalizationPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.normalization
Preprocessing function that makes normalization.
NormalizationPreprocessor(int, Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.normalization.NormalizationPreprocessor
Constructs a new instance of Normalization preprocessor.
NormalizationTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.normalization
Trainer of the Normalization preprocessor.
NormalizationTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.normalization.NormalizationTrainer
 
normalize() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing the normalized (L_2 norm) values of this vector.
normalize(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing the normalized (L_power norm) values of this vector.
normalize() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing the normalized (L_2 norm) values of this vector.
normalize(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing the normalized (L_power norm) values of this vector.
normalize() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing the normalized (L_2 norm) values of this vector.
normalize(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing the normalized (L_power norm) values of this vector.
notCancellable() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
notifyExisting() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
notifyListener(UUID, Message, IgniteRunnable) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
npv() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Negative Predictive Value (NPV).
nullable() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
nullable() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
NullLogger - Class in org.apache.ignite.logger
Logger which does not output anything.
NullLogger() - Constructor for class org.apache.ignite.logger.NullLogger
 
num2Arr(double) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Turn number to 1-sized array.
num2Vec(double) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Wrap specified value into vector.
NUMERIC_TYPES - Static variable in interface org.apache.ignite.cache.store.jdbc.JdbcTypesTransformer
Numeric types.

O

ObjectHistogram<T> - Class in org.apache.ignite.ml.dataset.feature
Basic implementation of Histogram that implements also DistributionComputer.
ObjectHistogram() - Constructor for class org.apache.ignite.ml.dataset.feature.ObjectHistogram
 
ObjectMetric<T> - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds typed value.
ObjectSubjectPair<O extends Serializable,S extends Serializable> - Class in org.apache.ignite.ml.recommendation
Object-subject pair.
ObjectSubjectPair(O, S) - Constructor for class org.apache.ignite.ml.recommendation.ObjectSubjectPair
Constructs a new instance of object-subject pair.
ObjectSubjectRatingTriplet<O extends Serializable,S extends Serializable> - Class in org.apache.ignite.ml.recommendation
Object-subject-rating triplet.
ObjectSubjectRatingTriplet(O, S, Double) - Constructor for class org.apache.ignite.ml.recommendation.ObjectSubjectRatingTriplet
Constructs a new instance of object-subject-rating triplet.
OdbcConfiguration - Class in org.apache.ignite.configuration
Deprecated.
OdbcConfiguration() - Constructor for class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Creates ODBC server configuration with all default values.
OdbcConfiguration(OdbcConfiguration) - Constructor for class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Creates ODBC server configuration by copying all properties from given configuration.
of(List<T>) - Static method in class org.apache.ignite.ml.composition.combinators.parallel.TrainersParallelComposition
Create parallel composition of trainers contained in a given list.
of(double...) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Creates dense local on heap vector based on array of doubles.
of(Double[]) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Creates vector based on array of Doubles.
of(Map<String, Double>) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Creates named vector based on map of keys and values.
of(DatasetTrainer<M, L>) - Static method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Construct instance of this class from a given DatasetTrainer.
of(SnapshotPath, int, int, String, boolean, RecordSerializerFactory) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
 
of(SnapshotPath, int, int, String) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
 
of(File, int, int, String) - Static method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
 
OFF - Static variable in class org.apache.ignite.ml.environment.logging.ConsoleLogger.Factory
Offset.
offer(T) - Method in interface org.apache.ignite.IgniteQueue
offer(T, long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
offerRescinded(SchedulerDriver, Protos.OfferID) - Method in class org.apache.ignite.mesos.IgniteScheduler
offHeapAllocatedSize() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets memory size allocated in off-heap.
offHeapEntriesCount() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets number of cache entries stored in off-heap memory.
offset() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
 
ofSame(List<? extends IgniteModel<I, O>>, IgniteFunction<O, I>) - Static method in class org.apache.ignite.ml.composition.combinators.sequential.ModelsSequentialComposition
Get sequential composition of submodels with same type.
ofSame(DatasetTrainer<? extends IgniteModel<I, O>, L>, IgniteBiFunction<Integer, ? super IgniteModel<I, O>, IgniteFunction<LabeledVector<L>, LabeledVector<L>>>, IgniteBiPredicate<Integer, IgniteModel<I, O>>, IgniteFunction<O, I>) - Static method in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Construct sequential composition of same trainers.
oldEntry() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictContext
Gets old (existing) cache entry.
oldValue() - Method in class org.apache.ignite.events.CacheEvent
Gets old value associated with this event.
oldValue() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry old value (applicable for continuous queries).
oldValueRequired() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
ON_DEFAULT_POOL - Static variable in interface org.apache.ignite.ml.environment.parallelism.ParallelismStrategy
On default pool.
onAckReceived() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Method called when ack message received.
onAfterPut(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called after new value has been stored.
onAfterPut(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called after new value has been stored.
onAfterRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called after value has been removed.
onAfterRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called after value has been removed.
onApplicationEvent(ContextRefreshedEvent) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
onApplicationEvent(ContextRefreshedEvent) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
onAttributeSet(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSessionAttributeListener
Called on attribute change (set or update).
onBeforePut(Cache.Entry<K, V>, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.put(Object, Object) and similar operations before new value is stored in cache.
onBeforePut(Cache.Entry<K, V>, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.put(Object, Object) and similar operations before new value is stored in cache.
onBeforeRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.remove(Object) and similar operations to provide control over returned value.
onBeforeRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.remove(Object) and similar operations to provide control over returned value.
onBeforeStart() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method is called by built-in managers implementation to avoid repeating SPI start attempts.
onCheckpointRemoved(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointListener
Notification for removed checkpoint.
onClientDisconnected(IgniteFuture<?>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Client node disconnected callback.
onClientDisconnected(IgniteFuture<?>) - Method in interface org.apache.ignite.spi.IgniteSpi
Client node disconnected callback.
onClientDisconnected(IgniteFuture<?>) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Client node disconnected callback.
onClientReconnected(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Client node reconnected callback.
onClientReconnected(boolean) - Method in interface org.apache.ignite.spi.IgniteSpi
Client node reconnected callback.
onClientReconnected(boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Client node reconnected callback.
onCollision(CollisionContext) - Method in interface org.apache.ignite.spi.collision.CollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onConnectionClosed(ConnectionClosedEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onContainersAllocated(List<Container>) - Method in class org.apache.ignite.yarn.ApplicationMaster
onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.ignite.yarn.ApplicationMaster
onContextDestroyed() - Method in interface org.apache.ignite.spi.IgniteSpi
Callback invoked prior to stopping grid before SPI context is destroyed.
onContextDestroyed() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Callback invoked prior to stopping grid before SPI context is destroyed.
onContextDestroyed0() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.IgniteSpi
Callback invoked when SPI context is initialized.
onContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Callback invoked when SPI context is initialized.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Method to be called in the end of onContextInitialized method.
onDisconnected(Exception) - Method in interface org.apache.ignite.client.ClientDisconnectListener
Client disconnected callback.
onDisconnected(UUID) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
Callback invoked when connection with remote node is lost.
onDiscovery(int, long, ClusterNode, Collection<ClusterNode>, Map<Long, Collection<ClusterNode>>, DiscoverySpiCustomMessage) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
onDiscovery(DiscoveryNotification) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
Notification for grid node discovery events.
ONE_THIRD - Static variable in class org.apache.ignite.ml.tree.randomforest.data.FeaturesCountSelectionStrategies
 
oneHot(int, int) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Turn number into a local Vector of given size with one-hot encoding.
oneHot(int, int, boolean) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Turn number into Vector of given size with one-hot encoding.
OneHotEncoderPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.encoding.onehotencoder
Preprocessing function that makes one-hot encoding.
OneHotEncoderPreprocessor(Map<String, Integer>[], Preprocessor<K, V>, Set<Integer>) - Constructor for class org.apache.ignite.ml.preprocessing.encoding.onehotencoder.OneHotEncoderPreprocessor
Constructs a new instance of One Hot Encoder preprocessor.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Callback for whenever entry is accessed.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in interface org.apache.ignite.cache.eviction.EvictionPolicy
Callback for whenever entry is accessed.
onEntryProcessorEntered(boolean) - Static method in class org.apache.ignite.thread.IgniteThread
Callback before entry processor execution is started.
onEntryProcessorLeft() - Static method in class org.apache.ignite.thread.IgniteThread
Callback after entry processor execution is finished.
onePhaseCommit() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
onError(Throwable) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method is called in case when method MessagingListenActor.receive(UUID, Object) threw an exception.
onError(Throwable) - Method in class org.apache.ignite.yarn.ApplicationMaster
OneVsRestTrainer<M extends IgniteModel<Vector,Double>> - Class in org.apache.ignite.ml.multiclass
This is a common heuristic trainer for multi-class labeled models.
OneVsRestTrainer(SingleLabelDatasetTrainer<M>) - Constructor for class org.apache.ignite.ml.multiclass.OneVsRestTrainer
 
onExchange(DiscoveryDataBag) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
Notifies discovery manager about data received from remote node.
onExchange(DiscoveryDataPacket, ClassLoader) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
onExternalCollision() - Method in interface org.apache.ignite.spi.collision.CollisionExternalListener
Callback invoked by Collision SPI whenever an external collision event occurs.
onFailure(Ignite, FailureContext) - Method in class org.apache.ignite.failure.AbstractFailureHandler
Handles failure occurred on ignite instance.
onFailure(Ignite, FailureContext) - Method in interface org.apache.ignite.failure.FailureHandler
Handles failure occurred on ignite instance.
onForbidBinaryMetadataRequestSectionEntered() - Static method in class org.apache.ignite.thread.IgniteThread
Callback on entering critical section where binary metadata requests are forbidden.
onForbidBinaryMetadataRequestSectionLeft() - Static method in class org.apache.ignite.thread.IgniteThread
Callback on leaving critical section where binary metadata requests are forbidden.
onGet(K, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.get(Object) and similar operations to provide control over returned value.
onGet(K, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.get(Object) and similar operations to provide control over returned value.
ongoingSnapshotOperation() - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Gets a status of an ongoing grid snapshot operation.
ongoingSnapshotOperationFuture() - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
 
onHandshakeFail(HandshakeFailEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onHandshakeStart(HandshakeStartEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onHandshakeSuccess(HandshakeSuccessEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onHeaderWritten() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called when header of the message is written.
onIgniteStart() - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Callback that notifies that Ignite has successfully started, including all internal components.
onIgniteStart() - Method in interface org.apache.ignite.plugin.CachePluginProvider
Callback that notifies that Ignite has successfully started, including all internal components.
onIgniteStart() - Method in interface org.apache.ignite.plugin.PluginProvider
Callback that notifies that Ignite has successfully started, including all internal components.
onIgniteStop(boolean) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Callback to notify that Ignite is about to stop.
onIgniteStop(boolean) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Callback to notify that Ignite is about to stop.
onIgniteStop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
Callback to notify that Ignite is about to stop.
onLifecycleEvent(LifecycleEventType) - Method in interface org.apache.ignite.lifecycle.LifecycleBean
This method is called when lifecycle event occurs.
onLocalNodeInitialized(ClusterNode) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
Notification of local node initialization.
OnMajorityPredictionsAggregator - Class in org.apache.ignite.ml.composition.predictionsaggregator
Predictions aggregator returning the most frequently prediction.
OnMajorityPredictionsAggregator() - Constructor for class org.apache.ignite.ml.composition.predictionsaggregator.OnMajorityPredictionsAggregator
 
onMasterNodeLeft(ComputeTaskSession) - Method in interface org.apache.ignite.compute.ComputeJobMasterLeaveAware
A method which is executed in case master node has left topology during job execution.
onMessage(UUID, T, IgniteRunnable) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
NOTE: CommunicationSpi should ignore very first 4 bytes received from sender node and pass the rest of the received message to the listener.
onMessageReceived(Message, Object) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collects statistics for message received by SPI.
onMessageSent(Message, Object) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collects statistics for message sent by SPI.
onNodeLeft(Object) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
 
onNodesUpdated(List<NodeReport>) - Method in class org.apache.ignite.yarn.ApplicationMaster
onOverflow() - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Handle overflow.
onPartitionFinished(GroupPartitionId) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
Method invoked on snapshot completion of partition.
onReceive(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
onRequestFail(RequestFailEvent) - Method in interface org.apache.ignite.client.events.RequestEventListener
 
onRequestStart(RequestStartEvent) - Method in interface org.apache.ignite.client.events.RequestEventListener
 
onRequestSuccess(RequestSuccessEvent) - Method in interface org.apache.ignite.client.events.RequestEventListener
 
onSend(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
onSessionEnd(CacheStoreSession, boolean) - Method in interface org.apache.ignite.cache.store.CacheStoreSessionListener
On session end callback.
onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
On session end callback.
onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
On session end callback.
onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
On session end callback.
onSessionStart(CacheStoreSession) - Method in interface org.apache.ignite.cache.store.CacheStoreSessionListener
On session start callback.
onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
On session start callback.
onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
On session start callback.
onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
On session start callback.
onShutdownRequest() - Method in class org.apache.ignite.yarn.ApplicationMaster
onSpiContextDestroyed() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onSpiContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onStateChange(String, IgniteState) - Method in interface org.apache.ignite.IgnitionListener
Listener for grid factory state change notifications.
onTimeout() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
Timeout callback.
onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
Undeployment callback invoked when class loader is being undeployed.
onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Undeployment callback invoked when class loader is being undeployed.
onUnregistered(ClassLoader) - Method in interface org.apache.ignite.spi.deployment.DeploymentListener
Called when a deployment has been unregistered..
onUpdated(Iterable<? extends T>) - Method in interface org.apache.ignite.cache.query.ContinuousQueryWithTransformer.EventListener
Called after one or more entries have been updated.
OomExceptionHandler - Class in org.apache.ignite.thread
OOM exception handler for system threads.
OomExceptionHandler(GridKernalContext) - Constructor for class org.apache.ignite.thread.OomExceptionHandler
 
OpenCensusMetricExporterSpi - Class in org.apache.ignite.spi.metric.opencensus
OpenCensus monitoring exporter.
OpenCensusMetricExporterSpi() - Constructor for class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
 
OpenCensusSpanAdapter - Class in org.apache.ignite.spi.tracing.opencensus
Span implementation based on OpenCensus library.
OpenCensusTraceExporter - Class in org.apache.ignite.spi.tracing.opencensus
Wrapper of OpenCensus trace exporters adopted for Ignite lifecycle.
OpenCensusTraceExporter(SpanExporter.Handler) - Constructor for class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
 
OpenCensusTracingSpi - Class in org.apache.ignite.spi.tracing.opencensus
Tracing SPI implementation based on OpenCensus library.
OpenCensusTracingSpi() - Constructor for class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This constructor is used if environment (JVM) already has OpenCensus tracing.
OpenCensusTracingSpi(SpanExporter.Handler...) - Constructor for class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This constructor is used if environment (JVM) hasn't OpenCensus tracing.
openConnection(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets connection from a pool.
openFileInputStream(String) - Method in class org.apache.ignite.ssl.SslContextFactory
By default, this method simply opens a raw file input stream.
openSocket(InetSocketAddress, IgniteSpiOperationTimeoutHelper) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
openSocket(Socket, InetSocketAddress, IgniteSpiOperationTimeoutHelper) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Connects to remote address sending U.IGNITE_HEADER when connection is established.
operation() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the operation type.
operation() - Method in class org.gridgain.grid.events.AuthorizationEvent
Gets requested operation.
operation(SecurityPermission) - Method in class org.gridgain.grid.events.AuthorizationEvent
Sets requested operation.
operation() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
operationCode() - Method in class org.apache.ignite.client.events.RequestEvent
 
operationId() - Method in interface org.gridgain.grid.persistentstore.SnapshotFuture
Unique id for snapshot operation.
operationId() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
Gets the snapshot operation ID.
operationId() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
operationName() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Display name for the batch operation.
operationName() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchLoaderAssistant
Returns name of the batch load operation.
operationName() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Returns operation name.
operationName() - Method in class org.apache.ignite.client.events.RequestEvent
 
operationType() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
operationType(SnapshotOperationType) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets type.
operationType() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
Gets snapshot operation type.
optionalSearchPaths() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
optionalSearchPaths(Collection<SnapshotPath>) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets optional path to search for snapshots data.
optionalSearchPaths() - Method in class org.gridgain.grid.persistentstore.ListSnapshotParams
 
optionalSearchPaths(Collection<SnapshotPath>) - Method in class org.gridgain.grid.persistentstore.ListSnapshotParams
Sets optional collection of search paths to search for snapshots.
optionalSearchPaths() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
optionalSearchPaths(Collection<SnapshotPath>) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets Optional path to search for snapshots data.
optionalSearchPaths() - Method in class org.gridgain.grid.persistentstore.SnapshotInfoParams
 
optionalSearchPaths(Collection<SnapshotPath>) - Method in class org.gridgain.grid.persistentstore.SnapshotInfoParams
Sets optional collection of search paths to search for snapshots.
options() - Method in class org.apache.ignite.springdata22.repository.query.IgniteQuery
Advanced querying option.
OracleDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the Oracle database.
OracleDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
 
OracleJdbcIpFinderDialect - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Oracle JDBC dialect to use along with TcpDiscoveryJdbcIpFinder.
OracleJdbcIpFinderDialect() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.OracleJdbcIpFinderDialect
 
order() - Method in interface org.apache.ignite.cache.CacheEntryVersion
Order of the update.
order() - Method in interface org.apache.ignite.cluster.ClusterNode
Node order within grid topology.
order() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Node order within grid topology.
order() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's order in initiator data center.
OrderedMatrix - Interface in org.apache.ignite.ml.math.primitives.matrix
Interface for matrix with particular order for storing entities.
org.apache.ignite - package org.apache.ignite
Contains entry-point Ignite & HPC APIs.
org.apache.ignite.binary - package org.apache.ignite.binary
Contains Ignite Binary Objects API classes.
org.apache.ignite.cache - package org.apache.ignite.cache
Contains main Data Grid APIs.
org.apache.ignite.cache.affinity - package org.apache.ignite.cache.affinity
Contains cache node affinity implementations.
org.apache.ignite.cache.affinity.rendezvous - package org.apache.ignite.cache.affinity.rendezvous
Contains HRW-based cache affinity for partitioned cache.
org.apache.ignite.cache.eviction - package org.apache.ignite.cache.eviction
Contains cache eviction policy implementations.
org.apache.ignite.cache.eviction.fifo - package org.apache.ignite.cache.eviction.fifo
Contains cache FIFO eviction policy implementations.
org.apache.ignite.cache.eviction.lru - package org.apache.ignite.cache.eviction.lru
Contains cache LRU eviction policy implementations.
org.apache.ignite.cache.eviction.random - package org.apache.ignite.cache.eviction.random
Contains cache randomized eviction policy implementations.
org.apache.ignite.cache.eviction.sorted - package org.apache.ignite.cache.eviction.sorted
Contains cache sorted eviction policy implementation.
org.apache.ignite.cache.hibernate - package org.apache.ignite.cache.hibernate
Contains implementation of Hibernate L2 cache.
org.apache.ignite.cache.jta - package org.apache.ignite.cache.jta
Contains JTA (Java Transaction API) related public classes and interfaces.
org.apache.ignite.cache.jta.jndi - package org.apache.ignite.cache.jta.jndi
Contains JNDI-based transaction manager lookup.
org.apache.ignite.cache.jta.reflect - package org.apache.ignite.cache.jta.reflect
Contains reflection-based transaction manager lookup.
org.apache.ignite.cache.jta.websphere - package org.apache.ignite.cache.jta.websphere
Contains WebSphere integrations.
org.apache.ignite.cache.query - package org.apache.ignite.cache.query
Contains APIs for creating and executing cache queries.
org.apache.ignite.cache.query.annotations - package org.apache.ignite.cache.query.annotations
Contains query-related annotations.
org.apache.ignite.cache.query.exceptions - package org.apache.ignite.cache.query.exceptions
Contains query-related exceptions.
org.apache.ignite.cache.spring - package org.apache.ignite.cache.spring
Contains implementation of Spring cache abstraction and @Cacheable annotation.
org.apache.ignite.cache.store - package org.apache.ignite.cache.store
Contains cache store interfaces.
org.apache.ignite.cache.store.cassandra - package org.apache.ignite.cache.store.cassandra
Contains CacheStore implementation backed by Cassandra database
org.apache.ignite.cache.store.cassandra.common - package org.apache.ignite.cache.store.cassandra.common
Contains commonly used helper classes
org.apache.ignite.cache.store.cassandra.datasource - package org.apache.ignite.cache.store.cassandra.datasource
Contains data source implementation
org.apache.ignite.cache.store.cassandra.persistence - package org.apache.ignite.cache.store.cassandra.persistence
Contains persistent settings configuration
org.apache.ignite.cache.store.cassandra.serializer - package org.apache.ignite.cache.store.cassandra.serializer
Contains serializers implementation, to store BLOBs into Cassandra
org.apache.ignite.cache.store.cassandra.session - package org.apache.ignite.cache.store.cassandra.session
Contains classes responsible for handling sessions and communication with Cassandra
org.apache.ignite.cache.store.cassandra.session.pool - package org.apache.ignite.cache.store.cassandra.session.pool
Contains session pool implenetation for Cassandra sessions
org.apache.ignite.cache.store.cassandra.session.transaction - package org.apache.ignite.cache.store.cassandra.session.transaction
Contains mutations implementation, to store changes made inside Ignite transaction
org.apache.ignite.cache.store.cassandra.utils - package org.apache.ignite.cache.store.cassandra.utils
Contains utility classes
org.apache.ignite.cache.store.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.store.spring - package org.apache.ignite.cache.store.spring
Contains cache store session listener based on Spring transaction management.
org.apache.ignite.cache.websession - package org.apache.ignite.cache.websession
Contains classes for Web Sessions Caching.
org.apache.ignite.client - package org.apache.ignite.client
Contains Ignite Thin Client API classes.
org.apache.ignite.client.events - package org.apache.ignite.client.events
 
org.apache.ignite.cluster - package org.apache.ignite.cluster
Contains cluster-related classes.
org.apache.ignite.compute - package org.apache.ignite.compute
Contains Compute Grid functionality.
org.apache.ignite.compute.gridify - package org.apache.ignite.compute.gridify
Contains APIs utilized for AOP-based grid-enabling.
org.apache.ignite.compute.gridify.aop - package org.apache.ignite.compute.gridify.aop
Contains common classes for different AOP providers.
org.apache.ignite.compute.gridify.aop.aspectj - package org.apache.ignite.compute.gridify.aop.aspectj
Contains all classes used by AspectJ AOP implementation.
org.apache.ignite.compute.gridify.aop.spring - package org.apache.ignite.compute.gridify.aop.spring
Contains all classes used by Spring AOP implementation.
org.apache.ignite.configuration - package org.apache.ignite.configuration
Contains configuration-related classes.
org.apache.ignite.events - package org.apache.ignite.events
Contains Event Subscription functionality together with various events emitted by Ignite.
org.apache.ignite.failure - package org.apache.ignite.failure
Contains Failure handling public API with standard FailureHandler implementations.
org.apache.ignite.kubernetes.configuration - package org.apache.ignite.kubernetes.configuration
Contains Kubernetes configuration classes.
org.apache.ignite.lang - package org.apache.ignite.lang
Contains general language constructs and functional APIs for distributed computations.
org.apache.ignite.lifecycle - package org.apache.ignite.lifecycle
Contains lifecycle-related classes.
org.apache.ignite.logger - package org.apache.ignite.logger
Contains logging functionality used throughout the system.
org.apache.ignite.logger.java - package org.apache.ignite.logger.java
Contains Java logging implementation for logging.
org.apache.ignite.logger.jcl - package org.apache.ignite.logger.jcl
Contains Jakarta commons logging implementation for logging.
org.apache.ignite.logger.log4j - package org.apache.ignite.logger.log4j
Contains default Log4j implementation for logging.
org.apache.ignite.logger.log4j2 - package org.apache.ignite.logger.log4j2
Contains default Log4j2 implementation for logging.
org.apache.ignite.logger.slf4j - package org.apache.ignite.logger.slf4j
Contains SLF4J implementation for logging.
org.apache.ignite.maintenance - package org.apache.ignite.maintenance
Package contains public interfaces for maintenance mechanism.
org.apache.ignite.marshaller - package org.apache.ignite.marshaller
Contains various supported marshallers.
org.apache.ignite.marshaller.jdk - package org.apache.ignite.marshaller.jdk
Contains JDK java.io based marshaller.
org.apache.ignite.mem - package org.apache.ignite.mem
 
org.apache.ignite.mesos - package org.apache.ignite.mesos
Contains classes to support integration with Apache Mesos.
org.apache.ignite.mesos.resource - package org.apache.ignite.mesos.resource
Contains classes provide access to resources.
org.apache.ignite.messaging - package org.apache.ignite.messaging
Contains Topic-based Messaging functionality.
org.apache.ignite.ml - package org.apache.ignite.ml
Root ML package.
org.apache.ignite.ml.clustering - package org.apache.ignite.ml.clustering
Contains clustering algorithms.
org.apache.ignite.ml.clustering.gmm - package org.apache.ignite.ml.clustering.gmm
Contains Gauss Mixture Model clustering algorithm (see GmmModel).
org.apache.ignite.ml.clustering.kmeans - package org.apache.ignite.ml.clustering.kmeans
Contains kMeans clustering algorithm.
org.apache.ignite.ml.composition - package org.apache.ignite.ml.composition
Contains classes for ensemble of models implementation.
org.apache.ignite.ml.composition.bagging - package org.apache.ignite.ml.composition.bagging
Contains bootstrap aggregation (bagging) trainer allowing to combine some other trainers and return a bagged version of them.
org.apache.ignite.ml.composition.boosting - package org.apache.ignite.ml.composition.boosting
Contains Gradient Boosting regression and classification abstract classes allowing regressor type selecting in child classes.
org.apache.ignite.ml.composition.boosting.convergence - package org.apache.ignite.ml.composition.boosting.convergence
Package contains implementation of convergency checking algorithms for gradient boosting.
org.apache.ignite.ml.composition.boosting.convergence.mean - package org.apache.ignite.ml.composition.boosting.convergence.mean
Contains implementation of convergence checking computer by mean of absolute value of errors in dataset.
org.apache.ignite.ml.composition.boosting.convergence.median - package org.apache.ignite.ml.composition.boosting.convergence.median
Contains implementation of convergence checking computer by median of medians of errors in dataset.
org.apache.ignite.ml.composition.boosting.convergence.simple - package org.apache.ignite.ml.composition.boosting.convergence.simple
Contains implementation of Stub for convergence checking.
org.apache.ignite.ml.composition.boosting.loss - package org.apache.ignite.ml.composition.boosting.loss
Contains loss functions for Gradient Boosting algorithms.
org.apache.ignite.ml.composition.combinators - package org.apache.ignite.ml.composition.combinators
Contains various combinators of trainers and models.
org.apache.ignite.ml.composition.combinators.parallel - package org.apache.ignite.ml.composition.combinators.parallel
Contains parallel combinators of trainers and models.
org.apache.ignite.ml.composition.combinators.sequential - package org.apache.ignite.ml.composition.combinators.sequential
Contains sequential combinators of trainers and models.
org.apache.ignite.ml.composition.predictionsaggregator - package org.apache.ignite.ml.composition.predictionsaggregator
Contains classes for several predictions aggregation strategies working with predictions vector from models ensemble.
org.apache.ignite.ml.composition.stacking - package org.apache.ignite.ml.composition.stacking
Contains classes used for training with stacking technique.
org.apache.ignite.ml.dataset - package org.apache.ignite.ml.dataset
Base package for machine learning dataset classes.
org.apache.ignite.ml.dataset.feature - package org.apache.ignite.ml.dataset.feature
Package for helper classes over features such as ObjectHistogram or FeatureMeta.
org.apache.ignite.ml.dataset.feature.extractor - package org.apache.ignite.ml.dataset.feature.extractor
Package for upstream object vectorizations.
org.apache.ignite.ml.dataset.feature.extractor.impl - package org.apache.ignite.ml.dataset.feature.extractor.impl
Package contains default implementations of Vectorizer.
org.apache.ignite.ml.dataset.impl - package org.apache.ignite.ml.dataset.impl
Base package for implementations of machine learning dataset.
org.apache.ignite.ml.dataset.impl.bootstrapping - package org.apache.ignite.ml.dataset.impl.bootstrapping
Base package for bootstrapped implementation of machine learning dataset.
org.apache.ignite.ml.dataset.impl.cache - package org.apache.ignite.ml.dataset.impl.cache
Base package for cache based implementation of machine learning dataset.
org.apache.ignite.ml.dataset.impl.cache.util - package org.apache.ignite.ml.dataset.impl.cache.util
Contains util classes used in cache based implementation of dataset.
org.apache.ignite.ml.dataset.impl.local - package org.apache.ignite.ml.dataset.impl.local
Base package for local implementation of machine learning dataset.
org.apache.ignite.ml.dataset.primitive - package org.apache.ignite.ml.dataset.primitive
Package that contains basic primitives build on top of Dataset.
org.apache.ignite.ml.dataset.primitive.builder - package org.apache.ignite.ml.dataset.primitive.builder
Base package for partition data and context builders.
org.apache.ignite.ml.dataset.primitive.builder.context - package org.apache.ignite.ml.dataset.primitive.builder.context
Contains partition context builders.
org.apache.ignite.ml.dataset.primitive.builder.data - package org.apache.ignite.ml.dataset.primitive.builder.data
Contains partition data builders.
org.apache.ignite.ml.dataset.primitive.context - package org.apache.ignite.ml.dataset.primitive.context
Contains implementation of partition context.
org.apache.ignite.ml.dataset.primitive.data - package org.apache.ignite.ml.dataset.primitive.data
Contains implementation of partition data.
org.apache.ignite.ml.environment - package org.apache.ignite.ml.environment
Package contains environment utils for ML algorithms.
org.apache.ignite.ml.environment.deploy - package org.apache.ignite.ml.environment.deploy
Package contains user-defined classes deploy support tools.
org.apache.ignite.ml.environment.logging - package org.apache.ignite.ml.environment.logging
Package contains several logging strategy realisations.
org.apache.ignite.ml.environment.parallelism - package org.apache.ignite.ml.environment.parallelism
Package contains realisations of parallelism strategies for multi-thread algorithms.
org.apache.ignite.ml.genetic - package org.apache.ignite.ml.genetic
Root GA package (GA Grid)
org.apache.ignite.ml.genetic.cache - package org.apache.ignite.ml.genetic.cache
Contains cache configurations for GA Grid
org.apache.ignite.ml.genetic.functions - package org.apache.ignite.ml.genetic.functions
Contains functions used for GA Grid
org.apache.ignite.ml.genetic.parameter - package org.apache.ignite.ml.genetic.parameter
Contains parameters used for GA Grid
org.apache.ignite.ml.genetic.utils - package org.apache.ignite.ml.genetic.utils
Contains utils for GA Grid
org.apache.ignite.ml.inference - package org.apache.ignite.ml.inference
Root package for model inference functionality.
org.apache.ignite.ml.inference.builder - package org.apache.ignite.ml.inference.builder
Root package for model inference builders.
org.apache.ignite.ml.inference.parser - package org.apache.ignite.ml.inference.parser
Root package for model inference parsers.
org.apache.ignite.ml.inference.reader - package org.apache.ignite.ml.inference.reader
Root package for model inference readers.
org.apache.ignite.ml.inference.storage - package org.apache.ignite.ml.inference.storage
Root package for inference model storages.
org.apache.ignite.ml.inference.storage.descriptor - package org.apache.ignite.ml.inference.storage.descriptor
Root package for inference model descriptor storages.
org.apache.ignite.ml.inference.storage.model - package org.apache.ignite.ml.inference.storage.model
Root package for inference model storages.
org.apache.ignite.ml.inference.storage.model.thinclient - package org.apache.ignite.ml.inference.storage.model.thinclient
Package contains classes for thin client operations with model storage.
org.apache.ignite.ml.inference.util - package org.apache.ignite.ml.inference.util
Root package for util classes used in org.apache.ignite.ml.inference package.
org.apache.ignite.ml.knn - package org.apache.ignite.ml.knn
Contains main APIs for kNN algorithms.
org.apache.ignite.ml.knn.ann - package org.apache.ignite.ml.knn.ann
Contains main APIs for ANN classification algorithms.
org.apache.ignite.ml.knn.classification - package org.apache.ignite.ml.knn.classification
Contains main APIs for kNN classification algorithms.
org.apache.ignite.ml.knn.regression - package org.apache.ignite.ml.knn.regression
Contains helper classes for kNN regression algorithms.
org.apache.ignite.ml.knn.utils - package org.apache.ignite.ml.knn.utils
Contains util functionality for kNN algorithms.
org.apache.ignite.ml.knn.utils.indices - package org.apache.ignite.ml.knn.utils.indices
Contains utils functionality for indices in kNN algorithms.
org.apache.ignite.ml.math - package org.apache.ignite.ml.math
Contains main APIs for matrix/vector algebra.
org.apache.ignite.ml.math.distances - package org.apache.ignite.ml.math.distances
Contains main APIs for distances.
org.apache.ignite.ml.math.exceptions - package org.apache.ignite.ml.math.exceptions
Contains exceptions for distributed code algebra.
org.apache.ignite.ml.math.exceptions.knn - package org.apache.ignite.ml.math.exceptions.knn
Contains exceptions for kNN algorithms.
org.apache.ignite.ml.math.exceptions.preprocessing - package org.apache.ignite.ml.math.exceptions.preprocessing
Contains exceptions for preprocessing.
org.apache.ignite.ml.math.functions - package org.apache.ignite.ml.math.functions
Contains serializable functions for distributed code algebra.
org.apache.ignite.ml.math.isolve - package org.apache.ignite.ml.math.isolve
Contains iterative algorithms for solving linear systems.
org.apache.ignite.ml.math.isolve.lsqr - package org.apache.ignite.ml.math.isolve.lsqr
Contains LSQR algorithm implementation.
org.apache.ignite.ml.math.primitives - package org.apache.ignite.ml.math.primitives
Contains classes for vector/matrix algebra.
org.apache.ignite.ml.math.primitives.matrix - package org.apache.ignite.ml.math.primitives.matrix
Contains matrix related classes.
org.apache.ignite.ml.math.primitives.matrix.impl - package org.apache.ignite.ml.math.primitives.matrix.impl
Contains several matrix implementations.
org.apache.ignite.ml.math.primitives.matrix.storage - package org.apache.ignite.ml.math.primitives.matrix.storage
Contains several matrix storages.
org.apache.ignite.ml.math.primitives.vector - package org.apache.ignite.ml.math.primitives.vector
Contains vector related classes.
org.apache.ignite.ml.math.primitives.vector.impl - package org.apache.ignite.ml.math.primitives.vector.impl
Contains several vector implementations.
org.apache.ignite.ml.math.primitives.vector.storage - package org.apache.ignite.ml.math.primitives.vector.storage
Contains several vector storages.
org.apache.ignite.ml.math.stat - package org.apache.ignite.ml.math.stat
Contains utility classes for distributions.
org.apache.ignite.ml.math.util - package org.apache.ignite.ml.math.util
Some math utils.
org.apache.ignite.ml.mleap - package org.apache.ignite.ml.mleap
Base package for Mleap model parser.
org.apache.ignite.ml.multiclass - package org.apache.ignite.ml.multiclass
Contains various multi-classifier models and trainers.
org.apache.ignite.ml.naivebayes - package org.apache.ignite.ml.naivebayes
Contains various naive Bayes classifiers.
org.apache.ignite.ml.naivebayes.discrete - package org.apache.ignite.ml.naivebayes.discrete
Contains Bernoulli naive Bayes classifier.
org.apache.ignite.ml.naivebayes.gaussian - package org.apache.ignite.ml.naivebayes.gaussian
Contains Gaussian naive Bayes classifier.
org.apache.ignite.ml.nn - package org.apache.ignite.ml.nn
Contains neural networks and related classes.
org.apache.ignite.ml.nn.architecture - package org.apache.ignite.ml.nn.architecture
Contains multilayer perceptron architecture classes.
org.apache.ignite.ml.nn.initializers - package org.apache.ignite.ml.nn.initializers
Contains multilayer perceptron parameters initializers.
org.apache.ignite.ml.optimization - package org.apache.ignite.ml.optimization
Contains implementations of optimization algorithms and related classes.
org.apache.ignite.ml.optimization.updatecalculators - package org.apache.ignite.ml.optimization.updatecalculators
Contains update calculators.
org.apache.ignite.ml.pipeline - package org.apache.ignite.ml.pipeline
Contains Pipeline API.
org.apache.ignite.ml.preprocessing - package org.apache.ignite.ml.preprocessing
Base package for machine learning preprocessing classes.
org.apache.ignite.ml.preprocessing.binarization - package org.apache.ignite.ml.preprocessing.binarization
Contains binarization preprocessor.
org.apache.ignite.ml.preprocessing.developer - package org.apache.ignite.ml.preprocessing.developer
Contains Developer API preprocessors.
org.apache.ignite.ml.preprocessing.encoding - package org.apache.ignite.ml.preprocessing.encoding
Contains encoding preprocessors.
org.apache.ignite.ml.preprocessing.encoding.onehotencoder - package org.apache.ignite.ml.preprocessing.encoding.onehotencoder
Contains one hot encoding preprocessor.
org.apache.ignite.ml.preprocessing.encoding.stringencoder - package org.apache.ignite.ml.preprocessing.encoding.stringencoder
Contains string encoding preprocessor.
org.apache.ignite.ml.preprocessing.imputing - package org.apache.ignite.ml.preprocessing.imputing
Contains Imputer preprocessor.
org.apache.ignite.ml.preprocessing.maxabsscaling - package org.apache.ignite.ml.preprocessing.maxabsscaling
Contains Max Abs Scaler preprocessor.
org.apache.ignite.ml.preprocessing.minmaxscaling - package org.apache.ignite.ml.preprocessing.minmaxscaling
Contains Min Max Scaler preprocessor.
org.apache.ignite.ml.preprocessing.normalization - package org.apache.ignite.ml.preprocessing.normalization
Contains Normalizer preprocessor.
org.apache.ignite.ml.preprocessing.standardscaling - package org.apache.ignite.ml.preprocessing.standardscaling
Contains Standard scaler preprocessor.
org.apache.ignite.ml.recommendation - package org.apache.ignite.ml.recommendation
Contains recommendation system framework.
org.apache.ignite.ml.recommendation.util - package org.apache.ignite.ml.recommendation.util
Contains util classes used in recommendation system framework.
org.apache.ignite.ml.regressions - package org.apache.ignite.ml.regressions
Contains various regressions.
org.apache.ignite.ml.regressions.linear - package org.apache.ignite.ml.regressions.linear
Contains various linear regressions.
org.apache.ignite.ml.regressions.logistic - package org.apache.ignite.ml.regressions.logistic
Contains various logistic regressions.
org.apache.ignite.ml.selection - package org.apache.ignite.ml.selection
Root package for dataset splitters, cross validation and search through parameters.
org.apache.ignite.ml.selection.cv - package org.apache.ignite.ml.selection.cv
Root package for cross-validation algorithms.
org.apache.ignite.ml.selection.paramgrid - package org.apache.ignite.ml.selection.paramgrid
Root package for parameter grid.
org.apache.ignite.ml.selection.scoring - package org.apache.ignite.ml.selection.scoring
Root package for score calculators.
org.apache.ignite.ml.selection.scoring.cursor - package org.apache.ignite.ml.selection.scoring.cursor
Util classes used for score calculation.
org.apache.ignite.ml.selection.scoring.evaluator - package org.apache.ignite.ml.selection.scoring.evaluator
Package for model evaluator classes.
org.apache.ignite.ml.selection.scoring.metric - package org.apache.ignite.ml.selection.scoring.metric
Root package for metrics.
org.apache.ignite.ml.selection.scoring.metric.classification - package org.apache.ignite.ml.selection.scoring.metric.classification
Root package for classification metrics.
org.apache.ignite.ml.selection.scoring.metric.exceptions - package org.apache.ignite.ml.selection.scoring.metric.exceptions
Root package for exceptions.
org.apache.ignite.ml.selection.scoring.metric.regression - package org.apache.ignite.ml.selection.scoring.metric.regression
Root package for regression metrics.
org.apache.ignite.ml.selection.split - package org.apache.ignite.ml.selection.split
Root package for dataset splitters and cross validation.
org.apache.ignite.ml.selection.split.mapper - package org.apache.ignite.ml.selection.split.mapper
Root package for mappers used in dataset splitters.
org.apache.ignite.ml.sparkmodelparser - package org.apache.ignite.ml.sparkmodelparser
Base package for Spark model parser.
org.apache.ignite.ml.sql - package org.apache.ignite.ml.sql
Contains util classes that help to work with machine learning models in SQL and train models on data from SQL tables.
org.apache.ignite.ml.structures - package org.apache.ignite.ml.structures
Contains some internal utility structures.
org.apache.ignite.ml.structures.partition - package org.apache.ignite.ml.structures.partition
Contains internal APIs for dataset partitioned labeled datasets.
org.apache.ignite.ml.structures.preprocessing - package org.apache.ignite.ml.structures.preprocessing
Contains internal APIs for dataset pre-processing.
org.apache.ignite.ml.svm - package org.apache.ignite.ml.svm
Contains main APIs for SVM(support vector machines) algorithms.
org.apache.ignite.ml.trainers - package org.apache.ignite.ml.trainers
Contains model trainers.
org.apache.ignite.ml.trainers.transformers - package org.apache.ignite.ml.trainers.transformers
Various upstream transformers.
org.apache.ignite.ml.tree - package org.apache.ignite.ml.tree
Root package for decision trees.
org.apache.ignite.ml.tree.boosting - package org.apache.ignite.ml.tree.boosting
Contains implementation of gradient boosting on trees.
org.apache.ignite.ml.tree.data - package org.apache.ignite.ml.tree.data
Contains data and data builder required for decision tree trainers built on top of partition based dataset.
org.apache.ignite.ml.tree.impurity - package org.apache.ignite.ml.tree.impurity
Root package for decision tree impurity measures and calculators.
org.apache.ignite.ml.tree.impurity.gini - package org.apache.ignite.ml.tree.impurity.gini
Contains Gini impurity measure and calculator.
org.apache.ignite.ml.tree.impurity.mse - package org.apache.ignite.ml.tree.impurity.mse
Contains mean squared error impurity measure and calculator.
org.apache.ignite.ml.tree.impurity.util - package org.apache.ignite.ml.tree.impurity.util
Contains util classes used in decision tree impurity calculators.
org.apache.ignite.ml.tree.leaf - package org.apache.ignite.ml.tree.leaf
Root package for decision trees leaf builders.
org.apache.ignite.ml.tree.randomforest - package org.apache.ignite.ml.tree.randomforest
Contains random forest implementation classes.
org.apache.ignite.ml.tree.randomforest.data - package org.apache.ignite.ml.tree.randomforest.data
Package contains helper data structures for random forest implementation.
org.apache.ignite.ml.tree.randomforest.data.impurity - package org.apache.ignite.ml.tree.randomforest.data.impurity
Contains implementation of impurity computers based on histograms.
org.apache.ignite.ml.tree.randomforest.data.impurity.basic - package org.apache.ignite.ml.tree.randomforest.data.impurity.basic
Contains implementation of basic classes for impurity computers.
org.apache.ignite.ml.tree.randomforest.data.statistics - package org.apache.ignite.ml.tree.randomforest.data.statistics
Contains implementation of statistics computers for Random Forest.
org.apache.ignite.ml.util - package org.apache.ignite.ml.util
Contains some utils for ML module.
org.apache.ignite.ml.util.generators - package org.apache.ignite.ml.util.generators
Contains utility classes for data streams generation.
org.apache.ignite.ml.util.generators.primitives - package org.apache.ignite.ml.util.generators.primitives
Contains primitives like random scalars and random vector generators for composing own data stream generator.
org.apache.ignite.ml.util.generators.primitives.scalar - package org.apache.ignite.ml.util.generators.primitives.scalar
Contains generators of pseudo-random scalars in according to specific disctribution.
org.apache.ignite.ml.util.generators.primitives.vector - package org.apache.ignite.ml.util.generators.primitives.vector
Contains generators of pseudo-random vectors in according to specific disctribution.
org.apache.ignite.ml.util.generators.standard - package org.apache.ignite.ml.util.generators.standard
Contains classes for predefined data stream generators.
org.apache.ignite.ml.util.genetic - package org.apache.ignite.ml.util.genetic
Contains some genetic algorithms for discrete optimization task in ML module locally.
org.apache.ignite.ml.util.plugin - package org.apache.ignite.ml.util.plugin
Contains Ignite plugins system integration classes.
org.apache.ignite.ml.xgboost - package org.apache.ignite.ml.xgboost
Base package for XGBoost model parser, correspondent DTOs and util classes.
org.apache.ignite.ml.xgboost.parser - package org.apache.ignite.ml.xgboost.parser
Base package for XGBoost model parser implementation.
org.apache.ignite.ml.xgboost.parser.visitor - package org.apache.ignite.ml.xgboost.parser.visitor
Base package for XGBoost model parser ANTLR visitor.
org.apache.ignite.mxbean - package org.apache.ignite.mxbean
Contains annotations for Dynamic MBeans.
org.apache.ignite.platform - package org.apache.ignite.platform
Contains platform-related classes.
org.apache.ignite.platform.cpp - package org.apache.ignite.platform.cpp
Contains C++ platform-related classes.
org.apache.ignite.platform.dotnet - package org.apache.ignite.platform.dotnet
Contains .Net platform-related classes.
org.apache.ignite.plugin - package org.apache.ignite.plugin
Contains plugins management API.
org.apache.ignite.plugin.extensions.communication - package org.apache.ignite.plugin.extensions.communication
Contains extendable components for communication.
org.apache.ignite.plugin.platform - package org.apache.ignite.plugin.platform
Contains platform plugins management API.
org.apache.ignite.plugin.security - package org.apache.ignite.plugin.security
Contains APIs for security, authentication, and authorization.
org.apache.ignite.plugin.segmentation - package org.apache.ignite.plugin.segmentation
Contains segmentation "split-brain" related classes.
org.apache.ignite.resources - package org.apache.ignite.resources
Contains resource injection annotations.
org.apache.ignite.scheduler - package org.apache.ignite.scheduler
Contains Job Scheduling functionality.
org.apache.ignite.services - package org.apache.ignite.services
Contains main Managed Services APIs.
org.apache.ignite.spi - package org.apache.ignite.spi
Contains common classes and interfaces for SPI implementations.
org.apache.ignite.spi.checkpoint - package org.apache.ignite.spi.checkpoint
Contains APIs for checkpoint SPI.
org.apache.ignite.spi.checkpoint.cache - package org.apache.ignite.spi.checkpoint.cache
Contains cache-based implementation for checkpoint SPI.
org.apache.ignite.spi.checkpoint.jdbc - package org.apache.ignite.spi.checkpoint.jdbc
Contains JDBC implementation for checkpoint SPI.
org.apache.ignite.spi.checkpoint.noop - package org.apache.ignite.spi.checkpoint.noop
Contains default no-op checkpoint SPI implementation.
org.apache.ignite.spi.checkpoint.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.communication.tcp.messages - package org.apache.ignite.spi.communication.tcp.messages
Contains implementation messages.
org.apache.ignite.spi.deployment - package org.apache.ignite.spi.deployment
Contains APIs for deployment SPI.
org.apache.ignite.spi.deployment.local - package org.apache.ignite.spi.deployment.local
Contains default local deployment SPI implementation.
org.apache.ignite.spi.deployment.uri - package org.apache.ignite.spi.deployment.uri
Contains URI-based deployment SPI implementation.
org.apache.ignite.spi.discovery - package org.apache.ignite.spi.discovery
Contains APIs for topology manager SPI.
org.apache.ignite.spi.discovery.isolated - package org.apache.ignite.spi.discovery.isolated
Contains implementation of special "isolated" mode for single-node cluster.
org.apache.ignite.spi.discovery.tcp - package org.apache.ignite.spi.discovery.tcp
Contains default TCP/IP implementation for discovery SPI.
org.apache.ignite.spi.discovery.tcp.ipfinder - package org.apache.ignite.spi.discovery.tcp.ipfinder
Contains IP finder interface and adapter.
org.apache.ignite.spi.discovery.tcp.ipfinder.cloud - package org.apache.ignite.spi.discovery.tcp.ipfinder.cloud
Contains Apache jclouds based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.elb - package org.apache.ignite.spi.discovery.tcp.ipfinder.elb
Contains AWS ELB-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.gce - package org.apache.ignite.spi.discovery.tcp.ipfinder.gce
Contains Google Cloud Storage IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc - package org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Contains JDBC IP finder implementation.
org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes - package org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes
Contains Kubernetes IP finder implementation.
org.apache.ignite.spi.discovery.tcp.ipfinder.multicast - package org.apache.ignite.spi.discovery.tcp.ipfinder.multicast
Contains multicast-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.s3 - package org.apache.ignite.spi.discovery.tcp.ipfinder.s3
Contains AWS S3-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt - package org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt
Contains Encryption services.
org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs - package org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs
Contains shared filesystem-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.vm - package org.apache.ignite.spi.discovery.tcp.ipfinder.vm
Contains local JVM-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.zk - package org.apache.ignite.spi.discovery.tcp.ipfinder.zk
Contains TCP Discovery IP Finder uses Apache ZooKeeper (ZK) to locate peer nodes.
org.apache.ignite.spi.discovery.zk - package org.apache.ignite.spi.discovery.zk
Contains Zookeeper Discovery Spi classes and interfaces.
org.apache.ignite.spi.encryption - package org.apache.ignite.spi.encryption
Contains APIs for encryption SPI.
org.apache.ignite.spi.encryption.keystore - package org.apache.ignite.spi.encryption.keystore
Contains encryption SPI implementation based on standard jdk keystore.
org.apache.ignite.spi.encryption.noop - package org.apache.ignite.spi.encryption.noop
Contains no-op encryption SPI implementation.
org.apache.ignite.spi.eventstorage - package org.apache.ignite.spi.eventstorage
Contains APIs for event storage SPI.
org.apache.ignite.spi.eventstorage.memory - package org.apache.ignite.spi.eventstorage.memory
Contains default in-memory implementation for event storage SPI.
org.apache.ignite.spi.failover - package org.apache.ignite.spi.failover
Contains APIs for failover SPI.
org.apache.ignite.spi.failover.always - package org.apache.ignite.spi.failover.always
Contains default "always" failover SPI.
org.apache.ignite.spi.failover.jobstealing - package org.apache.ignite.spi.failover.jobstealing
Contains job stealing failover SPI.
org.apache.ignite.spi.failover.never - package org.apache.ignite.spi.failover.never
Contains "never" failover SPI.
org.apache.ignite.spi.indexing - package org.apache.ignite.spi.indexing
Contains APIs for indexing SPI.
org.apache.ignite.spi.indexing.noop - package org.apache.ignite.spi.indexing.noop
Contains default no-op indexing SPI implementation.
org.apache.ignite.spi.loadbalancing - package org.apache.ignite.spi.loadbalancing
Contains APIs for load balancing SPI.
org.apache.ignite.spi.loadbalancing.adaptive - package org.apache.ignite.spi.loadbalancing.adaptive
Contains adaptive load balancing SPI.
org.apache.ignite.spi.loadbalancing.roundrobin - package org.apache.ignite.spi.loadbalancing.roundrobin
Contains default round-robin implementation for load balancing SPI.
org.apache.ignite.spi.loadbalancing.weightedrandom - package org.apache.ignite.spi.loadbalancing.weightedrandom
Contains weighted random-base implementation for load balancing SPI.
org.apache.ignite.spi.metric - package org.apache.ignite.spi.metric
Contains common classes and interfaces for metric SPI implementations.
org.apache.ignite.spi.metric.jmx - package org.apache.ignite.spi.metric.jmx
Contains JMX based implementation of MetricExporterSpi.
org.apache.ignite.spi.metric.log - package org.apache.ignite.spi.metric.log
Contains push to log implementation of MetricExporterSpi.
org.apache.ignite.spi.metric.noop - package org.apache.ignite.spi.metric.noop
Contains no-op implementation of MetricExporterSpi.
org.apache.ignite.spi.metric.opencensus - package org.apache.ignite.spi.metric.opencensus
Contains Opencensus based implementation of MetricExporterSpi.
org.apache.ignite.spi.systemview - package org.apache.ignite.spi.systemview
Contains common classes and interfaces for system view SPI implementations.
org.apache.ignite.spi.systemview.view - package org.apache.ignite.spi.systemview.view
Contains system view implementations.
org.apache.ignite.spi.systemview.view.datastructures - package org.apache.ignite.spi.systemview.view.datastructures
 
org.apache.ignite.spi.tracing - package org.apache.ignite.spi.tracing
Contains common classes and interfaces for tracing SPI implementations.
org.apache.ignite.spi.tracing.opencensus - package org.apache.ignite.spi.tracing.opencensus
Contains API for OpenCensus Tracing framework integration.
org.apache.ignite.springdata.proxy - package org.apache.ignite.springdata.proxy
Contains classes that provide client-independent access to the Ignite operations required by Spring Data.
org.apache.ignite.springdata22.repository - package org.apache.ignite.springdata22.repository
Package contains Apache Ignite Spring Data integration.
org.apache.ignite.springdata22.repository.config - package org.apache.ignite.springdata22.repository.config
Package includes Spring Data integration related configuration files.
org.apache.ignite.springdata22.repository.query - package org.apache.ignite.springdata22.repository.query
Package includes classes that integrates with Apache Ignite SQL engine.
org.apache.ignite.springdata22.repository.support - package org.apache.ignite.springdata22.repository.support
Package contains supporting files required by Spring Data framework.
org.apache.ignite.ssl - package org.apache.ignite.ssl
Contains classes for working with SSL.
org.apache.ignite.startup - package org.apache.ignite.startup
Contains Ignite runtime startup classes.
org.apache.ignite.startup.cmdline - package org.apache.ignite.startup.cmdline
Contains default command line startup.
org.apache.ignite.startup.servlet - package org.apache.ignite.startup.servlet
Contains servlet-based startup.
org.apache.ignite.stream - package org.apache.ignite.stream
Contains Ignite Streamer classes.
org.apache.ignite.stream.socket - package org.apache.ignite.stream.socket
Contains socket streamer implementation.
org.apache.ignite.tensorflow - package org.apache.ignite.tensorflow
TensorFlow integration that allows to start and maintain TensorFlow cluster on top of Apache Ignite cluster infrastructure.
org.apache.ignite.tensorflow.cluster - package org.apache.ignite.tensorflow.cluster
TensorFlow integration API that allows to start and maintain TensorFlow cluster using infrastructure tools from package org.apache.ignite.tensorflow.core.
org.apache.ignite.tensorflow.cluster.spec - package org.apache.ignite.tensorflow.cluster.spec
Contains specifications that describes TensorFlow cluster configuration.
org.apache.ignite.tensorflow.cluster.tfrunning - package org.apache.ignite.tensorflow.cluster.tfrunning
Additional "running" layer on top of Python running layer of infrastructure.
org.apache.ignite.tensorflow.cluster.util - package org.apache.ignite.tensorflow.cluster.util
Util components that are used in TensorFlow cluster package.
org.apache.ignite.tensorflow.core - package org.apache.ignite.tensorflow.core
TensorFlow integration core package that provides infrastructure layers that allows TensorFlow cluster to start and be maintained.
org.apache.ignite.tensorflow.core.longrunning - package org.apache.ignite.tensorflow.core.longrunning
The part of TensorFlow integration infrastructure that allows to start and maintain abstract long-running processes.
org.apache.ignite.tensorflow.core.longrunning.task - package org.apache.ignite.tensorflow.core.longrunning.task
Contains long-running process tasks that encapsulates the logic of starting, pinging and stopping a long-running process.
org.apache.ignite.tensorflow.core.longrunning.task.util - package org.apache.ignite.tensorflow.core.longrunning.task.util
Util package that contains util classes used in long-running tasks.
org.apache.ignite.tensorflow.core.nativerunning - package org.apache.ignite.tensorflow.core.nativerunning
The part of TensorFlow integration infrastructure that allows to start and maintain abstract native processes.
org.apache.ignite.tensorflow.core.nativerunning.task - package org.apache.ignite.tensorflow.core.nativerunning.task
Contains native process task that encapsulates the logic of starting native process.
org.apache.ignite.tensorflow.core.util - package org.apache.ignite.tensorflow.core.util
Util classes used in other org.apache.ignite.tensorflow.core classes.
org.apache.ignite.tensorflow.submitter - package org.apache.ignite.tensorflow.submitter
This package contains classes that allow to use command line interface to submit jobs into TensorFlow in Apache Ignite infrastructure.
org.apache.ignite.tensorflow.submitter.command - package org.apache.ignite.tensorflow.submitter.command
This package contains commands that command line tool provides.
org.apache.ignite.tensorflow.util - package org.apache.ignite.tensorflow.util
Util classes used in org.apache.ignite.tensorflow package.
org.apache.ignite.thread - package org.apache.ignite.thread
Contains threads-related utility classes.
org.apache.ignite.transactions - package org.apache.ignite.transactions
Contains transaction-related classes.
org.apache.ignite.transactions.spring - package org.apache.ignite.transactions.spring
Contains implementation of Spring transaction manager.
org.apache.ignite.yarn - package org.apache.ignite.yarn
Contains classes to support integration with Apache Hadoop Yarn.
org.apache.ignite.yarn.utils - package org.apache.ignite.yarn.utils
Utility and helper classes.
org.gridgain.grid - package org.gridgain.grid
Contains base API classes.
org.gridgain.grid.cache - package org.gridgain.grid.cache
Contains cache API classes.
org.gridgain.grid.cache.compress - package org.gridgain.grid.cache.compress
Contains cache entry compression Zstandard-based implementation.
org.gridgain.grid.cache.conflict - package org.gridgain.grid.cache.conflict
Contains cache conflicts API classes.
org.gridgain.grid.cache.db.wal - package org.gridgain.grid.cache.db.wal
Contains database WAL CRC classes.
org.gridgain.grid.cache.db.wal.crc - package org.gridgain.grid.cache.db.wal.crc
Contains database WAL classes.
org.gridgain.grid.cache.dr - package org.gridgain.grid.cache.dr
Contains cache data center replication API classes.
org.gridgain.grid.cache.store - package org.gridgain.grid.cache.store
Contains cache store API classes.
org.gridgain.grid.cache.store.jdbc - package org.gridgain.grid.cache.store.jdbc
Contains cache JDBC store API classes.
org.gridgain.grid.cache.store.local - package org.gridgain.grid.cache.store.local
Contains cache file local store API classes.
org.gridgain.grid.configuration - package org.gridgain.grid.configuration
Contains base GridGain configuration classes.
org.gridgain.grid.dr - package org.gridgain.grid.dr
Contains data center replication API classes.
org.gridgain.grid.dr.store - package org.gridgain.grid.dr.store
Contains data center replication store API classes.
org.gridgain.grid.dr.store.fs - package org.gridgain.grid.dr.store.fs
Contains data center replication file system store API classes.
org.gridgain.grid.dr.store.memory - package org.gridgain.grid.dr.store.memory
Contains data center replication in-memory store API classes.
org.gridgain.grid.events - package org.gridgain.grid.events
Contains events API classes.
org.gridgain.grid.interop - package org.gridgain.grid.interop
Contains interop API.
org.gridgain.grid.interop.cpp - package org.gridgain.grid.interop.cpp
Contains interop API for CPP platform.
org.gridgain.grid.marshaller - package org.gridgain.grid.marshaller
Contains marshaller API classes.
org.gridgain.grid.persistentstore - package org.gridgain.grid.persistentstore
Contains base GridGain database interfaces.
org.gridgain.grid.persistentstore.snapshot.file - package org.gridgain.grid.persistentstore.snapshot.file
Contains base GridGain database snapshot SPI file implementation.
org.gridgain.grid.persistentstore.snapshot.file.copy - package org.gridgain.grid.persistentstore.snapshot.file.copy
Contains two-phases copy strategy implementation.
org.gridgain.grid.persistentstore.snapshot.file.remote - package org.gridgain.grid.persistentstore.snapshot.file.remote
Contains remote GridGain database snapshot SPI file implementation.
org.gridgain.grid.persistentstore.snapshot.file.remote.wal - package org.gridgain.grid.persistentstore.snapshot.file.remote.wal
Contains GridGain database snapshot SPI file implementation for remote WAL.
org.gridgain.grid.product - package org.gridgain.grid.product
Contains Product and License related functionality.
org.gridgain.grid.ru - package org.gridgain.grid.ru
This package contains classes related to Rolling Upgrade process.
org.gridgain.grid.security - package org.gridgain.grid.security
Contains security API classes.
org.gridgain.grid.security.certificate - package org.gridgain.grid.security.certificate
Contains X.509 Certificate Authenticator classes.
org.gridgain.grid.security.jaas - package org.gridgain.grid.security.jaas
Contains JAAS API classes.
org.gridgain.grid.security.passcode - package org.gridgain.grid.security.passcode
Contains passcode API classes.
org.gridgain.grid.segmentation - package org.gridgain.grid.segmentation
Contains segmentation API classes.
org.gridgain.grid.segmentation.reachability - package org.gridgain.grid.segmentation.reachability
Contains segmentation resolver based on InetAddress.isReachable().
org.gridgain.grid.segmentation.sharedfs - package org.gridgain.grid.segmentation.sharedfs
Contains shared file system segmentation resolver implementation.
org.gridgain.grid.segmentation.tcp - package org.gridgain.grid.segmentation.tcp
Contains TCP segmentation resolver implementation.
original - Variable in class org.apache.ignite.ml.preprocessing.developer.MappedPreprocessor
Original preprocessor.
originatingNodeId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
originNodeId() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets ID of grid node that initiated the service deployment.
originNodeId() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets ID of grid node that initiated the service deployment.
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
OS_INFO_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
OS_USER_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
otherClusterVersion() - Method in interface org.apache.ignite.cache.CacheEntryVersion
If source of the update is "local" cluster then null will be returned.
otherNodeId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
OUT_OF_RESOURCES_TCP_MSG - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
IPC error message.
outputSize() - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Size of output of MLP.
outputStream() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Opens output stream for this file.
outputSupplier(IgniteFunction<A, B>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Transform function of form a -> b into a -> (() -> b).
outputSupplier(IgniteBiFunction<A, B, C>) - Static method in class org.apache.ignite.ml.math.functions.Functions
Transform function of form (a, b) -> c into (a, b) - () -> c.
overflowMode - Variable in class org.gridgain.grid.dr.store.DrAbstractSenderStore
 

P

p() - Method in class org.apache.ignite.ml.preprocessing.normalization.NormalizationPreprocessor
Gets the degree of L^p space parameter value.
p() - Method in class org.apache.ignite.ml.preprocessing.normalization.NormalizationTrainer
Gets the degree of L space parameter value.
PageReplacementMode - Enum in org.apache.ignite.configuration
Defines memory page replacement algorithm.
PageReplacementStartEvent - Class in org.apache.ignite.events
Event type indicating that page replacement started in one of the configured data regions.
PageReplacementStartEvent(ClusterNode, String, String) - Constructor for class org.apache.ignite.events.PageReplacementStartEvent
 
pageSize(int) - Method in interface org.apache.ignite.client.ClientIgniteSet
Sets the page size to be used for batched network data retrieval in ClientIgniteSet.iterator() and ClientIgniteSet.toArray().
pageSize() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets the page size to be used for batched network data retrieval in ClientIgniteSet.iterator() and ClientIgniteSet.toArray().
pageSize() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
pageSize(int) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.wal.IteratorParametersBuilder
 
PagesListView - Class in org.apache.ignite.spi.systemview.view
Pages-list representation for a SystemView.
PagesListView(PagesList, int) - Constructor for class org.apache.ignite.spi.systemview.view.PagesListView
 
pairedConnection() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
parallelism() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
parallelism(Integer) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets parallelism level for snapshot check operation.
parallelism() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
parallelism(Integer) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets parallelism level for snapshot restore operation.
parallelismLevel() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
parallelismLevel(Integer) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets level of parallelism.
parallelismLevel() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
parallelismLevel(Integer) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets level of parallelism.
parallelismLevel() - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
 
parallelismStrategy() - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Returns Parallelism Strategy instance.
ParallelismStrategy - Interface in org.apache.ignite.ml.environment.parallelism
Specifies the behaviour of processes in ML-algorithms that can may be parallelized such as parallel learning in bagging, learning submodels for One-vs-All model, Cross-Validation etc.
ParallelismStrategy.Type - Enum in org.apache.ignite.ml.environment.parallelism
The type of parallelism.
parallelogram(Vector) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of vectors from multidimension uniform distribution around zero.
parallelogram(Vector, long) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of vectors from multidimension uniform distribution around zero.
PARAM_ENFORCE_JOIN_ORDER - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: enforce join order flag (SQL hint).
PARAM_LAZY - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: replicated only flag (SQL hint).
PARAM_QRY_MAX_MEMORY - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: query max memory.
PARAM_SCHEMA - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: schema name.
parameters() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
parameters() - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get parameters vector.
parametersCount() - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Count of parameters in this MLP architecture.
parametersCount() - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get count of parameters of this model.
ParameterSetGenerator - Class in org.apache.ignite.ml.selection.paramgrid
Generates tuples of hyper parameter values by given map.
ParameterSetGenerator(Map<Integer, Double[]>) - Constructor for class org.apache.ignite.ml.selection.paramgrid.ParameterSetGenerator
Creates an instance of the generator.
ParameterUpdateCalculator<M,P extends Serializable> - Interface in org.apache.ignite.ml.optimization.updatecalculators
Interface for classes encapsulating parameters updateCache logic.
ParametricVectorGenerator - Class in org.apache.ignite.ml.util.generators.primitives.vector
Generate vectors having components generated by parametrized function.
ParametricVectorGenerator(RandomProducer, IgniteFunction<Double, Double>...) - Constructor for class org.apache.ignite.ml.util.generators.primitives.vector.ParametricVectorGenerator
Create an intance of ParametricVectorGenerator.
Parametrized<M extends Parametrized<M>> - Interface in org.apache.ignite.ml.optimization
Interface for parametrized models.
paramGrid - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Parameter grid.
ParamGrid - Class in org.apache.ignite.ml.selection.paramgrid
Keeps the grid of parameters.
ParamGrid() - Constructor for class org.apache.ignite.ml.selection.paramgrid.ParamGrid
 
paramsAsVector(List<MLPLayer>) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Flatten this MLP parameters as vector.
parse(I, Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
This method should transform raw data records into valid key-value pairs to be stored into cache.
parse(byte[]) - Method in class org.apache.ignite.ml.inference.parser.IgniteModelParser
Accepts serialized model represented by byte array, parses it and returns Model.
parse(byte[]) - Method in interface org.apache.ignite.ml.inference.parser.ModelParser
Accepts serialized model represented by byte array, parses it and returns Model.
parse(byte[]) - Method in class org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser
Accepts serialized model represented by byte array, parses it and returns Model.
parse(byte[]) - Method in class org.apache.ignite.ml.mleap.MLeapModelParser
Accepts serialized model represented by byte array, parses it and returns Model.
parse(String, SupportedSparkModels) - Static method in class org.apache.ignite.ml.sparkmodelparser.SparkModelParser
Load model from parquet (presented as a directory).
parse(byte[]) - Method in class org.apache.ignite.ml.xgboost.parser.XGModelParser
Accepts serialized model represented by byte array, parses it and returns Model.
parseModel(byte[]) - Method in class org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser
Parses model specified in serialized form as byte array.
parseModel(byte[]) - Method in class org.apache.ignite.ml.inference.parser.TensorFlowGraphModelParser
Parses model specified in serialized form as byte array.
parseModel(byte[]) - Method in class org.apache.ignite.ml.inference.parser.TensorFlowSavedModelModelParser
Parses model specified in serialized form as byte array.
partiallyFilledPagesFreeSpace() - Method in interface org.apache.ignite.DataRegionMetricsProvider
Calculates free space of partially filled pages for this data region.
partId() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
partition(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition id for the given key.
partition(Object) - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Gets partition number for a given key starting from 0.
partition(Object) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets partition number for a given key starting from 0.
partition() - Method in class org.apache.ignite.events.CacheEvent
Gets partition for the event which is the partition the key belongs to.
partition() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets partition for the event.
partition(Object) - Method in class org.apache.ignite.ml.dataset.impl.cache.util.DatasetAffinityFunctionWrapper
Returns key as a partition index.
partition() - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Gets current partition.
partition(Object) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets partition number for a given key starting from 0.
partition() - Method in interface org.apache.ignite.spi.failover.FailoverContext
partition(String, Object) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Calculates partition number for given key.
partition() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
PartitionContextBuilder<K,V,C extends Serializable> - Interface in org.apache.ignite.ml.dataset
Builder that accepts a partition upstream data and makes partition context.
PartitionDataBuilder<K,V,C extends Serializable,D extends AutoCloseable> - Interface in org.apache.ignite.ml.dataset
Builder that accepts a partition upstream data and partition context and makes partition data.
partitionId() - Method in class org.apache.ignite.spi.systemview.view.CachePagesListView
 
partitionId() - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
 
PartitionLossPolicy - Enum in org.apache.ignite.cache
Partition loss policy.
partitionLossPolicy() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
partitionLossPolicy() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
partitions() - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets number of partitions in cache according to configured affinity function.
partitions() - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.ml.dataset.impl.cache.util.DatasetAffinityFunctionWrapper
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets total number of partitions available.
partitionsCount() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
partitionsTransferred() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets number of partitions that have been transferred.
parts - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Parts.
parts() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets partitions for a query.
PasscodeAuthenticator - Class in org.gridgain.grid.security.passcode
Passcode-based implementation of the authentication.
PasscodeAuthenticator() - Constructor for class org.gridgain.grid.security.passcode.PasscodeAuthenticator
 
PasscodeAuthenticatorMBean - Interface in org.gridgain.grid.security.passcode
Management bean for PasscodeAuthenticator.
patch(Collection<SchemaAbstractOperation>) - Static method in class org.apache.ignite.cache.QueryEntityPatch
Builder method for patch with operations.
PatchedPreprocessor<K,V,L1,L2> - Class in org.apache.ignite.ml.preprocessing.developer
Preprocessing function that makes binarization.
PatchedPreprocessor(IgniteFunction<LabeledVector<L1>, LabeledVector<L2>>, Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.developer.PatchedPreprocessor
Constructs a new instance of Binarization preprocessor.
path(File) - Method in class org.gridgain.grid.persistentstore.SnapshotPath.FileSnapshotPathBuilder
Sets snapshot path.
path() - Method in class org.gridgain.grid.persistentstore.SnapshotPath
 
pattern() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets scheduling pattern.
pause() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Pauses data center replication for this cache.
pause() - Method in interface org.gridgain.grid.dr.DrSender
Pause replication to all remote DCs.
pause(byte) - Method in interface org.gridgain.grid.dr.DrSender
Pause replication for given DC.
pause() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Pause replication to all remote DCs.
pause(byte) - Method in interface org.gridgain.grid.dr.DrSenderMBean
Pause replication for given DC.
pause(String) - Method in interface org.gridgain.grid.GridDr
Deprecated.
This method actually works same way as GridDr.stopReplication(String) and stops replication for given cache.
paused() - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
Deprecated.
paused(byte) - Method in interface org.gridgain.grid.dr.DrSender
Returns DC pause flag.
paused() - Method in interface org.gridgain.grid.dr.DrSenderConnection
Returns connection pause flag.
paused(byte) - Method in interface org.gridgain.grid.dr.DrSenderMBean
Returns DC pause flag.
peek() - Method in interface org.apache.ignite.IgniteQueue
pendingQueueSize() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets current amount of cache entries in pending queue.
permissions() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Authorized permission set for the subject.
permissions(String) - Method in class org.gridgain.grid.security.jaas.JaasBasicPermissionsProvider
Converts principal to SecurityPermissionSet.
permissions(String) - Method in class org.gridgain.grid.security.jaas.JaasJsonPermissionProvider
Converts principal to SecurityPermissionSet.
permissions(String) - Method in interface org.gridgain.grid.security.jaas.JaasPermissionsProvider
Converts principal to SecurityPermissionSet.
permissions() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
Authorized permission set for the subject.
perNodeBufferSize() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets size of per node key-value pairs buffer.
perNodeBufferSize(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets size of per node key-value pairs buffer.
perNodeParallelOperations() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets maximum number of parallel stream operations for a single node.
perNodeParallelOperations(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets maximum number of parallel stream operations for a single node.
PersistenceController - Class in org.apache.ignite.cache.store.cassandra.persistence
Intermediate layer between persistent store (Cassandra) and Ignite cache key/value classes.
PersistenceController(KeyValuePersistenceSettings) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PersistenceController
Constructs persistence controller from Ignite cache persistence settings.
PersistenceMetrics - Interface in org.apache.ignite
Deprecated.
Use DataStorageMetrics instead.
PersistenceMetricsMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Part of old API. Metrics are accessible through DataStorageMetricsMXBean.
PersistenceSettings<F extends PojoField> - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings, which describes how particular key/value from Ignite cache should be stored in Cassandra.
PersistenceSettings(Element) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Constructs persistence settings from corresponding XML element.
PersistenceStrategy - Enum in org.apache.ignite.cache.store.cassandra.persistence
Describes persistence strategy to be used to persist object data into Cassandra.
PersistentStoreConfiguration - Class in org.apache.ignite.configuration
Deprecated.
PersistentStoreConfiguration() - Constructor for class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
persistentStoreMetrics() - Method in interface org.apache.ignite.Ignite
Deprecated.
persistentStoreMetrics() - Method in class org.apache.ignite.IgniteSpringBean
perThreadBufferSize(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Allows to set buffer size for thread in case of stream by IgniteDataStreamer.addData(Object, Object) call.
perThreadBufferSize() - Method in interface org.apache.ignite.IgniteDataStreamer
ping(Map<UUID, List<UUID>>) - Method in class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcessManager
Pings the given processes.
ping(Map<UUID, List<UUID>>) - Method in interface org.apache.ignite.tensorflow.core.ProcessManager
Pings the given processes.
ping(Map<UUID, List<UUID>>) - Method in class org.apache.ignite.tensorflow.core.ProcessManagerWrapper
Pings the given processes.
pingNode(UUID) - Method in interface org.apache.ignite.IgniteCluster
Pings a remote node.
pingNode(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Pings node with given node ID to see whether it is alive.
pingNode(UUID) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Pings a remote node.
pingNodeByAddress(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Pings node with given host name to see if it is alive.
Pipeline<K,V,C extends Serializable,L> - Class in org.apache.ignite.ml.pipeline
A simple pipeline, which acts as a global trainer which produce a Pipeline Model.
Pipeline() - Constructor for class org.apache.ignite.ml.pipeline.Pipeline
 
pipeline - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Pipeline.
PipelineMdl<K,V> - Class in org.apache.ignite.ml.pipeline
Wraps the model produced by Pipeline.
PipelineMdl() - Constructor for class org.apache.ignite.ml.pipeline.PipelineMdl
 
pk() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
PlainCredentials - Class in org.apache.ignite.cache.store.cassandra.datasource
Simple implementation of Credentials which just uses its constructor to hold user/password values.
PlainCredentials(String, String) - Constructor for class org.apache.ignite.cache.store.cassandra.datasource.PlainCredentials
Creates credentials object.
plainWrite(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.ByteChannelSnapshotOutputStream
Writes plain data to stream.
plainWrite(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotOutputStream
Writes plain data to stream.
plainWrite(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotEncryptionOutputStream
Writes plain data to stream.
PlatformCacheConfiguration - Class in org.apache.ignite.configuration
Platform cache configuration.
PlatformCacheConfiguration() - Constructor for class org.apache.ignite.configuration.PlatformCacheConfiguration
 
PlatformCachePluginConfigurationClosure - Interface in org.apache.ignite.plugin.platform
Platform cache configuration handler: updates plugin configuration using data sent from platform code.
PlatformCachePluginConfigurationClosureFactory - Interface in org.apache.ignite.plugin.platform
Factory for @PlatformCachePluginConfigurationClosure with a unique id.
PlatformConfiguration - Interface in org.apache.ignite.configuration
Platform configuration marker interface.
PlatformCppConfiguration - Class in org.apache.ignite.platform.cpp
Platform CPP configuration.
PlatformCppConfiguration() - Constructor for class org.apache.ignite.platform.cpp.PlatformCppConfiguration
Default constructor.
PlatformCppConfiguration(PlatformConfiguration) - Constructor for class org.apache.ignite.platform.cpp.PlatformCppConfiguration
Copying constructor.
PlatformDotNetAffinityFunction - Class in org.apache.ignite.platform.dotnet
AffinityFunction implementation which can be used to configure .NET affinity function in Java Spring configuration.
PlatformDotNetAffinityFunction() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
 
PlatformDotNetBinaryConfiguration - Class in org.apache.ignite.platform.dotnet
Mirror of .Net class BinaryConfiguration.cs
PlatformDotNetBinaryConfiguration() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Default constructor.
PlatformDotNetBinaryConfiguration(PlatformDotNetBinaryConfiguration) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Copy constructor.
PlatformDotNetBinaryTypeConfiguration - Class in org.apache.ignite.platform.dotnet
Mirror of .Net class BinaryTypeConfiguration.cs
PlatformDotNetBinaryTypeConfiguration() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Default constructor.
PlatformDotNetBinaryTypeConfiguration(PlatformDotNetBinaryTypeConfiguration) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Copy constructor.
PlatformDotNetCacheStoreFactory - Class in org.apache.ignite.platform.dotnet
Wrapper for .NET cache store implementations.
PlatformDotNetCacheStoreFactory() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
 
PlatformDotNetCacheStoreFactoryNative - Class in org.apache.ignite.platform.dotnet
Cache store factory that wraps native factory object.
PlatformDotNetCacheStoreFactoryNative(Object) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
Ctor.
PlatformDotNetConfiguration - Class in org.apache.ignite.platform.dotnet
Mirror of .Net class IgniteConfiguration.cs
PlatformDotNetConfiguration() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
Default constructor.
PlatformDotNetConfiguration(PlatformDotNetConfiguration) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
Copy constructor.
PlatformDotNetLifecycleBean - Class in org.apache.ignite.platform.dotnet
Lifecycle bean implementation which can be used to configure .Net lifecycle beans in Java Spring configuration.
PlatformDotNetLifecycleBean() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Constructor.
PlatformDotNetLifecycleBean(String) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Constructor.
PlatformJavaObjectFactory<T> - Interface in org.apache.ignite.platform
Object factory used for advanced interop between platform and Java.
PlatformPluginConfigurationClosure - Interface in org.apache.ignite.plugin.platform
Platform configuration handler: updates plugin configuration using data sent from platform code.
PlatformPluginConfigurationClosureFactory - Interface in org.apache.ignite.plugin.platform
Factory for @PlatformPluginConfigurationClosure with a unique id.
PlatformServiceMethod - Annotation Type in org.apache.ignite.platform
Annotation for setting mapping between java interface's method and platform service's method.
platformType() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets platform type.
PlatformType - Enum in org.apache.ignite.platform
Interop platform type.
plugin(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of deployed Ignite plugin.
plugin(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of deployed Ignite plugin.
plugin() - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
plugin() - Method in interface org.apache.ignite.plugin.PluginProvider
 
PLUGIN_NAME - Static variable in interface org.gridgain.grid.GridGain
 
PluginConfiguration - Interface in org.apache.ignite.plugin
Plugin configuration.
PluginContext - Interface in org.apache.ignite.plugin
Plugin context.
PluginNotFoundException - Exception in org.apache.ignite.plugin
Exception thrown if plugin is not found.
PluginNotFoundException(String) - Constructor for exception org.apache.ignite.plugin.PluginNotFoundException
 
PluginProvider<C extends PluginConfiguration> - Interface in org.apache.ignite.plugin
Pluggable Ignite component.
PluginValidationException - Exception in org.apache.ignite.plugin
TODO: Add class description.
PluginValidationException(String, String, UUID) - Constructor for exception org.apache.ignite.plugin.PluginValidationException
Constructs invalid plugin exception.
plus(H) - Method in interface org.apache.ignite.ml.dataset.feature.Histogram
 
plus(ObjectHistogram<T>) - Method in class org.apache.ignite.ml.dataset.feature.ObjectHistogram
PLUS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns a + b.
plus(double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns a + b.
plus(double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix where each value is a sum of the corresponding value of this matrix and argument value.
plus(Matrix) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix where each value is a sum of corresponding values of this matrix and passed in argument matrix.
plus(double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix where each value is a sum of the corresponding value of this matrix and argument value.
plus(Matrix) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix where each value is a sum of corresponding values of this matrix and passed in argument matrix.
plus(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing sum of each element in this vector and argument.
plus(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Creates new vector containing element by element sum from both vectors.
plus(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing sum of each element in this vector and argument.
plus(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Creates new vector containing element by element sum from both vectors.
plus(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing sum of each element in this vector and argument.
plus(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Creates new vector containing element by element sum from both vectors.
plus(GiniHistogram) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.GiniHistogram
plus(ImpurityHistogramsComputer.NodeImpurityHistograms<S>) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.ImpurityHistogramsComputer.NodeImpurityHistograms
Store features statistics from other instance.
plus(MSEHistogram) - Method in class org.apache.ignite.ml.tree.randomforest.data.impurity.MSEHistogram
plus(NormalDistributionStatistics) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
Returns plus of normal distribution statistics.
plus(VectorGenerator) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Creates new generator by sum of vectors of this generator and other.
PLUS - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
PLUS - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
PLUS_ABS - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns Math.abs(a) + Math.abs(b).
plusMult(double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns a + b*constant.
PointWithDistance<L> - Class in org.apache.ignite.ml.knn.utils
Utils class to be used in heap to compare two point using their distances to target point.
PointWithDistance(LabeledVector<L>, double) - Constructor for class org.apache.ignite.ml.knn.utils.PointWithDistance
Constructs a new instance of data point with distance.
PointWithDistanceUtil - Class in org.apache.ignite.ml.knn.utils
Util class with method that help working with PointWithDistance.
PointWithDistanceUtil() - Constructor for class org.apache.ignite.ml.knn.utils.PointWithDistanceUtil
 
PojoField - Class in org.apache.ignite.cache.store.cassandra.persistence
Descriptor for particular field in a POJO object, specifying how this field should be written to or loaded from Cassandra.
PojoField(Element, Class<?>) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Creates instance of PojoField based on it's description in XML element.
PojoField(PojoFieldAccessor) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Creates instance of PojoField from its field accessor.
PojoField(PojoField, Class<?>) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Creates instance of PojoField from the other instance and java class.
PojoFieldAccessor - Class in org.apache.ignite.cache.store.cassandra.persistence
Property accessor provides read/write access to POJO object properties defined through: 1) Getter/setter methods 2) Raw class members
PojoFieldAccessor(PropertyDescriptor, Field) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Constructs object instance from Java Bean property descriptor, providing access to getter/setter.
PojoFieldAccessor(Field) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Constructs object instance from Field, providing direct access to class member.
PojoKeyField - Class in org.apache.ignite.cache.store.cassandra.persistence
Descriptor for Ignite key POJO class
PojoKeyField(Element, Class) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Constructs Ignite cache key POJO object descriptor.
PojoKeyField(PojoKeyField, Class<?>) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Constructs instance of PojoKeyField based on the other instance and java class to initialize accessor.
PojoKeyField(PojoFieldAccessor) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField
Constructs Ignite cache key POJO object descriptor.
PojoKeyField.SortOrder - Enum in org.apache.ignite.cache.store.cassandra.persistence
Specifies sort order for POJO key field
PojoValueField - Class in org.apache.ignite.cache.store.cassandra.persistence
Descriptor for Ignite value POJO class
PojoValueField(Element, Class) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Constructs Ignite cache value field descriptor.
PojoValueField(PojoFieldAccessor) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Constructs Ignite cache value field descriptor.
PojoValueField(PojoValueField, Class<?>) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.PojoValueField
Constructs instance of PojoValueField based on the other instance and java class to initialize accessor.
policy() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Message processing policy.
policy() - Method in class org.apache.ignite.thread.IgniteThread
 
poll() - Method in interface org.apache.ignite.IgniteQueue
poll(long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
Population - Class in org.apache.ignite.ml.util.genetic
Represents a populations of chromosomes.
Population(int) - Constructor for class org.apache.ignite.ml.util.genetic.Population
 
POPULATION_CACHE - Static variable in interface org.apache.ignite.ml.genetic.parameter.GAGridConstants
populationCache constant
populationCache() - Static method in class org.apache.ignite.ml.genetic.cache.PopulationCacheConfig
 
PopulationCacheConfig - Class in org.apache.ignite.ml.genetic.cache
Cache configuration for GAGridConstants.POPULATION_CACHE cache population of chromosomes (ie: potential solutions)
PopulationCacheConfig() - Constructor for class org.apache.ignite.ml.genetic.cache.PopulationCacheConfig
 
port() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
position() - Method in class org.gridgain.grid.persistentstore.snapshot.file.ByteChannelSnapshotOutputStream
Returns this stream's position.
position() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotOutputStream
Returns this stream's position.
positiveClsLb() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
positiveClsLb() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Get the positive label.
postVisitDirectory(Path, IOException) - Method in class org.gridgain.grid.persistentstore.snapshot.file.DeleteFileVisitor
pow(double) - Static method in class org.apache.ignite.ml.math.functions.Functions
Function that returns Math.pow(a, b).
precision - Variable in class org.apache.ignite.ml.composition.boosting.convergence.ConvergenceCheckerFactory
Precision of error checking.
precision() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Precision or Positive Predictive Value (PPV).
Precision<L> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Precision calculator.
Precision(L) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.Precision
The class of interest or positive class.
precision() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
precision() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
predefined() - Method in class org.apache.ignite.spi.systemview.view.SqlSchemaView
 
predicate() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets predicate that defines a subset of nodes for this cluster group.
predict(Vector) - Method in class org.apache.ignite.ml.clustering.gmm.GmmModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.composition.bagging.BaggedModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer.GDBModel
Applies containing models to features and aggregate them to one prediction.
predict(I) - Method in class org.apache.ignite.ml.composition.combinators.parallel.ModelsParallelComposition
Make a prediction for the specified input arguments.
predict(I) - Method in class org.apache.ignite.ml.composition.combinators.sequential.ModelsSequentialComposition
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.composition.ModelOnFeaturesSubspace
Projects features vector to subspace in according to mapping and apply model to it.
predict(Vector) - Method in class org.apache.ignite.ml.composition.ModelsComposition
Applies containing models to features and aggregate them to one prediction.
predict(IS) - Method in class org.apache.ignite.ml.composition.stacking.StackedModel
Make a prediction for the specified input arguments.
predict(I) - Method in interface org.apache.ignite.ml.inference.Model
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.knn.classification.KNNClassificationModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.knn.regression.KNNRegressionModel
Make a prediction for the specified input arguments.
predict(NamedVector) - Method in class org.apache.ignite.ml.mleap.MLeapModel
Make a prediction for the specified input arguments.
predict(Double[]) - Method in class org.apache.ignite.ml.mleap.MLeapModel
Makes a prediction using default column order specified in MLeapModel.schema.
predict(DefaultLeapFrame) - Method in class org.apache.ignite.ml.mleap.MLeapModel
Makes a prediction using MLeap API.
predict(Vector) - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
 
predict(Vector) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
Returns a number of class to which the input belongs.
predict(Matrix) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Makes a prediction for the given objects.
predict(Vector) - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
 
predict(ObjectSubjectPair<O, S>) - Method in class org.apache.ignite.ml.recommendation.RecommendationModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Make a prediction for the specified input arguments.
predict(String, Double...) - Static method in class org.apache.ignite.ml.sql.SQLFunctions
Makes prediction using specified model name to extract model from model storage and specified input values as input object for prediction.
predict(Vector) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Make a prediction for the specified input arguments.
predict(I) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetModel
Result of this model application is a result of composition before `andThen` inner mdl `andThen` after.
predict(Vector) - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.tree.DecisionTreeLeafNode
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
Make a prediction for the specified input arguments.
predict(Vector) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeRoot
Make a prediction for the specified input arguments.
predict(NamedVector) - Method in class org.apache.ignite.ml.xgboost.XGModelComposition
Make a prediction for the specified input arguments.
predictionsAggregator() - Method in class org.apache.ignite.ml.composition.ModelsCompositionFormat
 
PredictionsAggregator - Interface in org.apache.ignite.ml.composition.predictionsaggregator
Predictions aggregator interface.
predictNextNodeKey(Vector) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
Returns leaf node for feature vector in according to decision tree.
predictRecommendation(String, Integer, Integer) - Static method in class org.apache.ignite.ml.sql.SQLFunctions
Makes prediction using specified model name to extract model from model storage and specified input values as input object for prediction.
preloadPartition(int) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Preload cache partition.
preloadPartition(int) - Method in interface org.apache.ignite.IgniteCache
Efficiently preloads cache primary partition into page memory.
preloadPartitionAsync(int) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Preload cache partition.
preloadPartitionAsync(int) - Method in interface org.apache.ignite.IgniteCache
Efficiently preloads cache partition into page memory.
prepare(int[]) - Method in class org.apache.ignite.cache.query.Query
Prepares the partitions.
prepareAndExecuteMaintenance() - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Examine all components if they need to execute maintenance actions.
prepareBuilders(String, Collection<JdbcType>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Prepare internal store specific builders for provided types metadata.
prepareBuilders(String, Collection<JdbcType>) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Prepare internal store specific builders for provided types metadata.
PreprocessingTrainer<K,V> - Interface in org.apache.ignite.ml.preprocessing
Trainer for preprocessor.
Preprocessor<K,V> - Interface in org.apache.ignite.ml.preprocessing
Basic interface in Preprocessor Hierarchy.
preprocessor - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Preprocessor.
previousAssignment(int) - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets affinity assignment for given partition on previous topology version.
previousId() - Method in class org.apache.ignite.events.ClusterIdUpdatedEvent
Value of cluster ID before update request that triggered this event.
previousSnapshots() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfoEx
Cache names per previous snapshot id
PreviousSnapshotsIterable - Class in org.gridgain.grid.persistentstore.snapshot.file
Iterable with previous snapshots.
PreviousSnapshotsIterable(long, String, Set<Integer>, FileDatabaseSnapshotSpi, Collection<SnapshotPath>, boolean, SnapshotSecurityLevel) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.PreviousSnapshotsIterable
Constructor.
previousState() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
 
previousState() - Method in class org.apache.ignite.events.ClusterStateChangeStartedEvent
 
previousTag() - Method in class org.apache.ignite.events.ClusterTagUpdatedEvent
Value of cluster tag before update request that triggered this event.
preVisitDirectory(Path, BasicFileAttributes) - Method in class org.gridgain.grid.persistentstore.snapshot.file.CopyFileVisitor
prevIterationGradient - Variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Previous iteration model partial derivatives by parameters.
prevIterationUpdates - Variable in class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Previous step weights updates.
prevIterationUpdates() - Method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Get previous step parameters updates.
prevIterationUpdates - Variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Previous iteration parameters updates.
primaryPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which the given cluster node has primary ownership.
primarySize() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all primary entries cached on this node.
primarySizeLong() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all primary entries cached on this node as a long value.
printLastErrors() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Prints errors.
printStackTrace(PrintStream) - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
printTree(DecisionTreeNode, boolean) - Static method in class org.apache.ignite.ml.tree.DecisionTree
Represents DecisionTree as String.
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.
prob(Vector) - Method in interface org.apache.ignite.ml.math.stat.Distribution
 
prob(Vector) - Method in class org.apache.ignite.ml.math.stat.DistributionMixture
prob(Vector) - Method in class org.apache.ignite.ml.math.stat.MultivariateGaussianDistribution
ProbableLabel - Class in org.apache.ignite.ml.knn.ann
The special class for fuzzy labels presenting the probability distribution over the class labels.
ProbableLabel(TreeMap<Double, Double>) - Constructor for class org.apache.ignite.ml.knn.ann.ProbableLabel
The key is class label, the value is the probability to be an item of this class.
process(Row, int) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Processes particular row inside batch operation.
process(Row) - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchLoaderAssistant
Processes each row returned by batch load operation.
process(Row) - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Processes Cassandra database table row returned by specified CQL statement.
process(Row, int) - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Processes particular row inside batch operation.
process(Row) - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Processes particular row inside batch operation.
processedCount() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
 
processedCount() - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
processedData() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
 
processedData() - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
processedPartitions() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Get count of processed partitions.
ProcessManager<R> - Interface in org.apache.ignite.tensorflow.core
Process manager that allows to run and maintain processes in the cluster.
ProcessManagerWrapper<T,R> - Class in org.apache.ignite.tensorflow.core
Process manager wrapper that allows to define how one type of process specification should be transformed into another type of process specification delegate working with and delegate all operations to this delegate.
ProcessManagerWrapper(ProcessManager<T>) - Constructor for class org.apache.ignite.tensorflow.core.ProcessManagerWrapper
Constructs a new instance of process manager wrapper.
PROCESSOR_ID - Static variable in class org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor
Processor id.
processSessionCreationError(ClusterNode, Collection<InetSocketAddress>, IgniteCheckedException) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Process errors if TCP/IP GridNioSession creation to remote node hasn't been performed.
processSystemClasses(ClassLoader, Collection<PluginProvider>, Consumer<String>) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Find all system class names (for JDK or Ignite classes) and process them with a given consumer.
produce() - Method in interface org.apache.ignite.lang.IgniteProducer
Produce value.
product() - Method in interface org.gridgain.grid.GridGain
Gets information about product as well as license management capabilities.
ProductLicense - Interface in org.gridgain.grid.product
Ignite license descriptor.
ProductLicenseException - Exception in org.gridgain.grid.product
This exception is thrown when license violation is detected.
ProductLicenseException(String, String) - Constructor for exception org.gridgain.grid.product.ProductLicenseException
Creates new license exception with given error message.
ProductLicenseException(String, String, Throwable) - Constructor for exception org.gridgain.grid.product.ProductLicenseException
Creates new license exception with given error message and optional nested exception.
ProductLicenseException(LicenseViolationInfoHolder) - Constructor for exception org.gridgain.grid.product.ProductLicenseException
Creates new license exception with given license violation info.
ProductLicenseException(LicenseViolationInfoHolder, Throwable) - Constructor for exception org.gridgain.grid.product.ProductLicenseException
Creates new license exception with given error message and optional nested exception.
progress() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
Promise<T> - Interface in org.apache.ignite.ml.environment.parallelism
Future interface extension for lambda-friendly interface.
PROP_CACHE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Cache name property name.
PROP_CFG - Static variable in class org.apache.ignite.IgniteJdbcDriver
Cache name property name.
PROP_COLLOCATED - Static variable in class org.apache.ignite.IgniteJdbcDriver
Collocated property name.
PROP_DISTRIBUTED_JOINS - Static variable in class org.apache.ignite.IgniteJdbcDriver
Distributed joins property name.
PROP_ENFORCE_JOIN_ORDER - Static variable in class org.apache.ignite.IgniteJdbcDriver
Transactions allowed property name.
PROP_HOST - Static variable in class org.apache.ignite.IgniteJdbcDriver
Hostname property name.
PROP_LAZY - Static variable in class org.apache.ignite.IgniteJdbcDriver
Lazy property name.
PROP_LOCAL - Static variable in class org.apache.ignite.IgniteJdbcDriver
Local property name.
PROP_MULTIPLE_STMTS - Static variable in class org.apache.ignite.IgniteJdbcDriver
Allow query with multiple statements.
PROP_NODE_ID - Static variable in class org.apache.ignite.IgniteJdbcDriver
Node ID property name.
PROP_PORT - Static variable in class org.apache.ignite.IgniteJdbcDriver
Port number property name.
PROP_QRY_MAX_MEMORY - Static variable in class org.apache.ignite.IgniteJdbcDriver
Query max memory property name.
PROP_SCHEMA - Static variable in class org.apache.ignite.IgniteJdbcDriver
Schema property name.
PROP_SKIP_REDUCER_ON_UPDATE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Skip reducer on update update property name.
PROP_STREAMING - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML streaming property name.
PROP_STREAMING_ALLOW_OVERWRITE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Whether DML streaming will overwrite existing cache entries.
PROP_STREAMING_FLUSH_FREQ - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML stream auto flush frequency property name.
PROP_STREAMING_PER_NODE_BUF_SIZE - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML stream node buffer size property name.
PROP_STREAMING_PER_NODE_PAR_OPS - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML stream parallel operations per node property name.
PROP_TX_ALLOWED - Static variable in class org.apache.ignite.IgniteJdbcDriver
Transactions allowed property name.
PROP_ZK_CONNECTION_STRING - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
System property name to provide the ZK Connection String.
properties() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Gets current session properties.
PropertyMappingHelper - Class in org.apache.ignite.cache.store.cassandra.common
Helper class providing bunch of methods to discover fields of POJO objects and map builtin Java types to appropriate Cassandra types.
PropertyMappingHelper() - Constructor for class org.apache.ignite.cache.store.cassandra.common.PropertyMappingHelper
 
protocol() - Method in class org.apache.ignite.client.events.ConnectionDescription
 
provideDiscoveryData(UUID) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Gets plugin discovery data object that will be sent to the new node during discovery process.
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.
PsCommand - Class in org.apache.ignite.tensorflow.submitter.command
Command "ps" that is used to print identifiers of all running TensorFlow clusters.
PsCommand() - Constructor for class org.apache.ignite.tensorflow.submitter.command.PsCommand
 
publish(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
publish(LogRecord) - Method in class org.apache.ignite.logger.log4j2.Log4jBridgeHandler
put(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache.
put(SessionImplementor, Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
put(CassandraSessionImpl, Session, long) - Static method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
Returns Cassandra driver session to sessions pool.
put(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in the cache.
put(K, V) - Method in interface org.apache.ignite.IgniteCache
put(T) - Method in interface org.apache.ignite.IgniteQueue
put(V1, V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
put(String, ModelDescriptor) - Method in class org.apache.ignite.ml.inference.storage.descriptor.IgniteModelDescriptorStorage
Saves the specified model descriptor with the specified model identifier.
put(String, ModelDescriptor) - Method in class org.apache.ignite.ml.inference.storage.descriptor.LocalModelDescriptorStorage
Saves the specified model descriptor with the specified model identifier.
put(String, ModelDescriptor) - Method in interface org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorage
Saves the specified model descriptor with the specified model identifier.
put(String, FileOrDirectory) - Method in class org.apache.ignite.ml.inference.storage.model.IgniteModelStorageProvider
Saves file or directory associated with the specified path.
put(String, FileOrDirectory) - Method in class org.apache.ignite.ml.inference.storage.model.LocalModelStorageProvider
Saves file or directory associated with the specified path.
put(String, FileOrDirectory) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorageProvider
Saves file or directory associated with the specified path.
put(String, String) - Method in class org.apache.ignite.services.ServiceCallContextBuilder
Put string attribute.
put(String, byte[]) - Method in class org.apache.ignite.services.ServiceCallContextBuilder
Put binary attribute.
put(String, K, V, long) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Puts object in cache.
put(K, V) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Associates the specified value with the specified key in the cache.
put(K, V) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Associates the specified value with the specified key in the cache.
put(K, V) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Associates the specified value with the specified key in the cache.
putAll(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pairs in cache.
putAll(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.client.ClientCache
Copies all of the entries from the specified map to the ClientCache.
putAll(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.IgniteCache
Copies all of the entries from the specified map to the Cache.
putAll(Map<? extends V1, ? extends V2>) - Method in class org.apache.ignite.lang.IgniteBiTuple
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Copies all of the entries from the specified map to the Ignite cache.
putAll(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Copies all of the entries from the specified map to the Ignite cache.
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Copies all of the entries from the specified map to the Ignite cache.
putAllAsync(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pairs in cache.
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.client.ClientCache
Copies all of the entries from the specified map to the ClientCache.
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously copies all of the entries from the specified map to the Cache.
putAllConflict(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Store DR data.
putAllConflictAsync(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Store DR data asynchronously.
putAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache.
putAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in the cache asynchronously.
putAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified value with the specified key in the cache.
putDistanceIdxPair(Map<Double, Set<Integer>>, int, double) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
 
putFile(String, byte[], boolean) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Creates a new or replaces existing file.
putFile(String, byte[], boolean) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Creates a new or replaces existing file.
putFile(String, byte[]) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Creates a new or replaces existing file.
putFromLoad(SessionImplementor, Object, Object, long, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
putFromLoad(SessionImplementor, 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
 
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.
putFromLoad(SharedSessionContractImplementor, Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
putFromLoad(SharedSessionContractImplementor, Object, Object, Object, boolean) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
putIfAbsent(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if cache had no previous mapping for it.
putIfAbsent(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
putIfAbsent(K, V) - Method in interface org.apache.ignite.IgniteCache
For CacheAtomicityMode.ATOMIC return value on primary node crash may be incorrect because of the automatic retries.
putIfAbsent(String, ModelDescriptor) - Method in class org.apache.ignite.ml.inference.storage.descriptor.IgniteModelDescriptorStorage
Saves the specified model descriptor with the specified model identifier if it's not saved yet.
putIfAbsent(String, ModelDescriptor) - Method in class org.apache.ignite.ml.inference.storage.descriptor.LocalModelDescriptorStorage
Saves the specified model descriptor with the specified model identifier if it's not saved yet.
putIfAbsent(String, ModelDescriptor) - Method in interface org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorage
Saves the specified model descriptor with the specified model identifier if it's not saved yet.
putIfAbsent(String, K, V, long) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Puts object into cache if there was no previous object associated with given key.
putIfAbsentAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
putIfAbsentAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
putIfAbsentAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified key with the given value if it is not already associated with a value.
putIntoCache(Object, Object, SharedSessionContractImplementor) - Method in class org.apache.ignite.cache.hibernate.IgniteGeneralDataRegion
putMetaIfAbsent(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Adds given metadata value only if it was absent.
PythonProcessBuilderSupplier - Class in org.apache.ignite.tensorflow.core.util
Python process builder supplier that is used to create Python process builder.
PythonProcessBuilderSupplier(boolean, String...) - Constructor for class org.apache.ignite.tensorflow.core.util.PythonProcessBuilderSupplier
Constructs a new instance of Python process builder supplier.

Q

qryStr() - Method in class org.apache.ignite.springdata22.repository.query.IgniteQuery
Text string of the query.
qualify(String) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
Query<R> - Class in org.apache.ignite.cache.query
Main API for configuring and executing cache queries.
query() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
query(Query<R>) - Method in interface org.apache.ignite.client.ClientCache
Queries cache.
query(ContinuousQuery<K, V>, ClientDisconnectListener) - Method in interface org.apache.ignite.client.ClientCache
Start ContinuousQuery on the cache.
query(SqlFieldsQuery) - Method in interface org.apache.ignite.client.ClientCache
Convenience method to execute SqlFieldsQuery.
query(SqlFieldsQuery) - Method in interface org.apache.ignite.client.IgniteClient
Execute SQL query and get cursor to iterate over results.
query(Query<R>) - Method in interface org.apache.ignite.IgniteCache
Queries cache.
query(SqlFieldsQuery) - Method in interface org.apache.ignite.IgniteCache
Queries cache.
query(Query<T>, IgniteClosure<T, R>) - Method in interface org.apache.ignite.IgniteCache
Queries the cache transforming the entries on the server nodes.
query(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(Query<R>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Execute SQL query and get cursor to iterate over results.
query(Query<R>) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Execute SQL query and get cursor to iterate over results.
query(Query<R>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Execute SQL query and get cursor to iterate over results.
Query - Annotation Type in org.apache.ignite.springdata22.repository.config
Annotation to provide a user defined query for a method.
QueryCancelledException - Exception in org.apache.ignite.cache.query
The exception is thrown if a query was cancelled or timed out while executing.
QueryCancelledException() - Constructor for exception org.apache.ignite.cache.query.QueryCancelledException
Default constructor.
QueryCursor<T> - Interface in org.apache.ignite.cache.query
Query result cursor.
QueryCursorWrapper(QueryCursor<T>, Function<T, V>) - Constructor for class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery.QueryCursorWrapper
Instantiates a new Query cursor wrapper.
QueryDetailMetrics - Interface in org.apache.ignite.cache.query
Query metrics aggregated by query type and its textual representation.
queryDetailMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets query detail metrics.
queryDetailMetricsSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
QueryEntity - Class in org.apache.ignite.cache
Query entity is a description of cache entry (composed of key and value) in a way of how it must be indexed and can be queried.
QueryEntity() - Constructor for class org.apache.ignite.cache.QueryEntity
Creates an empty query entity.
QueryEntity(QueryEntity) - Constructor for class org.apache.ignite.cache.QueryEntity
Copy constructor.
QueryEntity(String, String) - Constructor for class org.apache.ignite.cache.QueryEntity
Creates a query entity with the given key and value types.
QueryEntity(Class<?>, Class<?>) - Constructor for class org.apache.ignite.cache.QueryEntity
Creates a query entity with the given key and value types.
QueryEntityPatch - Class in org.apache.ignite.cache
Query entity patch which contain SchemaAbstractOperation operations for changing query entity.
QueryGroupIndex - Annotation Type in org.apache.ignite.cache.query.annotations
Describes group index.
QueryGroupIndex.List - Annotation Type in org.apache.ignite.cache.query.annotations
List of group indexes for type.
queryId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
queryId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
QueryIndex - Class in org.apache.ignite.cache
Contains list of fields to be indexed.
QueryIndex() - Constructor for class org.apache.ignite.cache.QueryIndex
Creates an empty index.
QueryIndex(String) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates single-field sorted ascending index.
QueryIndex(String, boolean) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates single-field sorted index.
QueryIndex(String, boolean, String) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates single-field sorted index.
QueryIndex(String, QueryIndexType) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for one field.
QueryIndex(String, QueryIndexType, boolean) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for one field.
QueryIndex(String, QueryIndexType, boolean, String) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for one field.
QueryIndex(Collection<String>, QueryIndexType) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for a collection of fields.
QueryIndex(LinkedHashMap<String, Boolean>, QueryIndexType) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for a collection of fields.
QueryIndexType - Enum in org.apache.ignite.cache
Index type.
QueryMetrics - Interface in org.apache.ignite.cache.query
Cache query metrics used to obtain statistics on query.
queryMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets query metrics.
queryParallelism() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
QueryRetryException - Exception in org.apache.ignite.cache.query
The exception is thrown if a query was cancelled or timed out while executing.
QueryRetryException(String) - Constructor for exception org.apache.ignite.cache.query.QueryRetryException
 
QuerySqlField - Annotation Type in org.apache.ignite.cache.query.annotations
Annotates fields for SQL queries.
QuerySqlField.Group - Annotation Type in org.apache.ignite.cache.query.annotations
Describes group of index and position of field in this group.
QuerySqlFunction - Annotation Type in org.apache.ignite.cache.query.annotations
Annotates public static methods in classes to be used in SQL queries as custom functions.
QueryTextField - Annotation Type in org.apache.ignite.cache.query.annotations
Annotation for fields to be indexed for full text search using Lucene.
queryType() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
queryType() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query type.
queryType() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query type.
QueryUtils - Class in org.apache.ignite.springdata22.repository.query
Simple utility class to create queries.
queue() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Gets read-only view on internal FIFO queue in proper order.
queue() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Gets read-only view on internal FIFO queue in proper order.
queue() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Gets read-only view of backed queue in proper order.
queue(String, int, CollectionConfiguration) - Method in interface org.apache.ignite.Ignite
Will get a named queue from cache and create one if it has not been created yet and cfg is not null.
queue(String, int, CollectionConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Will get a named queue from cache and create one if it has not been created yet and cfg is not null.
queueLength() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
QueueView - Class in org.apache.ignite.spi.systemview.view.datastructures
Queue representation for a SystemView.
QueueView(GridCacheQueueProxy<?>) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 

R

r2() - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues
Returns coefficient of determination.
RANDOM_ACCESS_MODE - Static variable in interface org.apache.ignite.ml.math.StorageConstants
Storage mode optimized for random access.
randomDistribution(int) - Static method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
Generates pseudorandom discrete distribution.
randomDistribution(int, long) - Static method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
Generates pseudorandom discrete distribution.
RandomForestClassifierTrainer - Class in org.apache.ignite.ml.tree.randomforest
Classifier trainer based on RandomForest algorithm.
RandomForestClassifierTrainer(List<FeatureMeta>) - Constructor for class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Constructs an instance of RandomForestClassifierTrainer.
RandomForestRegressionTrainer - Class in org.apache.ignite.ml.tree.randomforest
Regression trainer based on RandomForest algorithm.
RandomForestRegressionTrainer(List<FeatureMeta>) - Constructor for class org.apache.ignite.ml.tree.randomforest.RandomForestRegressionTrainer
Constructs an instance of RandomForestRegressionTrainer.
RandomForestTrainer<L,S extends ImpurityComputer<BootstrappedVector,S>,T extends RandomForestTrainer<L,S,T>> - Class in org.apache.ignite.ml.tree.randomforest
Class represents a realization of Random Forest algorithm.
RandomForestTrainer(List<FeatureMeta>) - Constructor for class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Create an instance of RandomForestTrainer.
RandomInitializer - Class in org.apache.ignite.ml.nn.initializers
Class for initialization of MLP parameters with random uniformly distributed numbers from -1 to 1.
RandomInitializer(Random) - Constructor for class org.apache.ignite.ml.nn.initializers.RandomInitializer
Construct RandomInitializer from given RNG.
RandomInitializer(long) - Constructor for class org.apache.ignite.ml.nn.initializers.RandomInitializer
Constructs RandomInitializer with the given seed.
RandomInitializer() - Constructor for class org.apache.ignite.ml.nn.initializers.RandomInitializer
Constructs RandomInitializer with random seed.
randomNumbersGenerator() - Method in interface org.apache.ignite.ml.environment.LearningEnvironment
Random numbers generator.
RandomProducer - Interface in org.apache.ignite.ml.util.generators.primitives.scalar
Represents a generator of preudorandom scalar values.
RandomSleeper - Class in org.apache.ignite.cache.store.cassandra.common
Provides sleep method with randomly selected sleep time from specified range and incrementally shifts sleep time range for each next sleep attempt
RandomSleeper(int, int, int, IgniteLogger) - Constructor for class org.apache.ignite.cache.store.cassandra.common.RandomSleeper
Creates sleeper instance.
RandomStrategy - Class in org.apache.ignite.ml.selection.paramgrid
This strategy enables the random search in hyper-parameter space.
RandomStrategy() - Constructor for class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
 
randomUuid() - Static method in class org.apache.ignite.lang.IgniteUuid
Creates new pseudo-random ID.
rateTimeInterval(long) - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
rateTimeInterval(long) - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
rateTimeInterval(long) - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
rateTimeInterval(long) - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Sets time interval for rate-based metrics.
ratio() - Method in interface org.gridgain.grid.cache.compress.CompressionMetrics
Gets current ratio of compressed data size to uncompressed size, for all data which was accepted.
rawData() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
rawData() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
rawData() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
rawData() - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
 
rawReader() - Method in interface org.apache.ignite.binary.BinaryReader
Gets raw reader.
rawWriter() - Method in interface org.apache.ignite.binary.BinaryWriter
Gets raw writer.
RBRACK - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
RBRACK - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
RBRACK() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
 
RBRACK() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
ReachabilitySegmentationResolver - Class in org.gridgain.grid.segmentation.reachability
Segmentation resolver that uses address reachability to check whether node is in the correct segment or not.
ReachabilitySegmentationResolver() - Constructor for class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
 
read() - Method in class org.apache.ignite.ml.inference.reader.FileSystemModelReader
Rads model and returns it in serialized form as byte array.
read() - Method in class org.apache.ignite.ml.inference.reader.InMemoryModelReader
Rads model and returns it in serialized form as byte array.
read() - Method in interface org.apache.ignite.ml.inference.reader.ModelReader
Rads model and returns it in serialized form as byte array.
read() - Method in class org.apache.ignite.ml.inference.reader.ModelStorageModelReader
Rads model and returns it in serialized form as byte array.
readAffinityTopologyVersion(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads AffinityTopologyVersion.
readBinary(BinaryReader) - Method in interface org.apache.ignite.binary.Binarylizable
Reads fields from provided reader.
readBinary(Object, BinaryReader) - Method in class org.apache.ignite.binary.BinaryReflectiveSerializer
Reads fields from provided reader.
readBinary(Object, BinaryReader) - Method in interface org.apache.ignite.binary.BinarySerializer
Reads fields from provided reader.
readBinary(BinaryReader) - Method in class org.apache.ignite.lang.IgniteUuid
Reads fields from provided reader.
readBitSet(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads BitSet.
readBoolean() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readBoolean(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readBoolean(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads boolean value.
readBooleanArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readBooleanArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readBooleanArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads boolean array.
readByte() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readByte(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readByte(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads byte value.
readByteArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readByteArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readByteArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads byte array.
readChar() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readChar(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readChar(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads char value.
readCharArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readCharArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readCharArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads char array.
readCollection() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readCollection(BinaryCollectionFactory<T>) - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readCollection(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readCollection(String, BinaryCollectionFactory<T>) - Method in interface org.apache.ignite.binary.BinaryReader
 
readCollection(String, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads collection.
readDate() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDate(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDateArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDateArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDecimal() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDecimal(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDecimalArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDecimalArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDouble() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDouble(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDouble(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads double value.
readDoubleArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDoubleArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDoubleArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads double array.
readEnum() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readEnum(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readEnumArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readEnumArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
reader(UUID, MessageFactory) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFormatter
Creates new message reader instance.
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.affinity.AffinityKey
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
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.ml.dataset.impl.bootstrapping.BootstrappedVector
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.distances.EuclideanDistance
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.distances.HammingDistance
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.structures.Dataset
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.structures.DatasetRow
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.structures.FeatureMetadata
readExternal(ObjectInput) - Method in class org.apache.ignite.ml.structures.LabeledVector
readExternal(ObjectInput) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
readExternal(ObjectInput) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
readExternal(ObjectInput) - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
readExternal(ObjectInput) - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
readExternalData(byte, ObjectInput) - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
Load object's specific data content.
readFloat() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readFloat(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readFloat(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads float value.
readFloatArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readFloatArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readFloatArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads float array.
readFrom(ByteBuffer, MessageReader) - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Reads this message from provided byte buffer.
readIgniteUuid(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads IgniteUuid.
readInt() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readInt(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readInt(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int value.
readInt(String, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int value.
readIntArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readIntArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readIntArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int array.
readLong() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readLong(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readLong(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads long value.
readLongArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readLongArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readLongArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads long array.
readMap() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readMap(BinaryMapFactory<K, V>) - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readMap(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readMap(String, BinaryMapFactory<K, V>) - Method in interface org.apache.ignite.binary.BinaryReader
 
readMap(String, MessageCollectionItemType, MessageCollectionItemType, boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads map.
readMessage(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads nested message.
readMessage(Socket, InputStream, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Reads message from the socket limiting read time.
readNextPage(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.DigestSnapshotInputStream
Reads data from stream and writes it into the provided buffer.
readNextPage(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
Reads data from stream and writes it into the provided buffer.
readNextRecord() - Method in class org.gridgain.grid.persistentstore.snapshot.file.DigestSnapshotInputStream
Reads next WAL record from stream.
readNextRecord() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
Reads next WAL record from stream.
readObject() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readObject(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readObjectArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readObjectArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readObjectArray(String, MessageCollectionItemType, Class<T>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads array of objects.
ReadOnlyDynamicMBean - Class in org.apache.ignite.spi.metric.jmx
Base class for read only DynamicMBean implementations.
ReadOnlyDynamicMBean() - Constructor for class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
 
ReadOnlyMetricManager - Interface in org.apache.ignite.spi.metric
Read only metric manager.
ReadOnlyMetricRegistry - Interface in org.apache.ignite.spi.metric
Read only metric registry.
ReadOnlySystemViewRegistry - Interface in org.apache.ignite.spi.systemview
Read only system view registry.
readReceipt(Socket, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Reads message delivery receipt from the socket.
readRegistry(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
Reads snapshot file registry from the consistent node id folder in a snapshot.
readShort() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readShort(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readShort(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads short value.
readShortArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readShortArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readShortArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads short array.
readString() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readString(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readString(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads String.
readStringArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readStringArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTime() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTime(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTimeArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTimeArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTimestamp() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTimestamp(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTimestampArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTimestampArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readUuid() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readUuid(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readUuid(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads UUID.
readUuidArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readUuidArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
reason() - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
Gets stop reason.
reason() - Method in class org.gridgain.grid.events.DrCacheReplicationEvent
Returns pause reason.
rebalance() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Forces this cache node to re-balance its partitions.
rebalance() - Method in interface org.apache.ignite.IgniteCache
This cache node to re-balance its partitions.
rebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceBatchSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceDelay() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
rebalanceDelay() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceEnabled(boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Enable or disable cache partition rebalance per node.
rebalanceMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
rebalanceMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceOrder() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
rebalanceOrder() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceThrottle() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceTimeout() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalancingStartTime() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
recall() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Sensitivity or True Positive Rate (TPR).
Recall<L> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Recall calculator.
Recall(L) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.Recall
The class of interest or positive class.
receive(UUID, T) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method receives the message.
receive(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in interface org.apache.ignite.stream.StreamReceiver
Updates cache with batch of entries.
receive(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in class org.apache.ignite.stream.StreamTransformer
Updates cache with batch of entries.
receive(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in class org.apache.ignite.stream.StreamVisitor
Updates cache with batch of entries.
received() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
received() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
RECEIVED_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by node consistent id metric description.
RECEIVED_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by node consistent id metric name.
RECEIVED_MESSAGES_BY_TYPE_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by type metric description.
RECEIVED_MESSAGES_BY_TYPE_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by type metric name.
RECEIVED_MESSAGES_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages metric description.
RECEIVED_MESSAGES_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages metric name.
receivedBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received bytes count.
receiveDiscoveryData(UUID, Serializable) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Receives plugin discovery data object from remote nodes (called on new node during discovery process).
receiveDiscoveryData(UUID, Serializable) - Method in interface org.apache.ignite.plugin.PluginProvider
Receives plugin discovery data object from remote nodes (called on new node during discovery process).
receivedMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received messages counts (grouped by node).
receivedMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received messages counts (grouped by type).
receivedMessagesByTypeMetricName(Short) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Generate metric name by message direct type id.
receivedMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received messages count.
receiver(StreamReceiver<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets custom stream receiver to this data streamer.
receiverAggregatedInMetrics(byte) - Method in interface org.gridgain.grid.GridDr
Gets receiver hub incoming data metrics aggregated across all cache names for the given remote data center.
receiverAggregatedInMetrics(String) - Method in interface org.gridgain.grid.GridDr
Gets receiver hub incoming data metrics aggregated across all remote data centers for the given cache name.
receiverAggregatedInMetrics() - Method in interface org.gridgain.grid.GridDr
Gets receiver hub incoming data metrics aggregated across all remote data centers and cache names.
receiverAggregatedOutMetrics() - Method in interface org.gridgain.grid.GridDr
Gets receiver hub outgoing data metrics aggregated across all receiver caches.
receiverCacheMetrics(String) - Method in interface org.gridgain.grid.GridDr
Gets receiver cache metrics.
receiverInMetrics(byte, String) - Method in interface org.gridgain.grid.GridDr
Gets receiver hub incoming data metrics for the given remote data center and cache name.
receiverOutMetrics(String) - Method in interface org.gridgain.grid.GridDr
Gets receiver hub outgoing data metrics for the given cache name.
receiverOutMetrics(byte, String) - Method in interface org.gridgain.grid.GridDr
Gets receiver hub outgoing data metrics for the given source data center id and cache name.
RecommendationBinaryDatasetDataBuilder - Class in org.apache.ignite.ml.recommendation.util
Recommendation binary dataset data builder.
RecommendationBinaryDatasetDataBuilder(String, String, String) - Constructor for class org.apache.ignite.ml.recommendation.util.RecommendationBinaryDatasetDataBuilder
Constructs a new instance of recommendation binary dataset data builder.
RecommendationDatasetData<O extends Serializable,S extends Serializable> - Class in org.apache.ignite.ml.recommendation.util
A partition data of a dataset required in RecommendationTrainer.
RecommendationDatasetData(List<? extends ObjectSubjectRatingTriplet<O, S>>) - Constructor for class org.apache.ignite.ml.recommendation.util.RecommendationDatasetData
Constructs a new instance of recommendation dataset data.
RecommendationDatasetDataBuilder<K,O extends Serializable,S extends Serializable,Z extends ObjectSubjectRatingTriplet<O,S>> - Class in org.apache.ignite.ml.recommendation.util
A partition data builder that makes SimpleDatasetData.
RecommendationDatasetDataBuilder() - Constructor for class org.apache.ignite.ml.recommendation.util.RecommendationDatasetDataBuilder
 
RecommendationModel<O extends Serializable,S extends Serializable> - Class in org.apache.ignite.ml.recommendation
Recommendation model that predicts rating for ObjectSubjectPair.
RecommendationModel(Map<O, Vector>, Map<S, Vector>) - Constructor for class org.apache.ignite.ml.recommendation.RecommendationModel
Constructs a new instance of recommendation model.
RecommendationTrainer - Class in org.apache.ignite.ml.recommendation
Trainer of the recommendation system.
RecommendationTrainer() - Constructor for class org.apache.ignite.ml.recommendation.RecommendationTrainer
 
reconnectFuture() - Method in exception org.apache.ignite.IgniteClientDisconnectedException
 
record(Event) - Method in interface org.apache.ignite.spi.eventstorage.EventStorageSpi
Records single event.
record(Event) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Records single event.
record(Event) - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
Records single event.
recordEvent(Event) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Records local event.
recordLocal(Event) - Method in interface org.apache.ignite.IgniteEvents
Records customer user generated event.
recordsCompressed() - Method in interface org.gridgain.grid.cache.compress.CompressionMetrics
Gets total number of records taken as input for compression, regardless of whether it was accepted for compression and of compression ratio.
recordsDecompressed() - Method in interface org.gridgain.grid.cache.compress.CompressionMetrics
Gets total number of records taken as input for decompression.
RECOVERY_LAST_ID_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Recovery last received ID message type.
RecoveryLastReceivedMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Recovery acknowledgment message.
RecoveryLastReceivedMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Default constructor required by Message.
RecoveryLastReceivedMessage(long) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
redoBytesSize(byte) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
 
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() - Method in interface org.apache.ignite.lang.IgniteReducer
Reduces collected values into one.
reduce(List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.CrossOverTask
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.ml.genetic.FitnessTask
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.ml.genetic.MutateTask
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.ml.genetic.RouletteWheelSelectionTask
Return list of parent Chromosomes.
reduce(List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.TruncateSelectionTask
Reduces (or aggregates) results received so far into one compound result to be returned to caller via ComputeTaskFuture.get() method.
reduceStats(List<NormalDistributionStatistics>, List<NormalDistributionStatistics>, List<FeatureMeta>) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatisticsComputer
Merges statistics on features from two partitions.
reentrantLock(String, boolean, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates reentrant lock.
reentrantLock(String, boolean, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates reentrant lock.
ReentrantLockView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteLock representation for a SystemView.
ReentrantLockView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
refreshJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Refreshes collection of job siblings.
REGION_CACHE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
Property prefix used to specify region name to cache name mapping.
register() - Static method in class org.apache.ignite.IgniteJdbcThinDriver
 
register(short, Supplier<Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.IgniteMessageFactory
Register message factory with given direct type.
register(ClassLoader, Class<?>) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Registers a class loader with this SPI.
register(ClassLoader, Class<?>) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Registers a class loader with this SPI.
register(ClassLoader, Class<?>) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Registers a class loader with this SPI.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Registers new addresses.
registerAll(IgniteMessageFactory) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactoryProvider
Registers all messages factories.
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in interface org.apache.ignite.client.ClientCache
Registers a CacheEntryListener.
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>, ClientDisconnectListener) - Method in interface org.apache.ignite.client.ClientCache
Registers a CacheEntryListener.
registerClass(Class<?>) - Method in interface org.apache.ignite.IgniteBinary
Register binary type for specified class.
registerClassName(byte, int, String, boolean) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Method to register typeId->class name mapping in marshaller context cluster-wide.
registerClassName(byte, int, String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Deprecated.
Use MarshallerContext.registerClassName(byte, int, java.lang.String, boolean) instead. This particular method will be deleted in future releases.
registerClassNameLocally(byte, int, String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Method to register typeId->class name mapping in marshaller context on local node only.
registered(SchedulerDriver, Protos.FrameworkID, Protos.MasterInfo) - Method in class org.apache.ignite.mesos.IgniteScheduler
registeredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets addresses registered in the IP finder, initializes addresses having no port (or 0 port) with TcpDiscoverySpi.DFLT_PORT.
registerEnum(String, Map<String, Integer>) - Method in interface org.apache.ignite.IgniteBinary
Register enum type.
registerExtension(Class<T>, T) - Method in interface org.apache.ignite.plugin.ExtensionRegistry
Registers extension provided by plugin.
registerMaintenanceTask(MaintenanceTask) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Method to register MaintenanceTask locally on the node where method is called.
registerMaintenanceTask(MaintenanceTask, UnaryOperator<MaintenanceTask>) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Method to register MaintenanceTask locally on the node where method is called.
registerMBean(String, T, Class<T>) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Registers SPI MBean.
registerPort(int, IgnitePortProtocol, Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Registers open port.
registerPort(int, IgnitePortProtocol) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Registers open port.
registerWorkflowCallback(String, MaintenanceWorkflowCallback) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Registers MaintenanceWorkflowCallback for a MaintenanceTask with a given name.
registerWorkflowCallbackIfTaskExists(String, IgniteThrowableFunction<MaintenanceTask, MaintenanceWorkflowCallback>) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Call the MaintenanceRegistry.registerWorkflowCallback(String, MaintenanceWorkflowCallback) if the active maintenance task with given name exists.
REGISTRY_IS_MISSING_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
Error message when the snapshot digest registry doesn't exist.
RegressionDataStream - Class in org.apache.ignite.ml.util.generators.standard
Represents a generator of regression data stream based on Vector->Double function where each Vector was produced from hypercube with sides = [minXValue, maxXValue].
RegressionDataStream(int, IgniteFunction<Vector, Double>, double, double) - Constructor for class org.apache.ignite.ml.util.generators.standard.RegressionDataStream
Creates an instance of RegressionDataStream.
RegressionLeafValuesComputer - Class in org.apache.ignite.ml.tree.randomforest.data.statistics
Implementation of LeafValuesComputer for regression task.
RegressionLeafValuesComputer() - Constructor for class org.apache.ignite.ml.tree.randomforest.data.statistics.RegressionLeafValuesComputer
 
RegressionMetrics - Class in org.apache.ignite.ml.selection.scoring.metric.regression
Regression metrics calculator.
RegressionMetrics() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetrics
 
RegressionMetricValues - Class in org.apache.ignite.ml.selection.scoring.metric.regression
Provides access to regression metric values.
RegressionMetricValues(int, double, double, double) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues
Initalize an instance.
release() - Method in class org.apache.ignite.cache.store.cassandra.session.pool.IdleSession
Closes wrapped Cassandra driver session
release() - Static method in class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
Releases all session from pool and closes all their connections to Cassandra database.
release() - Method in interface org.apache.ignite.IgniteSemaphore
Releases a permit, returning it to the semaphore.
release(int) - Method in interface org.apache.ignite.IgniteSemaphore
Releases the given number of permits, returning them to the semaphore.
releaseDate() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets release date.
releasePort(UUID, int) - Method in class org.apache.ignite.tensorflow.cluster.util.ClusterPortManager
Releases acquired port on the specified node.
releasePorts(TensorFlowClusterSpec) - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowClusterResolver
Releases ports acquired for the given cluster specification.
RELU - Static variable in class org.apache.ignite.ml.nn.Activators
Rectified linear unit (ReLU) activation function.
remoteAddress() - Method in class org.apache.ignite.client.events.ConnectionDescription
Gets address of remote peer of this connection.
remoteAddress() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
remoteDaemonNodes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a collection of all remote daemon nodes in topology.
remoteDataCentersFormatted() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Gets formatted remote data centers configuration info.
remoteFilter() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
remoteListen(IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListen(int, long, boolean, IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Adds a message listener for a given topic to all nodes in the cluster group (possibly including this node if it belongs to the cluster group as well).
remoteListenAsync(IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListenAsync(int, long, boolean, IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListenAsync(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Asynchronously adds a message listener for a given topic to all nodes in the cluster group (possibly including this node if it belongs to the cluster group as well).
remoteMessage() - Method in exception org.apache.ignite.plugin.PluginValidationException
 
remoteNodes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a collection of remote grid nodes.
remoteQuery(IgnitePredicate<T>, long, int...) - Method in interface org.apache.ignite.IgniteEvents
Queries nodes in this cluster group for events using passed in predicate filter for event selection.
remoteQueryAsync(IgnitePredicate<T>, long, int...) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously queries nodes in this cluster group for events using passed in predicate filter for event selection.
remoteSnapshotWalSizes(SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Retrieving total segment sizes for remote snapshots.
remoteSnapshotWalSizes(SnapshotPath, long) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Retrieving total segment sizes for a remote snapshot.
remoteTransformer() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
remove(SessionImplementor, 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.HibernateCacheProxy
Removes given key mapping from cache.
remove(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mapping from cache if one exists and value is equal to the passed in value.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate removed object from database but before transaction completed.
remove(SharedSessionContractImplementor, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
remove(K) - Method in interface org.apache.ignite.client.ClientCache
Removes the mapping for a key from this cache if it is present.
remove(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the mapping for a key only if currently mapped to the given value.
remove(Object) - Method in interface org.apache.ignite.client.ClientIgniteSet
remove(K) - Method in interface org.apache.ignite.IgniteCache
remove(K, V) - Method in interface org.apache.ignite.IgniteCache
For CacheAtomicityMode.ATOMIC return value on primary node crash may be incorrect because of the automatic retries.
remove(Object) - Method in interface org.apache.ignite.IgniteQueue
remove(Object) - Method in interface org.apache.ignite.IgniteSet
remove(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
remove(String) - Method in class org.apache.ignite.ml.inference.storage.descriptor.IgniteModelDescriptorStorage
Removes model descriptor for the specified model descriptor.
remove(String) - Method in class org.apache.ignite.ml.inference.storage.descriptor.LocalModelDescriptorStorage
Removes model descriptor for the specified model descriptor.
remove(String) - Method in interface org.apache.ignite.ml.inference.storage.descriptor.ModelDescriptorStorage
Removes model descriptor for the specified model descriptor.
remove(String) - Method in class org.apache.ignite.ml.inference.storage.model.DefaultModelStorage
Removes specified directory or file.
remove(String) - Method in class org.apache.ignite.ml.inference.storage.model.IgniteModelStorageProvider
Removes file or directory associated with the specified path.
remove(String) - Method in class org.apache.ignite.ml.inference.storage.model.LocalModelStorageProvider
Removes file or directory associated with the specified path.
remove(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorage
Removes specified directory or file.
remove(String) - Method in interface org.apache.ignite.ml.inference.storage.model.ModelStorageProvider
Removes file or directory associated with the specified path.
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(K) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Removes the mapping for a key from this cache if it is present.
remove(K) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Removes the mapping for a key from this cache if it is present.
remove(K) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Removes the mapping for a key from this cache if it is present.
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(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes given key mappings from cache.
removeAll() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes mappings from cache.
removeAll(SharedSessionContractImplementor) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
removeAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Removes entries for the specified keys.
removeAll() - Method in interface org.apache.ignite.client.ClientCache
Removes all of the mappings from this cache.
removeAll(Collection<?>) - Method in interface org.apache.ignite.client.ClientIgniteSet
removeAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
/** Removes entries for the specified keys.
removeAll() - Method in interface org.apache.ignite.IgniteCache
Removes all of the mappings from this cache.
removeAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
removeAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
removeAll(Set<? extends K>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Removes entries for the specified keys.
removeAll(Set<? extends K>) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Removes entries for the specified keys.
removeAll(Set<? extends K>) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Removes entries for the specified keys.
removeAllAsync(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mappings from cache for entries.
removeAllAsync() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
removeAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Removes entries for the specified keys.
removeAllAsync() - Method in interface org.apache.ignite.client.ClientCache
Removes all of the mappings from this cache.
removeAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes entries for the specified keys.
removeAllAsync() - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes all of the mappings from this cache.
removeAllConflict(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes DR data.
removeAllConflictAsync(Map) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Removes DR data asynchronously.
removeAppender(FileAppender) - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
Removes file appender.
removeAsync(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mapping from cache.
removeAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously removes given key mapping from cache if one exists and value is equal to the passed in value.
removeAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the mapping for a key only if currently mapped to the given value.
removeAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the mapping for a key only if currently mapped to the given value.
removeAttribute(String) - Method in interface org.apache.ignite.ml.math.MetaAttributes
Removes meta attribute with given name.
removeAttributeListener(ComputeTaskSessionAttributeListener) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Removes given listener.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
removeCheckpoint(String) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Removes previously saved job's state for a given key from an underlying storage.
removeCheckpoint(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
This method allows manually remove the checkpoint with given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeClosedManager(CacheManager) - Method in class org.apache.ignite.cache.CachingProvider
 
removed() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets status of atomic.
removed() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether this set has been removed (ClientIgniteSet.close() was called).
removed() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets status of atomic.
removed() - Method in interface org.apache.ignite.IgniteAtomicReference
Gets status of atomic.
removed() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets status of atomic sequence.
removed() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets status of atomic.
removed() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets removed status of the latch.
removed() - Method in interface org.apache.ignite.IgniteLock
Gets status of reentrant lock.
removed() - Method in interface org.apache.ignite.IgniteQueue
Gets status of queue.
removed() - Method in interface org.apache.ignite.IgniteSemaphore
Gets removed status of the semaphore.
removed() - Method in interface org.apache.ignite.IgniteSet
Gets status of set.
removed() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
removed() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
removeData(K) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds key for removal on remote node.
removeData(Ignite, UUID) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Remove data from local cache by Dataset ID.
removeEldestEntry(Map.Entry<K, V>) - Method in class org.apache.ignite.ml.util.LRUCache
removeField(String) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Removes field from this builder.
removeIncomeConnectionListener(IgniteInClosure<Socket>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
removeLearningEnv(Ignite, UUID) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Remove learning environment from local cache by Dataset ID.
removeListener(IgnitionListener) - Static method in class org.apache.ignite.Ignition
Removes lsnr added by Ignition.addListener(IgnitionListener) method.
removeLocalEventListener(GridLocalEventListener) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes local event listener.
removeLocalMessageListener(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes a previously registered local message listener.
removeMessageListener(GridMessageListener, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
removeMeta() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Removes metadata by name.
removeMeta(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Removes metadata only if its current value is equal to val passed in.
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Removes holder from backed queue and marks holder as removed.
removeMetricRegistry(String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes metric registry with given name.
removeModel(Ignite, String) - Static method in class org.apache.ignite.ml.inference.IgniteModelStorageUtil
Removes model with specified name.
removeNode(UUID) - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.ml.dataset.impl.cache.util.DatasetAffinityFunctionWrapper
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Removes node from affinity.
removeQuery(String, Iterable<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct remove query.
removeQuery(String, Iterable<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct remove query.
removeSendMessageListener(IgniteInClosure<TcpDiscoveryAbstractMessage>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
removeSources() - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
 
removeTimeoutObject(IgniteSpiTimeoutObject) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
removeTimeoutObject(IgniteSpiTimeoutObject) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
removeType(int) - Method in interface org.apache.ignite.IgniteBinary
Remove (de-register) binary type with the specified id.
RendezvousAffinityFunction - Class in org.apache.ignite.cache.affinity.rendezvous
Affinity function for partitioned cache based on Highest Random Weight algorithm.
RendezvousAffinityFunction() - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Empty constructor with all defaults.
RendezvousAffinityFunction(boolean) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Initializes affinity with flag to exclude same-host-neighbors from being backups of each other and specified number of backups.
RendezvousAffinityFunction(boolean, int) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Initializes affinity with flag to exclude same-host-neighbors from being backups of each other, and specified number of backups and partitions.
RendezvousAffinityFunction(int, IgniteBiPredicate<ClusterNode, ClusterNode>) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Initializes optional counts for replicas and backups.
repeat(String, int, String, String, String) - Static method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Concatenates elements using provided delimiter.
replace(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if only if there is a previous mapping for it.
replace(Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Stores given key-value pair in cache only if only if the previous value is equal to the 'oldVal' passed in.
replace(K, V, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to a given value.
replace(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to some value.
replace(K, V, V) - Method in interface org.apache.ignite.IgniteCache
For CacheAtomicityMode.ATOMIC return value on primary node crash may be incorrect because of the automatic retries.
replace(K, V) - Method in interface org.apache.ignite.IgniteCache
replaceAsync(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if only if there is a previous mapping for it.
replaceAsync(Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Asynchronously stores given key-value pair in cache only if only if the previous value is equal to the 'oldVal' passed in.
replaceAsync(K, V, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to a given value.
replaceAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to some value.
replaceAsync(K, V, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronous version of the IgniteCache.replace(Object, Object, Object).
replaceAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously replaces the entry for a key only if currently mapped to a given value.
replaceMeta(T, T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Replaces given metadata with new newVal value only if its current value is equal to curVal.
RepositoryConfig - Annotation Type in org.apache.ignite.springdata22.repository.config
The annotation can be used to pass Ignite specific parameters to a bound repository.
requestedTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
 
RequestEvent - Class in org.apache.ignite.client.events
Base class for request events.
RequestEvent(ConnectionDescription, long, short, String) - Constructor for class org.apache.ignite.client.events.RequestEvent
 
RequestEventListener - Interface in org.apache.ignite.client.events
Listener for request events.
RequestFailEvent - Class in org.apache.ignite.client.events
Event that is fired when a request fails.
RequestFailEvent(ConnectionDescription, long, short, String, long, Throwable) - Constructor for class org.apache.ignite.client.events.RequestFailEvent
 
requestId() - Method in class org.apache.ignite.client.events.RequestEvent
 
requestId() - Method in class org.apache.ignite.events.ServiceEvent
Gets service request ID initiated this service event.
RequestStartEvent - Class in org.apache.ignite.client.events
Event that is fired when a request is started.
RequestStartEvent(ConnectionDescription, long, short, String) - Constructor for class org.apache.ignite.client.events.RequestStartEvent
 
RequestSuccessEvent - Class in org.apache.ignite.client.events
Event that is fired when a request is started.
RequestSuccessEvent(ConnectionDescription, long, short, String, long) - Constructor for class org.apache.ignite.client.events.RequestSuccessEvent
 
reregistered(SchedulerDriver, Protos.MasterInfo) - Method in class org.apache.ignite.mesos.IgniteScheduler
reset() - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.cache.affinity.AffinityKeyMapper
Deprecated.
Resets cache affinity mapper to its initial state.
reset() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Resets cache affinity to its initial state.
reset() - Method in class org.apache.ignite.ml.dataset.impl.cache.util.DatasetAffinityFunctionWrapper
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.mxbean.IoStatisticsMetricsMXBean
Reset all IO statistics.
reset() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Resets this reader.
reset() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Resets this writer.
reset() - Method in interface org.apache.ignite.spi.metric.Metric
Resets metric state.
reset(TracingConfigurationCoordinates) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Reset tracing configuration for the specific tracing coordinates (scope, label, etc.) to default values.
resetAll(Scope) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Reset tracing configuration for the specific scope, or all tracing configurations if scope not specified.
resetLostPartitions(Collection<String>) - Method in interface org.apache.ignite.Ignite
Clears partition's lost state and moves caches to a normal mode.
resetLostPartitions(Collection<String>) - Method in class org.apache.ignite.IgniteSpringBean
Clears partition's lost state and moves caches to a normal mode.
resetMetrics() - Method in interface org.apache.ignite.IgniteCluster
Resets local I/O, job, and task execution metrics.
resetMetrics() - Method in interface org.apache.ignite.IgniteTransactions
Resets transaction metrics.
resetMetrics(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Resets metrics for of a given registry.
resetMetrics(String) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
Resets metrics for of a given registry.
resetMetrics() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Resets metrics for this SPI instance.
resetMetrics() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Resets metrics for this instance.
resetMetrics() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Resets metrics for this SPI instance.
resetMetrics() - Method in interface org.gridgain.grid.GridDr
Reset all sender hub and receiver hub metrics on this node.
resetProbabilitiesSettings() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
Sets default settings equiprobableClasses to false and removes priorProbabilities.
resetQueryDetailMetrics() - Method in interface org.apache.ignite.IgniteCache
Reset query detail metrics.
resetQueryMetrics() - Method in interface org.apache.ignite.IgniteCache
Reset query metrics.
resetRestartingCaches() - Method in interface org.gridgain.grid.persistentstore.SnapshotMXBean
Reset restarting caches.
resetSettings() - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
Sets default settings.
resetThreadedQueryInitiatorId() - Static method in class org.apache.ignite.cache.query.SqlFieldsQuery
Used at the job worker to clear originator for current thread.
resolve(CommunicationFailureContext) - Method in interface org.apache.ignite.configuration.CommunicationFailureResolver
 
resolve(CommunicationFailureContext) - Method in class org.apache.ignite.configuration.DefaultCommunicationFailureResolver
resolve(CacheConflictContext<K, V>) - Method in interface org.gridgain.grid.cache.conflict.CacheConflictResolver
Resolve conflicting key update.
resolve(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Resolves subfile.
resolveAndAcquirePorts(String) - Method in class org.apache.ignite.tensorflow.cluster.util.TensorFlowClusterResolver
Resolves TensorFlow cluster and acquires required ports.
resolveCommunicationFailure(ClusterNode, Exception) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
resolveCommunicationFailure(ClusterNode, Exception) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
resolveCommunicationFailure(ClusterNode, Exception) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
resolveCommunicationFailure(ClusterNode, Exception) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
resolvedAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Resolves addresses registered in the IP finder, removes duplicates and local host address and returns the collection of.
resolveDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Perform dialect resolution.
resolveNodeHash(ClusterNode) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Resolves node hash.
resolveRegularOrCompressed(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Resolves regular or compressed file (zip, zstd, lz4, etc).
resolveSibling(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Resolves file in parent folder.
ResourceHandler - Class in org.apache.ignite.mesos.resource
HTTP controller which provides on slave resources.
ResourceHandler(String, String, String) - Constructor for class org.apache.ignite.mesos.resource.ResourceHandler
 
resourceOffers(SchedulerDriver, List<Protos.Offer>) - Method in class org.apache.ignite.mesos.IgniteScheduler
ResourceProvider - Class in org.apache.ignite.mesos.resource
Provides path to user's libs and config file.
ResourceProvider() - Constructor for class org.apache.ignite.mesos.resource.ResourceProvider
 
resourceUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
 
respond(Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
Responds to the original sender node with given message and continues to listen for the new messages.
respond(UUID, Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
Responds to the provided node with given message and continues to listen for the new messages.
restart(boolean) - Static method in class org.apache.ignite.Ignition
Restarts all started grids.
restart(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Restart JVM.
RESTART_EXIT_CODE - Static variable in class org.apache.ignite.Ignition
This is restart code that can be used by external tools, like Shell scripts, to auto-restart the Ignite JVM process.
restartFuture() - Method in exception org.apache.ignite.IgniteCacheRestartingException
 
restartNodes() - Method in interface org.apache.ignite.IgniteCluster
Restarts nodes satisfying optional set of predicates.
restartNodes(Collection<UUID>) - Method in interface org.apache.ignite.IgniteCluster
Restarts nodes defined by provided IDs.
RestartProcessFailureHandler - Class in org.apache.ignite.failure
This handler could be used only with ignite.
RestartProcessFailureHandler() - Constructor for class org.apache.ignite.failure.RestartProcessFailureHandler
 
restore(RestoreSnapshotParams) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Restores snapshot identified by the given snapshot info.
restoreSnapshot(long, Set<String>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
restoreSnapshot(long, Collection<File>, Set<String>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
restoreSnapshot(long, Collection<File>, Set<String>, IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
restoreSnapshot(long, Collection<File>, Set<String>, boolean, IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>, String) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
RestoreSnapshotParams - Class in org.gridgain.grid.persistentstore
Parameters for restore snapshot operation.
RestoreSnapshotParams() - Constructor for class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
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.
result(ComputeJobResult, List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.CrossOverTask
Default implementation which will wait for all jobs to complete before calling ComputeTask.reduce(List) method.
result(ComputeJobResult, List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.FitnessTask
Default implementation which will wait for all jobs to complete before calling ComputeTask.reduce(List) method.
result(ComputeJobResult, List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.MutateTask
Default implementation which will wait for all jobs to complete before calling ComputeTask.reduce(List) method.
result(ComputeJobResult, List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.RouletteWheelSelectionTask
Default implementation which will wait for all jobs to complete before calling ComputeTask.reduce(List) method.
result(ComputeJobResult, List<ComputeJobResult>) - Method in class org.apache.ignite.ml.genetic.TruncateSelectionTask
Default implementation which will wait for all jobs to complete before calling ComputeTask.reduce(List) method.
resultPolicy() - Method in class org.apache.ignite.events.JobEvent
Gets job result policy.
resultPolicy(ComputeJobResultPolicy) - Method in class org.apache.ignite.events.JobEvent
Sets job result policy.
resume() - Method in interface org.apache.ignite.transactions.Transaction
Resume a transaction if it was previously suspended.
resume() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Starts data center replication for this cache.
resume() - Method in interface org.gridgain.grid.dr.DrSender
Resume replication for all remote DCs.
resume(byte) - Method in interface org.gridgain.grid.dr.DrSender
Resume replication for given DC.
resume() - Method in interface org.gridgain.grid.dr.DrSenderMBean
Resume replication for all remote DCs.
resume(byte) - Method in interface org.gridgain.grid.dr.DrSenderMBean
Resume replication for given DC.
resume(String) - Method in interface org.gridgain.grid.GridDr
Deprecated.
This method actually works same way as GridDr.startReplication(String) and starts replication for given cache.
retainAll(Collection<?>) - Method in interface org.apache.ignite.client.ClientIgniteSet
retainAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
retainAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
retryReadyFuture() - Method in exception org.apache.ignite.cluster.ClusterTopologyException
 
retryReadyFuture(IgniteFuture<?>) - Method in exception org.apache.ignite.cluster.ClusterTopologyException
 
REV_HASH_SIZE - Static variable in class org.apache.ignite.lang.IgniteProductVersion
revisionHash() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision hash.
revisionTimestamp() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision timestamp.
ring(double, double, double) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of 2D-vectors from ring-like distribution.
ring(double, double, double, long) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
Returns vector generator of 2D-vectors from ring-like distribution around zero.
RingsDataStream - Class in org.apache.ignite.ml.util.generators.standard
Represents a data stream of vectors produced by family of ring-like distributions around zero blurred by gauss distribution.
RingsDataStream(int, double, double) - Constructor for class org.apache.ignite.ml.util.generators.standard.RingsDataStream
Create an intance of RingsDataStream.
RingsDataStream(int, double, double, long) - Constructor for class org.apache.ignite.ml.util.generators.standard.RingsDataStream
Create an intance of RingsDataStream.
rmse() - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues
Returns root mean squared error.
rmtAddr() - Method in class org.gridgain.grid.events.DrRemoteDcNodeEvent
Returns remote address of the node in the remote data center.
rocauc() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns ROCAUC value.
ROCAUC - Class in org.apache.ignite.ml.selection.scoring.metric.classification
ROC AUC score calculator.
ROCAUC() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
 
rollback() - Method in interface org.apache.ignite.client.ClientTransaction
Rolls back this transaction.
rollback() - Method in interface org.apache.ignite.transactions.Transaction
Rolls back this transaction.
rollbackAsync() - Method in interface org.apache.ignite.transactions.Transaction
Asynchronously rolls back this transaction.
rollbackTime() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The last time, when transaction was rollbacked.
rollbackTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets last time transaction was rollback.
rollingUpgrade() - Method in interface org.gridgain.grid.GridGain
Gets an instance of Rolling upgrade facade.
RollingUpgradeMXBean - Interface in org.gridgain.grid.ru
This interface defines JMX view on RollingUpgrade.
RootCommand - Class in org.apache.ignite.tensorflow.submitter.command
Root command that aggregates all sub commands.
RootCommand() - Constructor for class org.apache.ignite.tensorflow.submitter.command.RootCommand
 
rotate(double) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Rotate first two components of all vectors of generator by angle around zero.
rotate(double, int, int) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Rotate selected two components of all vectors of generator by angle around zero.
RouletteWheelSelectionJob - Class in org.apache.ignite.ml.genetic
Responsible for performing Roulette Wheel selection
RouletteWheelSelectionJob(Double, LinkedHashMap<Long, Double>) - Constructor for class org.apache.ignite.ml.genetic.RouletteWheelSelectionJob
 
RouletteWheelSelectionTask - Class in org.apache.ignite.ml.genetic
Responsible for performing Roulette Wheel selection.
RouletteWheelSelectionTask(GAConfiguration) - Constructor for class org.apache.ignite.ml.genetic.RouletteWheelSelectionTask
 
RoundRobinLoadBalancingSpi - Class in org.apache.ignite.spi.loadbalancing.roundrobin
This SPI iterates through nodes in round-robin fashion and pick the next sequential node.
RoundRobinLoadBalancingSpi() - Constructor for class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
 
RoundRobinLoadBalancingSpiMBean - Interface in org.apache.ignite.spi.loadbalancing.roundrobin
Management bean for RoundRobinLoadBalancingSpi SPI.
routineId() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
row() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read results set row.
row() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix.Element
Gets element's row index.
ROW_STORAGE_MODE - Static variable in interface org.apache.ignite.ml.math.StorageConstants
Storage mode optimized for row access.
rowCount() - Method in class org.apache.ignite.ml.clustering.gmm.CovarianceMatricesAggregator
 
rowCountForNewCluster() - Method in class org.apache.ignite.ml.clustering.gmm.NewComponentStatisticsAggregator
 
RowIndexException - Exception in org.apache.ignite.ml.math.exceptions
This exception is used to indicate any error condition accessing matrix elements by invalid row index.
RowIndexException(int) - Constructor for exception org.apache.ignite.ml.math.exceptions.RowIndexException
 
rowOffset() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
rowsCount() - Method in class org.apache.ignite.ml.tree.data.TreeDataIndex
 
rowsCount(DecisionTreeData, TreeDataIndex) - Method in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Returns rows count in current dataset.
rowSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets number of rows in this matrix.
rowSize() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets number of rows in this matrix.
rowSize() - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
 
rowSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
rowSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
rowSize() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
rowSize - Variable in class org.apache.ignite.ml.structures.Dataset
Amount of instances.
rowSize() - Method in class org.apache.ignite.ml.structures.Dataset
Gets amount of observation.
rowsLength() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
RPropParameterUpdate - Class in org.apache.ignite.ml.optimization.updatecalculators
Data needed for RProp updater.
RPropParameterUpdate(Vector, Vector, Vector, Vector) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Construct instance of this class by given parameters.
RPropUpdateCalculator - Class in org.apache.ignite.ml.optimization.updatecalculators
Class encapsulating RProp algorithm.
RPropUpdateCalculator(double, double, double) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.RPropUpdateCalculator
Construct RPropUpdateCalculator.
RPropUpdateCalculator() - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.RPropUpdateCalculator
Construct RPropUpdateCalculator with default parameters.
rss() - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues
Returns residual sum of squares.
RULE_xgHeader - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
RULE_xgLeaf - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
RULE_xgModel - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
RULE_xgNode - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
RULE_xgTree - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
RULE_xgValue - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
ruleNames - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Rule names.
ruleNames - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Rule names.
run(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job on a node within the underlying cluster group.
run(Collection<? extends IgniteRunnable>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on grid nodes within the underlying cluster group.
run() - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
The main method for genetic algorithm.
run() - Method in class org.apache.ignite.spi.IgniteSpiThread
run() - Method in class org.apache.ignite.tensorflow.core.nativerunning.task.NativeProcessStartTask
run() - Method in class org.apache.ignite.tensorflow.submitter.command.AttachCommand
run() - Method in class org.apache.ignite.tensorflow.submitter.command.PsCommand
run() - Method in class org.apache.ignite.tensorflow.submitter.command.RootCommand
run() - Method in class org.apache.ignite.tensorflow.submitter.command.StartCommand
run() - Method in class org.apache.ignite.tensorflow.submitter.command.StopCommand
run() - Method in class org.apache.ignite.yarn.ApplicationMaster
Runs application master.
run() - Method in class org.gridgain.grid.persistentstore.snapshot.file.ZipCompressionTask
Deprecated.
runAsync(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job asynchronously on a node within the underlying cluster group.
runAsync(Collection<? extends IgniteRunnable>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on grid nodes within the underlying cluster group.
runIoTest(long, long, int, long, int, int, boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Runs IO latency test against all remote server nodes in cluster.
runLocal(Runnable) - Method in interface org.apache.ignite.IgniteScheduler
Executes given closure on internal system thread pool asynchronously.
runLocal(Runnable, long, TimeUnit) - Method in interface org.apache.ignite.IgniteScheduler
Executes given closure after the delay.
runParallel(LearningEnvironment) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
The main method for genetic algorithm.

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.
sampleSize - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sample size.
SAMPLING_RATE_ALWAYS - Static variable in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
Max valid sampling rate with special meaning that span will be always created.
SAMPLING_RATE_NEVER - Static variable in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
Min valid sampling rate with special meaning that span won't be created.
samplingRate() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
 
SandboxMLCache - Class in org.apache.ignite.ml.util
Common utility code used in some ML examples to set up test cache.
SandboxMLCache(Ignite) - Constructor for class org.apache.ignite.ml.util.SandboxMLCache
 
save(D, P) - Method in interface org.apache.ignite.ml.Exporter
Save model by path p
save(D, String) - Method in class org.apache.ignite.ml.FileExporter
Save model by path p
save(K, S) - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Saves a given entity using provided key.
save(Map<K, S>) - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Saves all given keys and entities combinations.
save(K, S, ExpiryPolicy) - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Saves a given entity using provided key with expiry policy It's suggested to use this method instead of default CrudRepository.save(Object) that generates IDs (keys) that are not unique cluster wide.
save(Map<K, S>, ExpiryPolicy) - Method in interface org.apache.ignite.springdata22.repository.IgniteRepository
Saves all given keys and entities combinations with expiry policy It's suggested to use this method instead of default CrudRepository.save(Object) that generates IDs (keys) that are not unique cluster wide.
save(K, S) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Saves a given entity using provided key.
save(Map<K, S>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Saves all given keys and entities combinations.
save(K, S, ExpiryPolicy) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Saves a given entity using provided key with expiry policy It's suggested to use this method instead of default CrudRepository.save(Object) that generates IDs (keys) that are not unique cluster wide.
save(Map<K, S>, ExpiryPolicy) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Saves all given keys and entities combinations with expiry policy It's suggested to use this method instead of default CrudRepository.save(Object) that generates IDs (keys) that are not unique cluster wide.
save(S) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Not implemented.
SAVE_REGISTRY_ERROR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
Error message when writing snapshot digest registry file.
saveAll(Iterable<S>) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryImpl
Not implemented.
saveAsCsv(Vector, String, String) - Static method in class org.apache.ignite.ml.math.Tracer
Saves given vector as CSV file.
saveAsCsv(Matrix, String, String) - Static method in class org.apache.ignite.ml.math.Tracer
Saves given matrix as CSV file.
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.
saveContext(Ignite, String, int, C) - Static method in class org.apache.ignite.ml.dataset.impl.cache.util.ComputeUtils
Saves the specified partition context into the Ignite Cache.
saveModel(Exporter<KMeansModelFormat, P>, P) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Save model by the given path.
saveModel(Exporter<ModelsCompositionFormat, P>, P) - Method in class org.apache.ignite.ml.composition.ModelsComposition
Save model by the given path.
saveModel(Exporter<D, P>, P) - Method in interface org.apache.ignite.ml.Exportable
Save model by the given path.
saveModel(Ignite, IgniteModel<I, O>, String) - Static method in class org.apache.ignite.ml.inference.IgniteModelStorageUtil
Saved specified model with specified name.
saveModel(Exporter<KNNModelFormat, P>, P) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
 
saveModel(Exporter<KNNModelFormat, P>, P) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Save model by the given path.
saveModel(Exporter<MultiClassModel, P>, P) - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
Save model by the given path.
saveModel(Exporter<DiscreteNaiveBayesModel, P>, P) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesModel
Save model by the given path.
saveModel(Exporter<GaussianNaiveBayesModel, P>, P) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesModel
Save model by the given path.
saveModel(Exporter<LinearRegressionModel, P>, P) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
Save model by the given path.
saveModel(Exporter<LogisticRegressionModel, P>, P) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Save model by the given path.
saveModel(Exporter<SVMLinearClassificationModel, P>, P) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Save model by the given path.
scal(Double, Vector) - Static method in class org.apache.ignite.ml.math.Blas
Performs in-place multiplication of vector x by a real scalar a.
scale() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
scale() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
scanIterator(boolean, IgniteBiPredicate, long) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
scanIterator(boolean, IgniteBiPredicate) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
ScanQuery<K,V> - Class in org.apache.ignite.cache.query
Scan query over cache entries.
ScanQuery() - Constructor for class org.apache.ignite.cache.query.ScanQuery
Create scan query returning all entries.
ScanQuery(int) - Constructor for class org.apache.ignite.cache.query.ScanQuery
Creates partition scan query returning all entries for given partition.
ScanQuery(IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.cache.query.ScanQuery
Create scan query with filter.
ScanQuery(Integer, IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.cache.query.ScanQuery
Create scan query with filter.
scanQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets scan query filter.
scanQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets scan query filter.
ScanQueryView - Class in org.apache.ignite.spi.systemview.view
Scan query iterator representation for a SystemView.
ScanQueryView(UUID, long, boolean, IgniteSpiCloseableIterator<IgniteBiTuple<K, V>>) - Constructor for class org.apache.ignite.spi.systemview.view.ScanQueryView
 
schedule(String) - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Schedule defragmentation for given caches.
scheduleLocal(Runnable, String) - Method in interface org.apache.ignite.IgniteScheduler
Schedules job for execution using local cron-based scheduling.
scheduleLocal(Callable<R>, String) - Method in interface org.apache.ignite.IgniteScheduler
Schedules job for execution using local cron-based scheduling.
scheduler() - Method in interface org.apache.ignite.Ignite
Gets an instance of cron-based scheduler.
scheduler() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of cron-based scheduler.
SchedulerFuture<R> - Interface in org.apache.ignite.scheduler
Future for cron-based scheduled execution.
schema() - Method in class org.apache.ignite.spi.systemview.view.SqlViewView
View schema.
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns schema name.
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlSchemaView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns schema name.
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
Scope - Enum in org.apache.ignite.spi.tracing
Tracing span scope.
scope() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
 
score(Function<IgniteBiPredicate<K, V>, DatasetBuilder<K, V>>, BiFunction<IgniteBiPredicate<K, V>, M, LabelPairCursor<L>>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Computes cross-validated metrics.
score(Iterator<LabelPair<Double>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.AbstractMetrics
Calculates score.
score(Iterator<LabelPair<L>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Accuracy
Calculates score.
score(Iterator<LabelPair<L>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Fmeasure
Calculates score.
score(Iterator<LabelPair<L>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Precision
Calculates score.
score(Iterator<LabelPair<L>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.Recall
Calculates score.
score(Iterator<LabelPair<Double>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Calculates score.
score(Iterator<LabelPair<L>>) - Method in interface org.apache.ignite.ml.selection.scoring.metric.Metric
Calculates score.
scoreAll(Iterator<LabelPair<Double>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.AbstractMetrics
Calculates metrics values.
scoreAll(Iterator<LabelPair<Double>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
Calculates binary metrics values.
scoreAll(Iterator<LabelPair<Double>>) - Method in class org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetrics
Calculates regression metrics values.
scoreByFolds() - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Calculates score by folds.
scoreByFolds() - Method in class org.apache.ignite.ml.selection.cv.CrossValidation
Calculates score by folds.
scoreByFolds() - Method in class org.apache.ignite.ml.selection.cv.DebugCrossValidation
Calculates score by folds.
scorePipeline(Function<IgniteBiPredicate<K, V>, DatasetBuilder<K, V>>, BiFunction<IgniteBiPredicate<K, V>, M, LabelPairCursor<L>>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Computes cross-validated metrics.
searchHistogram(String, ReadOnlyMetricRegistry) - Static method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
Parse attribute name for a histogram and search it's value.
secondModel() - Method in class org.apache.ignite.ml.composition.combinators.sequential.ModelsSequentialComposition
Get second model.
security() - Method in interface org.gridgain.grid.GridGain
Gets an instance of GridSecurity interface.
SecurityBasicPermissionSet - Class in org.apache.ignite.plugin.security
Simple implementation of SecurityPermissionSet interface.
SecurityBasicPermissionSet() - Constructor for class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
 
SecurityCredentials - Class in org.apache.ignite.plugin.security
Security credentials used for node authentication.
SecurityCredentials() - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
Empty constructor required by Externalizable.
SecurityCredentials(String, String) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
Constructs security credentials based on login and password.
SecurityCredentials(String, String, Object) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
Constructs security credentials based on login, password, and custom user object.
SecurityCredentialsBasicProvider - Class in org.apache.ignite.plugin.security
Basic implementation for SecurityCredentialsProvider.
SecurityCredentialsBasicProvider(SecurityCredentials) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentialsBasicProvider
Constructs security credentials provider based on security credentials passed in.
SecurityCredentialsProvider - Interface in org.apache.ignite.plugin.security
Security credentials provider for specifying security credentials.
SecurityException - Exception in org.apache.ignite.plugin.security
Common security exception for the grid.
SecurityException(String, Throwable) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
Constructs security grid exception with given message and cause.
SecurityException(Throwable) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
Creates new security grid exception given throwable as a cause and source of error message.
SecurityException(String) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
Constructs security grid exception with given message.
SecurityPermission - Enum in org.apache.ignite.plugin.security
Supported security permissions within grid.
SecurityPermissionSet - Interface in org.apache.ignite.plugin.security
Security permission set for authorized security subjects.
SecurityPermissionSetBuilder - Class in org.apache.ignite.plugin.security
Provides a convenient way to create a permission set.
SecurityPermissionSetBuilder() - Constructor for class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
SecuritySubject - Interface in org.apache.ignite.plugin.security
Security subject representing authenticated node with a set of permissions.
SecuritySubjectAdapter - Class in org.gridgain.grid.security
Authenticated security subject.
SecuritySubjectAdapter(UUID, SecuritySubjectType, Object, InetSocketAddress, SecurityPermissionSet) - Constructor for class org.gridgain.grid.security.SecuritySubjectAdapter
Deprecated. 
SecuritySubjectAdapter(UUID, SecuritySubjectType, Object, InetSocketAddress, SecurityPermissionSet, Certificate[]) - Constructor for class org.gridgain.grid.security.SecuritySubjectAdapter
SecuritySubjectType - Enum in org.apache.ignite.plugin.security
Supported security subject types.
SegmentationPolicy - Enum in org.apache.ignite.plugin.segmentation
Policy that defines how node will react on topology segmentation.
SegmentationResolver - Interface in org.apache.ignite.plugin.segmentation
This is interface for segmentation (a.k.a "split-brain" problem) resolvers.
SegmentEofException - Exception in org.gridgain.grid.cache.db.wal
This exception is thrown either when we reach the end of file of WAL segment, or when we encounter a record with type equal to 0.
SegmentEofException(String, Throwable) - Constructor for exception org.gridgain.grid.cache.db.wal.SegmentEofException
 
selectBestKChromosome(int) - Method in class org.apache.ignite.ml.util.genetic.Population
Selects the top K chromosomes by fitness value from the smallest to the largest.
SelectionStrategy - Enum in org.apache.ignite.ml.util.genetic
Please, have a look at https://en.wikipedia.org/wiki/Selection_(genetic_algorithm).
selectKDistinct(int, int, Random) - Static method in class org.apache.ignite.ml.util.Utils
Select k distinct integers from range [0, n) with reservoir sampling: https://en.wikipedia.org/wiki/Reservoir_sampling.
selectKDistinct(int, int) - Static method in class org.apache.ignite.ml.util.Utils
Select k distinct integers from range [0, n) with reservoir sampling: https://en.wikipedia.org/wiki/Reservoir_sampling.
self() - Method in class org.apache.ignite.ml.knn.classification.KNNClassificationTrainer
Returns this instance.
self() - Method in class org.apache.ignite.ml.knn.KNNTrainer
Returns this instance.
self() - Method in class org.apache.ignite.ml.knn.regression.KNNRegressionTrainer
Returns this instance.
semaphore(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates semaphore.
semaphore(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates semaphore.
SemaphoreView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteSemaphore representation for a SystemView.
SemaphoreView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
send(ComputeJob, ClusterNode) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends given job to a specific grid node.
send(Map<? extends ComputeJob, ClusterNode>) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends collection of grid jobs to assigned nodes.
send(ComputeJob) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends job to a node automatically picked by the underlying load balancer.
send(Collection<? extends ComputeJob>) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends collection of jobs to nodes automatically picked by the underlying load balancer.
send(Object, Object) - Method in interface org.apache.ignite.IgniteMessaging
Sends given message with specified topic to the nodes in the underlying cluster group.
send(Object, Collection<?>) - Method in interface org.apache.ignite.IgniteMessaging
Sends given messages with the specified topic to the nodes in the underlying cluster group.
send(ClusterNode, Serializable, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Sends a message to a remote node.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sends custom message across the ring.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sends custom message across the ring.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sends custom message across the ring.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sends custom message across the ring.
senderAggregatedInMetrics() - Method in interface org.gridgain.grid.GridDr
Gets sender hub incoming data metrics aggregated across all caches.
senderAggregatedOutMetrics(byte) - Method in interface org.gridgain.grid.GridDr
Gets sender hub outgoing data metrics aggregated across all cache names for the given remote data center ID.
senderAggregatedOutMetrics(String) - Method in interface org.gridgain.grid.GridDr
Gets sender hub outgoing data metrics aggregated across all remote data centers for the given cache name.
senderAggregatedOutMetrics() - Method in interface org.gridgain.grid.GridDr
Gets sender hub outgoing data metrics aggregated across all remote data centers and cache names.
senderCacheMetrics(String) - Method in interface org.gridgain.grid.GridDr
Gets sender cache metrics.
senderCacheStatus(String) - Method in interface org.gridgain.grid.GridDr
Gets data center replication status for particular sender cache.
senderInMetrics(String) - Method in interface org.gridgain.grid.GridDr
Gets sender hub incoming data metrics for specified sender cache.
senderOutMetrics(byte, String) - Method in interface org.gridgain.grid.GridDr
Gets sender hub outgoing data metrics for the given remote data center ID and cache name.
sendMessage(ClusterNode, T) - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Sends given message to destination node.
sendMessage(ClusterNode, Message) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sends given message to destination node.
sendMessage(ClusterNode, Message, IgniteInClosure<IgniteException>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sends given message to destination node.
sendMessage() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
sendOrdered(Object, Object, long) - Method in interface org.apache.ignite.IgniteMessaging
Sends given message with specified topic to the nodes in the underlying cluster group.
sendServerExceptionStackTraceToClient() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Gets a value indicating whether full exception stack trace should be sent to the client.
sendServerExceptionStackTraceToClient(boolean) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
SENT_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by node consistent id metric description.
SENT_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by node consistent id metric name.
SENT_MESSAGES_BY_TYPE_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by type metric description.
SENT_MESSAGES_BY_TYPE_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by type metric name.
SENT_MESSAGES_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages metric description.
SENT_MESSAGES_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages metric name.
sentBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent bytes count.
sentMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent messages counts (grouped by node).
sentMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent messages counts (grouped by type).
sentMessagesByTypeMetricName(Short) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Generate metric name by message direct type id.
sentMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent messages count.
SEQUENTIAL_ACCESS_MODE - Static variable in interface org.apache.ignite.ml.math.StorageConstants
Storage mode optimized for sequential access.
SerializableConsumer<T> - Interface in org.apache.ignite.tensorflow.util
Serializable consumer.
SerializableSupplier<T> - Interface in org.apache.ignite.tensorflow.util
Serializable supplier.
serialize(Object) - Method in class org.apache.ignite.cache.store.cassandra.serializer.JavaSerializer
Serializes object into byte buffer.
serialize(Object) - Method in class org.apache.ignite.cache.store.cassandra.serializer.KryoSerializer
Serializes object into byte buffer.
serialize(Object) - Method in interface org.apache.ignite.cache.store.cassandra.serializer.Serializer
Serializes object into byte buffer.
serialize(Path) - Static method in class org.apache.ignite.ml.inference.util.DirectorySerializer
Serializes directory content.
serialize(T) - Static method in class org.apache.ignite.ml.util.Utils
Serialized the specified object.
serialize(NoopSpiSpecificSpan) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
Serializes span to byte array to send context over network.
serialize(OpenCensusSpanAdapter) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Serializes span to byte array to send context over network.
serialize(S) - Method in interface org.apache.ignite.spi.tracing.TracingSpi
Serializes span to byte array to send context over network.
Serializer - Interface in org.apache.ignite.cache.store.cassandra.serializer
Interface which should be implemented by all serializers responsible for writing/loading data to/from Cassandra in binary (BLOB) format.
SerializeSeparately - Annotation Type in org.apache.ignite.configuration
This annotation is needed to mark fields of CacheConfiguration to serialize them separately during sending over network or storing to disk.
serialVersionUID - Static variable in class org.apache.ignite.ml.preprocessing.encoding.stringencoder.StringEncoderPreprocessor
 
serverKeepBinary(boolean) - Method in interface org.apache.ignite.client.ClientIgniteSet
Sets a value indicating whether user objects should be kept in binary form on the server, or deserialized.
serverKeepBinary() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether user objects should be kept in binary form on the server, or deserialized.
serverNodeId() - Method in class org.apache.ignite.client.events.ConnectionDescription
 
service(String) - Method in interface org.apache.ignite.IgniteServices
Gets locally deployed service with specified name.
Service - Interface in org.apache.ignite.services
An instance of grid-managed service.
ServiceCallContext - Interface in org.apache.ignite.services
Service call context.
ServiceCallContextBuilder - Class in org.apache.ignite.services
Service call context builder.
ServiceCallContextBuilder() - Constructor for class org.apache.ignite.services.ServiceCallContextBuilder
 
serviceClass() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets service class.
serviceClass() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service class.
serviceClass() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
ServiceConfiguration - Class in org.apache.ignite.services
Managed service configuration.
ServiceConfiguration() - Constructor for class org.apache.ignite.services.ServiceConfiguration
 
ServiceContext - Interface in org.apache.ignite.services
Service execution context.
ServiceDeploymentException - Exception in org.apache.ignite.services
Exception indicating service deployment failure.
ServiceDeploymentException(String, Collection<ServiceConfiguration>) - Constructor for exception org.apache.ignite.services.ServiceDeploymentException
Creates service deployment exception with error message.
ServiceDeploymentException(Throwable, Collection<ServiceConfiguration>) - Constructor for exception org.apache.ignite.services.ServiceDeploymentException
Creates service deployment exception with Throwable as a cause.
ServiceDeploymentException(String, Throwable, Collection<ServiceConfiguration>) - Constructor for exception org.apache.ignite.services.ServiceDeploymentException
Creates service deployment exception with error message and Throwable as a cause.
serviceDescriptor(String) - Method in interface org.apache.ignite.client.ClientServices
Gets metadata about deployed services in the grid.
ServiceDescriptor - Interface in org.apache.ignite.services
Service deployment descriptor.
serviceDescriptors() - Method in interface org.apache.ignite.client.ClientServices
Gets metadata about all deployed services in the grid.
serviceDescriptors() - Method in interface org.apache.ignite.IgniteServices
Gets metadata about all deployed services in the grid.
ServiceEvent - Class in org.apache.ignite.events
Grid service event.
ServiceEvent(ClusterNode, String, int, String, String, UUID, UUID) - Constructor for class org.apache.ignite.events.ServiceEvent
Creates service event with given parameters.
serviceId() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
serviceName() - Method in class org.apache.ignite.events.ServiceEvent
Gets name of the service that triggered this event.
servicePermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of service names to service permissions.
servicePermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of service names to service permissions.
serviceProxy(String, Class<? super T>) - Method in interface org.apache.ignite.client.ClientServices
Gets a remote handle on the service.
serviceProxy(String, Class<? super T>, long) - Method in interface org.apache.ignite.client.ClientServices
Gets a remote handle on the service with timeout.
serviceProxy(String, Class<? super T>, boolean) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service.
serviceProxy(String, Class<? super T>, boolean, long) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service with timeout.
serviceProxy(String, Class<? super T>, boolean, ServiceCallContext) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service with the specified caller context.
serviceProxy(String, Class<? super T>, boolean, ServiceCallContext, long) - Method in interface org.apache.ignite.IgniteServices
Gets a remote handle on the service with the specified caller context and timeout.
ServiceResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of Ignite service(s) by specified service name.
services() - Method in interface org.apache.ignite.client.IgniteClient
Gets services facade over all cluster nodes started in server mode.
services(ClientClusterGroup) - Method in interface org.apache.ignite.client.IgniteClient
Gets services facade over nodes within the cluster group.
services() - Method in interface org.apache.ignite.Ignite
Gets services facade over all cluster nodes started in server mode.
services(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets services facade over nodes within the cluster group.
services(String) - Method in interface org.apache.ignite.IgniteServices
Gets all locally deployed services with specified name.
services() - Method in class org.apache.ignite.IgniteSpringBean
Gets services facade over all cluster nodes started in server mode.
services(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets services facade over nodes within the cluster group.
ServiceView - Class in org.apache.ignite.spi.systemview.view
Service representation for a SystemView.
ServiceView(ServiceInfo) - Constructor for class org.apache.ignite.spi.systemview.view.ServiceView
 
ServletContextListenerStartup - Class in org.apache.ignite.startup.servlet
This class defines Ignite startup based on servlet context listener.
ServletContextListenerStartup() - Constructor for class org.apache.ignite.startup.servlet.ServletContextListenerStartup
 
ServletStartup - Class in org.apache.ignite.startup.servlet
This class defines servlet-based Ignite startup.
ServletStartup() - Constructor for class org.apache.ignite.startup.servlet.ServletStartup
 
session(IgniteLogger) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Creates Cassandra session wrapper if it wasn't created yet and returns it
session() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
session() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
 
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
sessionEnd(boolean) - Method in interface org.apache.ignite.cache.store.CacheStore
Deprecated.
Use CacheStoreSessionListener instead (refer to its JavaDoc for details).
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
Default empty implementation for ending transactions.
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Default empty implementation for ending transactions.
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default empty implementation for ending transactions.
sessionEnd(boolean) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
sessionForSnapshotCreation(long, boolean, File, CompressionOption, int, FutureTaskQueue<GroupPartitionId>, SnapshotOperationContext, MessageDigestFactory, SnapshotEncryptionOptions) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Starts a snapshot session.
sessionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
ComputeJobView.sessionId() value equal to the value of ComputeTaskView.sessionId() if both records represents parts of the same computation.
sessionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
ComputeTaskView.sessionId() value equal to the value of ComputeJobView.sessionId() if both records represents parts of the same computation.
SessionPool - Class in org.apache.ignite.cache.store.cassandra.session.pool
Cassandra driver sessions pool.
SessionPool() - Constructor for class org.apache.ignite.cache.store.cassandra.session.pool.SessionPool
 
set(String, ClientCollectionConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Gets a distributed set from cache.
set(String, CollectionConfiguration) - Method in interface org.apache.ignite.Ignite
Will get a named set from cache and create one if it has not been created yet and cfg is not null.
set(T) - Method in interface org.apache.ignite.IgniteAtomicReference
Unconditionally sets the value.
set(T, S) - Method in interface org.apache.ignite.IgniteAtomicStamped
Unconditionally sets the value and the stamp.
set(String, CollectionConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Will get a named set from cache and create one if it has not been created yet and cfg is not null.
set(V1, V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
Sets both values in the tuple.
set(int, int, double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Sets given value.
set(double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix.Element
Sets element's value.
set(int, int, double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Sets given value.
set(int, int, double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
 
set(int, int, double) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
set(int, int, double) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
set(int, int, double) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
set(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Sets value.
set(String, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
Sets element with specified string index and value.
set(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Sets value.
set(String, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.NamedVector
Sets element with specified string index and value.
set(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
set(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
set(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
set(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
set(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector.Element
Sets element's value.
set(int, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Sets value.
set(int, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
 
set(int, double) - Method in class org.apache.ignite.ml.structures.DatasetRow
Sets value.
set(TracingConfigurationCoordinates, TracingConfigurationParameters) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Set new tracing configuration for the specific tracing coordinates (scope, label, etc.).
set1(V1) - Method in class org.apache.ignite.lang.IgniteBiTuple
Sets first value.
set2(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
Sets second value.
setAccountToken(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Specifies the path to the service token file.
setAccountToken(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets timeout for receiving acknowledgement for sent message.
setAclProvider(AuthenticationAclProvider) - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Sets ACL provider.
setActiveJobsThreshold(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Sets number of jobs that can be executed in parallel.
setActiveJobsThreshold(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Sets number of jobs that can be executed in parallel.
setActiveOnStart(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setAddr(InetAddress) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets server address.
setAddress(InetAddress) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Sets target address to check reachability of.
setAddress(InetSocketAddress) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Sets target address to check reachability of.
setAddressAsString(String) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Convenient way to set address.
setAddressAsString(String) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Convenient way to set address.
setAddresses(String...) - Method in class org.apache.ignite.configuration.ClientConfiguration
Set addresses of Ignite server nodes within a cluster.
setAddresses(String...) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets the addresses of the Ignite nodes to connect; address string format: host[:portRangeFrom[..portRangeTo]].
setAddresses(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Parses provided values and initializes the internal collection of addresses.
setAddressesFinder(ClientAddressFinder) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setAddressRequestAttempts(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets number of attempts to send multicast address request.
setAddressResolver(AddressResolver) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets address resolver for addresses mapping determination.
setAddressResolver(AddressResolver) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets address resolver.
setAddressTranslator(AddressTranslator) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets address translator.
setAffinity(AffinityFunction) - Method in class org.apache.ignite.configuration.AtomicConfiguration
Sets atomic cache affinity function.
setAffinity(AffinityFunction) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets affinity for cache keys.
setAffinityAwarenessEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether partition awareness should be enabled.
setAffinityBackupFilter(IgniteBiPredicate<ClusterNode, List<ClusterNode>>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Sets optional backup filter.
setAffinityKey(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets affinity key used for key-to-node affinity calculation.
setAffinityKeyFieldName(String) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
Sets affinity key field name.
setAffinityKeyFieldName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setAffinityMapper(AffinityKeyMapper) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets custom affinity mapper.
setAlias(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets table alias for type.
setAliases(Map<String, String>) - Method in class org.apache.ignite.cache.QueryEntity
Sets mapping from full property name in dot notation to an alias that will be used as SQL column name.
setAllowDuplicateRegistrations(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setAllSegmentationResolversPassRequired(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets all segmentation resolvers pass required flag.
setAlwaysAcceptServerNodes(boolean) - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
If set to true, CertificateAuthenticator will automatically approve all remote nodes and only check thin clients.
setAlwaysWriteFullPages(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag that enforces writing full page to WAL on every change (instead of delta record).
setAlwaysWriteFullPages(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setApplicationAndNode(String, UUID) - Method in class org.apache.ignite.logger.java.JavaLogger
Sets application name and node ID.
setApplicationAndNode(String, UUID) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Sets application name and node ID.
setApplicationAndNode(String, UUID) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Sets application name and node ID.
setApplicationAndNode(String, UUID) - Method in interface org.apache.ignite.logger.LoggerNodeIdAndApplicationAware
Sets application name and node ID.
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.IgniteSpringBean
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.springdata22.repository.support.IgniteRepositoryFactoryBean
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets SQL arguments.
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets SQL arguments.
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets SQL arguments.
setArguments(Object...) - Method in class org.apache.ignite.compute.ComputeJobAdapter
Sets given arguments.
setAssemblies(List<String>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
setAsyncCallbackPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets async callback thread pool size to use within grid.
setAsyncContinuationExecutor(Executor) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the async continuation executor.
setAsyncContinuationExecutor(Executor) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets the continuation executor for cache async APIs.
setAtomicConfiguration(AtomicConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache atomicity mode.
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setAtomicSequenceReserveSize(int) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets default number of sequence values reserved for IgniteAtomicSequence instances.
setAtomicSequenceReserveSize(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
Sets default number of sequence values reserved for IgniteAtomicSequence instances.
setAttribute(Object, Object) - Method in interface org.apache.ignite.compute.ComputeJobContext
Sets an attribute into this job context.
setAttribute(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Sets session attributed.
setAttribute(String, T) - Method in interface org.apache.ignite.ml.math.MetaAttributes
Sets meta attribute with given name and value.
setAttribute(Attribute) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
setAttributes(Map<?, ?>) - Method in interface org.apache.ignite.compute.ComputeJobContext
Sets map of attributes into this job context.
setAttributes(Map<?, ?>) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Sets task attributes.
setAttributes(Map<String, Object>) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
 
setAttributes(AttributeList) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
setAuthenticationEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets flag indicating whether the user authentication is enabled for cluster.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(Authenticator) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets fully configured instance of Authenticator.
setAuthProvider(AuthProvider) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets authentication provider.
setAutoActivationEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setAutoAdjustmentEnabled(boolean) - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
setAutoAdjustmentTimeout(long) - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
setAutoBinaryConfigurationEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether automatic binary configuration retrieval should be enabled.
setAutoCloseServerCursor(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets automatic unsubscribe flag.
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets automatic unsubscribe flag.
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets automatic unsubscribe flag.
setAwaitAcknowledge(boolean) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets await acknowledge flag.
setAwsCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets AWS credentials.
setAwsCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets AWS credentials.
setAwsCredentialsProvider(AWSCredentialsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets AWS credentials provider.
setBackupFilter(IgniteBiPredicate<ClusterNode, ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Deprecated.
Use affinityBackupFilter instead.
setBackups(int) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets the number of backup nodes.
setBackups(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setBackups(int) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setBackups(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setBackups(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets number of nodes used to back up single partition for CacheMode.PARTITIONED cache.
setBackups(int) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setBackupSyncFrequency(long) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets backup part's DR state synchronization frequency.
setBaselineTopology(Collection<? extends BaselineNode>) - Method in interface org.apache.ignite.IgniteCluster
Sets baseline topology.
setBaselineTopology(long) - Method in interface org.apache.ignite.IgniteCluster
Sets baseline topology constructed from the cluster topology of the given version (the method succeeds only if the cluster topology has not changed).
setBasePath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setBatchQueueSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets batch queue size.
setBatchSendFrequency(long) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets batch send frequency.
setBatchSendSize(int) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
setBatchSendSizeBytes(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets batch send size in bytes.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Set maximum batch size for write and delete operations.
setBatchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Set maximum batch size for write and delete operations.
setBatchSize(int) - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
setBestHyperParams(Map<String, Double>) - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
Helper method in cross-validation process.
setBias(int, int, double) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Set the bias of given neuron in given layer.
setBiases(int, Vector) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Sets the biases of layer with a given index.
setBinaryConfiguration(BinaryConfiguration) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setBinaryConfiguration(BinaryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets configuration for Ignite Binary objects.
setBinaryConfiguration(PlatformDotNetBinaryConfiguration) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
setBucketEndpoint(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets bucket endpoint.
setBucketEndpoint(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets bucket endpoint for IP finder.
setBucketName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets Google Cloud Storage bucket name.
setBucketName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets bucket name for IP finder.
setBucketNameSuffix(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets bucket name suffix.
setBucketSize(double) - Method in class org.apache.ignite.ml.dataset.feature.BucketMeta
 
setBucketThresholds(double[][]) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
Sets buckest borders.
setBuffer(ByteBuffer) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Sets but buffer to read from.
setBuffer(ByteBuffer) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Sets but buffer to write to.
setBuildIndexThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets index create/rebuild thread pool size to use within grid.
setCacheConfiguration(CacheConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache configurations.
setCacheKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache key configuration.
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setCacheMetrics(Map<Integer, CacheMetrics>) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Sets node cache metrics.
setCacheMode(CacheMode) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets the cache mode.
setCacheMode(CacheMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets caching mode.
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setCacheName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets associated cache name.
setCacheName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets cache name used for key-to-node affinity calculation.
setCacheName(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Sets cache name to be used by this SPI.
setCacheName(String) - Method in class org.apache.ignite.tensorflow.submitter.command.StartCommand
 
setCacheNames(String...) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
setCachePermissions(Map<String, Collection<SecurityPermission>>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set cache permission map.
setCacheSanityCheckEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache sanity check flag.
setCacheStoreFactory(Factory<? extends CacheStore<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets factory for persistent storage for cache data.
setCacheStoreSessionListenerFactories(Factory<? extends CacheStoreSessionListener>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Cache store session listener factories.
setCacheStoreSessionListenerFactories(Factory<CacheStoreSessionListener>...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Cache store session listener factories.
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setCallbackHandlerFactory(JaasCallbackHandlerFactory) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Sets JAAS-implementation specific callback handler factory.
setCfg(String) - Method in class org.apache.ignite.tensorflow.submitter.command.AbstractCommand
 
setCheckMd5(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
If set to true then SPI should exclude files with same md5s from deployment.
setCheckpointFrequency(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets the checkpoint frequency which is a minimal interval when the dirty pages will be written to the Persistent Store.
setCheckpointFrequency(long) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets checkpoint creation frequency.
setCheckpointingFrequency(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets the checkpointing frequency which is a minimal interval when the dirty pages will be written to the Persistent Store.
setCheckpointingPageBufferSize(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets amount of memory allocated for the checkpointing temporary buffer.
setCheckpointingThreads(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a number of threads to use for the checkpointing purposes.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets the checkpoint listener.
setCheckpointPageBufferSize(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets amount of memory allocated for the checkpoint temporary buffer.
setCheckpointReadLockTimeout(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets timeout for checkpoint read lock acquisition.
setCheckpointReadLockTimeout(long) - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
setCheckpointSpi(CheckpointSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CheckpointSpi.
setCheckpointTableName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint table name.
setCheckpointThreads(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a number of threads to use for the checkpoint purposes.
setCheckpointWriteOrder(CheckpointWriteOrder) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property defines order of writing pages to disk storage during checkpoint.
setCheckpointWriteOrder(CheckpointWriteOrder) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property defines order of writing pages to disk storage during checkpoint.
setChecksum(boolean) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Enables or disables checksum calculation for entries on disk.
setChecksumEnabled(boolean) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Gets checksum enabled flag.
setChromosome(int, Chromosome) - Method in class org.apache.ignite.ml.util.genetic.Population
Sets the chromsome for given index.
setChromosomeCriteria(ChromosomeCriteria) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
set value for ChromosomeCriteria
setChromosomeLen(int) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the Chromsome length
setCipherSuites(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Override default cipher suites.
setCipherSuites(String...) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets enabled cipher suites.
setClassLoader(ClassLoader) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets loader which will be used for instantiating execution context (EntryProcessors, CacheEntryListeners, CacheLoaders and ExpiryPolicys).
setClassName(String) - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Sets class name to use.
setClassNames(Collection<String>) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets class names of binary objects explicitly.
setClient(boolean) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets flag indicating if this is client node context.
setClientConf(ClientConfiguration) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
AWS client configuration.
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.
setClientConnectorConfiguration(ClientConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets client connector configuration.
setClientFailureDetectionTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure detection timeout to use in TcpDiscoverySpi and TcpCommunicationSpi.
setClientMode(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets client mode flag.
setClientMode(boolean) - Static method in class org.apache.ignite.Ignition
Sets client mode thread-local flag.
setClientReconnectDisabled(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets client reconnect disabled flag.
setClientReconnectDisabled(boolean) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets client reconnect disabled flag.
setClusterDiscoveryEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether cluster discovery should be enabled.
setClusterId(UUID) - Method in class org.apache.ignite.tensorflow.submitter.command.AttachCommand
 
setClusterId(UUID) - Method in class org.apache.ignite.tensorflow.submitter.command.StopCommand
 
setClusterProps(ClusterProperties) - Method in class org.apache.ignite.mesos.IgniteScheduler
 
setClusterStateOnStart(ClusterState) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets state of cluster on start.
setCntOfValues(long) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.MeanValueStatistic
 
setCollectMetrix(boolean) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Enables metrics collection.
setCollisionSpi(CollisionSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CollisionSpi.
setCollocated(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets flag defining if this query is collocated.
setCollocated(boolean) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setCollocated(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setCollocated(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets collocated.
setColocated(boolean) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setColumn(int, double[]) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Sets values for given column.
setColumn(int, double[]) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Sets values for given column.
setCommunicationFailureResolver(CommunicationFailureResolver) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setCommunicationSpi(CommunicationSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CommunicationSpi.
setComp(Comparator<EvictableEntry<K, V>>) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
Sets entries comparator.
setCompactBufferSize(int) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets compact buffer size.
setCompactFooter(boolean) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Set whether to write footers in compact form.
setComponentClass(Class<T>) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
setCompression(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets compression algorithm to use for the transport.
setCompressionLevel(int) - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Sets compression level to be used by Zstandard library.
setCompressionLevel(int) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
setCompressionOption(CompressionOption) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
setCompressKeys(boolean) - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Sets flag indicating whether cache keys will be considered for compression.
setConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets the number of concurrent segments in Ignite internal page mapping tables.
setConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets the number of concurrent segments in Ignite internal page mapping tables.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets configuration bean.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Sets Ignite configuration.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets configuration bean.
setConfigurationPath(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets configuration file path.
setConfigurationPath(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets configuration file path.
setConflictResolver(CacheConflictResolver) - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Sets conflict resolver.
setConflictResolverMode(CacheConflictMode) - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Sets conflict resolver mode.
setConnectionConfiguration(DrSenderConnectionConfiguration...) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Set remote data center connection configurations.
setConnectionRecoveryTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets timeout that defines how long server node would try to recovery connection.
setConnectionRequestor(ConnectionRequestor) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets connection URL.
setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets connection URL.
setConnectorConfiguration(ConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setConnectTimeout(int) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Sets connect timeout.
setConsistencyLevel(ConsistencyLevel) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setConsistentId(Serializable) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets consistent globally unique node ID which survives node restarts.
setConsistentId(Serializable) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Sets consistent globally unique node ID which survives node restarts.
setContactPoints(String...) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets list of contact points to connect to Cassandra cluster.
setContext(MarshallerContext) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
Sets marshaller context.
setContext(MarshallerContext) - Method in interface org.apache.ignite.marshaller.Marshaller
Sets marshaller context.
setConverter(SocketMessageConverter<T>) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets message converter.
setCopiedOriginalLabels(double[]) - Method in class org.apache.ignite.ml.tree.data.DecisionTreeData
 
setCopyOnRead(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setCopyOnRead(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets copy on read flag.
setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets create table query.
setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets create table query.
setCredential(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets credential that is used during authentication on the cloud.
setCredentialPath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets the path to a credential that is used during authentication on the cloud.
setCredentials(Credentials) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets credentials to use for authentication.
setCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
AWS credentials.
setCredentialsProvider(AWSCredentialsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Sets AWS credentials provider.
setCredentialsProvider(AWSCredentialsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Sets AWS credentials provider.
setCriteria(IndexQueryCriterion...) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets conjunction (AND) criteria for index query.
setCriteria(List<IndexQueryCriterion>) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets conjunction (AND) criteria for index query.
setCriteria(List<String>) - Method in class org.apache.ignite.ml.genetic.parameter.ChromosomeCriteria
Set criteria
setCrossOverRate(double) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the cross over rate.
setCurator(CuratorFramework) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setCurrentReadClass(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Sets type of message currently read.
setCurrentWriteClass(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Sets type of message currently written.
setDaemon(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets daemon flag.
setDaemon(boolean) - Static method in class org.apache.ignite.Ignition
Sets daemon flag.
setData(Row[]) - Method in class org.apache.ignite.ml.structures.Dataset
 
setDatabaseFieldName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setDatabaseFieldType(int) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setDatabaseSchema(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets database schema name.
setDatabaseTable(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Table name in database.
setDataCenterId(byte) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets data center ID of the grid.
setDataCenterId(byte) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets ID of remote data center.
setDataExchange(DiscoverySpiDataExchange) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataRegionConfigurations(DataRegionConfiguration...) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets data regions configurations.
setDataRegionName(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setDataRegionName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets a name of DataRegionConfiguration for this cache.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Deprecated.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets DataSource to use for database access.
setDataSource(DataSource) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Sets data source.
setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets data source bean name.
setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets name of the data source bean.
setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets name of the data source bean.
setDataSourceFactory(Factory<DataSource>) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets factory for underlying datasource.
setDataStorageConfiguration(DataStorageConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets durable memory configuration.
setDataStreamerThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set thread pool size that will be used to process data stream messages.
setDeadlockTimeout(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
This is an experimental feature.
setDefaultAllowAll(boolean) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set default allow all.
setDefaultDataRegionConfiguration(DataRegionConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Overrides configuration of default data region which is created automatically.
setDefaultFieldValues(Map<String, Object>) - Method in class org.apache.ignite.cache.QueryEntity
Sets fields default values.
setDefaultIdMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultKeepDeserialized(boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Sets default keep deserialized flag.
setDefaultLockTimeout(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setDefaultLockTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets default lock timeout in milliseconds.
setDefaultMemoryPolicyName(String) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets the name for the default memory policy that will initialize the default memory region.
setDefaultMemoryPolicySize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Overrides size of default memory policy which is created automatically.
setDefaultNameMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultPermissions(String) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Sets default permissions for users without principals.
setDefaultPermissionSet(SecurityPermissionSet) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Sets default permission set.
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.SqlConfiguration
Deprecated.
Since 8.7.26. Please use distributed default query timeout.
setDefaultSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultTxConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Sets default transaction concurrency.
setDefaultTxConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction concurrency.
setDefaultTxIsolation(TransactionIsolation) - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Sets default transaction isolation.
setDefaultTxIsolation(TransactionIsolation) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction isolation.
setDefaultTxTimeout(long) - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Sets default transaction timeout in milliseconds.
setDefaultTxTimeout(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction timeout in milliseconds.
setDefaultWarmUpConfiguration(WarmUpConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets default warm-up configuration.
setDefragmentationThreadPoolSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets maximum number of partitions which can be defragmented at the same time.
setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets delete entry query.
setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets delete entry query.
setDelimiter(byte[]) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets message delimiter.
setDeltas(Vector) - Method in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Set previous iteration deltas.
setDeploymentMode(DeploymentMode) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets task classes and resources sharing mode.
setDeploymentSpi(DeploymentSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of DeploymentSpi.
setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Set database dialect.
setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Set database dialect.
setDictionarySize(int) - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Sets dictionary size, in bytes.
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.gridgain.grid.configuration.DrReceiverConfiguration
Sets direct buffer flag in receiver hub's TCP server.
setDirectMode(boolean) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets direct mode flag.
setDirectoryPath(String) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets directory path where persistent store data is to be saved.
setDirectoryPaths(Collection<String>) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets path to a shared directory where checkpoints will be stored.
setDiscoveryPort(int) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Specifies the port which is returned to the caller to use for service discovery.
setDiscoveryPort(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets discovery port for warmup.
setDiscoverySpi(DiscoverySpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of DiscoverySpi.
setDiscoveryStartupDelay(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Not used any more.
setDistributed(boolean) - Method in class org.apache.ignite.ml.structures.Dataset
 
setDistributedJoins(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Specify if distributed joins are enabled for this query.
setDistributedJoins(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Specify if distributed joins are enabled for this query.
setDistributedJoins(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setDistributedJoins(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets distributed joins.
setDrManagementThreadPoolSize(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set thread pool size that will be used to executing internal DR tasks.
setDrReceiverConfiguration(DrReceiverConfiguration) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set data center sender hub configuration.
setDrReceiverEnabled(boolean) - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
setDrSenderConfiguration(CacheDrSenderConfiguration) - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
Sets data center replication send configuration.
setDrSenderConfiguration(DrSenderConfiguration) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set data center receiver hub configuration.
setDrStateTransferThreadPoolSize(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set thread pool size that will be used to executing partition scan tasks for full-state transfer purposes.
setDrStreamerThreadPoolSize(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set thread pool size that will be used to send and receive DR (Data Replication) Streamer messages.
setDrThreadPoolSize(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set thread pool size that will be used to send and receive DR (Data Replication) messages.
setDrUseCacheNames(boolean) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Compatibility flag.
setDynamicCacheConfiguration(CacheConfiguration<Object, Object>) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets dynamic cache configuration template.
setDynamicNearCacheConfiguration(NearCacheConfiguration<Object, Object>) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets dynamic cache configuration template.
setEagerTtl(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setEagerTtl(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eager ttl flag.
setElitismCnt(int) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the elitism count.
setElseNode(DecisionTreeNode) - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
setEmptyPagesPoolSize(int) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Specifies the minimal number of empty pages to be present in reuse lists for this data region.
setEmptyPagesPoolSize(int) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Specifies the minimal number of empty pages to be present in reuse lists for this memory policy.
setEncodeUri(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Indicates that URI must be encoded before usage.
setEncryptionConfiguration(EncryptionConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets encryption configuration.
setEncryptionEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets encrypted flag.
setEncryptionService(EncryptionService) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets encryption service for client side node address encryption.
setEncryptionSpi(EncryptionSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of EncryptionSpi.
setEndpointAddress(String) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Set ODBC endpoint address.
setEnforceJoinOrder(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets flag to enforce join order of tables in the query.
setEnforceJoinOrder(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setEnforceJoinOrder(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets enforce join order.
setEntryCompressionConfiguration(EntryCompressionConfiguration) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets compression configuration to be used to compress entries.
setEntryFilter(CacheDrEntryFilter) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Set entry filter.
setEnum(boolean) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets whether this is enum type.
setEnum(boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Sets whether this is enum type.
setEnumValues(Map<String, Integer>) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Set enum ordinal to names mapping.
setEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.pipeline.Pipeline
Set learning environment builder.
setEventListeners(EventListener...) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setEventsDisabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets events disabled flag.
setEventStorageSpi(EventStorageSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of EventStorageSpi.
setEvictionFilter(EvictionFilter<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eviction filter.
setEvictionPolicy(EvictionPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
setEvictionPolicyFactory(Factory<? extends EvictionPolicy<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache eviction policy factory.
setEvictionThreshold(double) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory pages eviction threshold.
setEvictionThreshold(double) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory pages eviction threshold.
setExcludeNeighbors(boolean) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Sets flag to exclude same-host-neighbors from being backups of each other (default is false).
setExecutorConfiguration(ExecutorConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets custom executors for user compute tasks.
setExpireAgeMs(long) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets events expiration time.
setExpireCount(long) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets events queue size.
setExpireDateFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint expiration date field name.
setExpireDateFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint expiration date field type.
setExpiryPolicy(ExpiryPolicy) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setExportFilter(Predicate<ReadOnlyMetricRegistry>) - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
Sets export filter.
setExportFilter(Predicate<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.metric.MetricExporterSpi
Sets export filter.
setExportFilter(Predicate<ReadOnlyMetricRegistry>) - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
Sets export filter.
setExportFilter(Predicate<SystemView<?>>) - Method in interface org.apache.ignite.spi.systemview.SystemViewExporterSpi
Sets export filter.
setExternalCollisionListener(CollisionExternalListener) - Method in interface org.apache.ignite.spi.collision.CollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setFailoverSpi(FailoverSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of FailoverSpi.
setFailureDetectionTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure detection timeout to use in TcpDiscoverySpi and TcpCommunicationSpi.
setFailureHandler(FailureHandler) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure handler.
setFetchSize(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets number of rows to immediately fetch in CQL statement execution.
setFetchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Sets fetch size.
setField(String, Object) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Sets field value.
setField(String, T, Class<? super T>) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Sets field value with value type specification.
setField(String, BinaryObjectBuilder) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Sets field value.
setFieldNames(Collection<String>, boolean) - Method in class org.apache.ignite.cache.QueryIndex
Sets a collection of field names altogether with the field sorting direction.
setFields(LinkedHashMap<String, String>) - Method in class org.apache.ignite.cache.QueryEntity
Sets query fields for this query pair.
setFields(LinkedHashMap<String, Boolean>) - Method in class org.apache.ignite.cache.QueryIndex
Sets fields included in the index.
setFieldsPrecision(Map<String, Integer>) - Method in class org.apache.ignite.cache.QueryEntity
Sets fieldsPrecision map for a fields.
setFieldsScale(Map<String, Integer>) - Method in class org.apache.ignite.cache.QueryEntity
Sets fieldsScale map for a fields.
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JDailyRollingFileAppender
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JExternallyRolledFileAppender
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JFileAppender
setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
setFileIOFactory(FileIOFactory) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets factory to provide implementation of FileIO interface which is used for data storage files read/write operations
setFileIOFactory(FileIOFactory) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets remote cache entries filter.
setFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets filter.
setFilter(IgnitePredicate<Event>) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets filter for events to be recorded.
setFitness(Double) - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Sets the fitness value.
setFitness(Integer, Double) - Method in class org.apache.ignite.ml.util.genetic.Population
Sets the fitness value for chromosome with the given index.
setFitnessFunction(IFitnessFunction) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set IFitnessFunction
setFitnessScore(double) - Method in class org.apache.ignite.ml.genetic.Chromosome
Set the fitnessScore for this chromosome
setFlushFrequency(long) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets data flush frequency.
setFlushFrequency(long) - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
setForceFieldsQuery(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets force fields query.
setForceServerMode(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Deprecated.
Will be removed at 3.0.
setFs(FileSystem) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets file system.
setFsyncDelay(long) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets maximum delay in milliseconds after which fsync will be issued after a write to a file.
setFullStateTransferBufferSize(long) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets global DR full state transfer buffer size.
setGene(int, double) - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Sets gene value by index.
setGenePool(List<Gene>) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the gene pool.
setGenes(long[]) - Method in class org.apache.ignite.ml.genetic.Chromosome
Set the gene keys (ie: primary keys)
setGlobalNodeAuthentication(boolean) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Sets global node authentication flag.
setGridCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets number of grids to start and run the warmup.
setGridLogger(IgniteLogger) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets logger to use within grid.
setGridName(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
setGridName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setGridName(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
setGridStartTime(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets grid start time.
setGridStartTime(long) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets grid start time.
setGroupName(String) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets the cache group name.
setGroupName(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setGroupName(String) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setGroupName(String) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setGroupName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets the cache group name.
setGroupName(String) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setHandshakeTimeout(long) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets handshake timeout for client connections.
setHasher(JdbcTypeHasher) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets hash code calculator.
setHasher(JdbcTypeHasher) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets hash code calculator.
setHealthCheckFrequency(long) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets health check frequency.
setHeartbeatEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether heartbeats are enabled.
setHeartbeatInterval(long) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the heartbeat message interval, in milliseconds.
setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Sets hibernate configuration path.
setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
Sets hibernate configuration path.
setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
Sets hibernate configuration path.
setHibernateProperties(Properties) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Sets Hibernate properties.
setHibernateProperties(Properties) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
Sets Hibernate properties.
setHost(String) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set host.
setHost(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets host for TCP binary protocol server.
setHost(String) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set host.
setHost(String) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Convenient way to set address.
setIdempotent(Boolean) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setIdentity(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets the identity that is used as a user name during a connection to the cloud.
setIdleQueryCursorCheckFrequency(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle query cursor check frequency.
setIdleQueryCursorTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle query cursors timeout.
setIdleTimeout(long) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets idle timeout for client connections.
setIdleTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle timeout for REST server.
setIdleTimeout(long) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets idle timeout for receiver hub's TCP server connection.
setIdMapper(BinaryIdMapper) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets ID mapper.
setIdMapper(BinaryIdMapper) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets ID mapper.
setIdMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setIgnite(Ignite) - Method in class org.apache.ignite.stream.StreamAdapter
 
setIgniteHome(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite installation folder.
setIgniteInstanceName(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
Sets Ignite instance name.
setIgniteInstanceName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets node name.
setIgniteInstanceName(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets Ignite instance name.
setIgnoredDataCenterIds(byte...) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets ignored data center IDs.
setIgnoredFailureTypes(Set<FailureType>) - Method in class org.apache.ignite.failure.AbstractFailureHandler
Sets failure types that must be ignored by failure handler.
setImpurity(double) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
setIncludeEventTypes(int...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets array of event types, which will be recorded by GridEventStorageManager.record(Event).
setIncludeExpired(boolean) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets the flag value defining whether to notify about EventType.EXPIRED events.
setIncludeNotReadyAddresses(boolean) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Determines whether addresses of not-ready pods should be included.
setIncludeProperties(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets array of system or environment property names to include into node attributes.
setIncrementalDrPoolSize(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set thread pool size that will be used to executing partition scan tasks for incremental replication purposes.
setIndexedTypes(Class<?>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Array of key and value type pairs to be indexed (thus array length must be always even).
setIndexes(Collection<QueryIndex>) - Method in class org.apache.ignite.cache.QueryEntity
Sets a collection of index entities.
setIndexingSpi(IndexingSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of IndexingSpi.
setIndexType(QueryIndexType) - Method in class org.apache.ignite.cache.QueryIndex
Sets index type.
setInitialContextEnvironment(Map<?, ?>) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Sets initial context environment map that will be used in InitialContext.InitialContext(Hashtable) constructor.
setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets initial query.
setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets initial query.
setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets initial query.
setInitialSize(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets initial memory region size defined by this data region.
setInitialSize(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets initial memory region size defined by this memory policy.
setInitSchema(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInitSchema(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInitSchema(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInlineSize(int) - Method in class org.apache.ignite.cache.QueryIndex
Sets index inline size in bytes.
setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets insert entry query.
setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets insert entry query.
setInterceptor(CacheInterceptor<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache interceptor.
setInternalListener(IgniteDiscoverySpiInternalListener) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
For TESTING only.
setInternalListener(IgniteDiscoverySpiInternalListener) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
For TESTING only.
setInternalListener(IgniteDiscoverySpiInternalListener) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
For TESTING only.
setInteropConfiguration(InteropConfiguration) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets interop configuration.
setInvalidate(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets invalidation flag for near cache entries in this transaction.
setIpFinder(TcpDiscoveryIpFinder) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets IP finder for IP addresses sharing and storing.
setIpFinderCleanFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets IP finder clean frequency in milliseconds.
setIterationCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets iteration count for warmup.
setJavaFieldName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setJavaFieldType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setJdbcEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether access through JDBC is enabled.
setJettyPath(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets path, either absolute or relative to IGNITE_HOME, to JETTY XML configuration file.
setJmxReporting(boolean) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Enables JMX reporting of the metrics.
setJndiNames(String...) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Sets JNDI names used by this TM factory.
setJndiNames(List<String>) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
Sets a list of JNDI names used by this TM.
setJobArguments(String[]) - Method in class org.apache.ignite.tensorflow.submitter.command.StartCommand
 
setJobCmd(String) - Method in class org.apache.ignite.tensorflow.submitter.command.StartCommand
 
setJobFolder(String) - Method in class org.apache.ignite.tensorflow.submitter.command.StartCommand
 
setJobPriorityAttributeKey(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets job priority attribute key.
setJoinTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets join timeout.
setJoinTimeout(long) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setKeepBinary(boolean) - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Sets a value indicating whether platform cache should store keys and values in binary form.
setKeepDeserialized(Boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Sets keep deserialized flag.
setKey(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
setKeyAlgorithm(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key manager algorithm that will be used to create a key manager.
setKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache key configuration.
setKeyFieldName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets key field name.
setKeyFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint key field name.
setKeyFields(Set<String>) - Method in class org.apache.ignite.cache.QueryEntity
Gets query fields for this query pair that belongs to the key.
setKeyFields(JdbcTypeField...) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets optional persistent key fields (needed only if CacheJdbcPojoStore is used).
setKeyFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint key field type.
setKeyId(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
Set the KMS key id used to encrypt/decrypt the data.
setKeyPair(KeyPair) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionService
Set the public private key pair.
setKeyPath(String) - Method in class org.gridgain.grid.configuration.SftpConfiguration
Sets path to JKS key in builder style.
setKeyPrefix(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
This can be thought of as the sub-folder within the bucket that will hold the node addresses.
setKeyRange(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets key range.
setKeySize(int) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets encryption key size.
setKeyStoreFilePath(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets path to the key store file.
setKeyStorePassword(char[]) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets password to access KeyStore.
setKeyStorePassword(char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key store password.
setKeyStorePath(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets path to jdk keyStore that stores master key.
setKeyStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key store type used in context initialization.
setKeyType(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets key type for this query pair.
setKeyType(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets key type.
setKeyType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets key type.
setKeyTypeName(String) - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Sets fully-qualified platform type name of the cache key used for the local map.
setLabel(L) - Method in class org.apache.ignite.ml.structures.LabeledVector
Set the label
setLabel(int, double) - Method in class org.apache.ignite.ml.structures.LabeledVectorSet
Fill the label with given value.
setLateAffinityAssignment(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Starting from Ignite 2.1 late affinity assignment is always enabled.
setLazy(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets lazy query execution flag.
setLazy(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setLazy(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets lazy.
setLazyBinaryMetadataRegistration(boolean) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets register metadata mode: - true metadata is registered on the received cluster only when data that is replicated; - false all metadata received from the master cluster are registered.
setLazyMemoryAllocation(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets lazyMemoryAllocation flag value.
setLevel(Level) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Sets level for internal log4j implementation.
setLicenseUrl(String) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets license URL different from the default location of the license file.
setLifecycleBeans(LifecycleBean...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets a collection of lifecycle beans.
setLimit(int) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets limit to response records count.
setLimit(int) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets limit to response records count for TextQuery.
setListener(CommunicationListener<T>) - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Set communication listener.
setListener(CommunicationListener<Message>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
setListener(DeploymentListener) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Sets or unsets deployment event listener.
setListener(DeploymentListener) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Sets or unsets deployment event listener.
setListener(DeploymentListener) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets or unsets deployment event listener.
setListener(DiscoverySpiListener) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Deprecated.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets a listener for discovery events.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets a listener for discovery events.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets a listener for discovery events.
setLivenessCheckEnabled(boolean) - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
setLoadBalancerName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Sets AWS Classic load balancer name which nodes are plugged under it.
setLoadBalancingMode(DrSenderLoadBalancingMode) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets sender hub load balancing mode.
setLoadBalancingMode(DrReceiverLoadBalancingMode) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets remote receiver hub load balancing policy.
setLoadBalancingPolicy(LoadBalancingPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets load balancing policy.
setLoadBalancingSpi(LoadBalancingSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of LoadBalancingSpi.
setLoadPreviousValue(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setLoadProbe(AdaptiveLoadProbe) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Sets implementation of node load probe.
setLoadQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets load query.
setLoadQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets load query.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets whether this query should be executed on a local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.Query
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.TextQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets local.
setLocalAddress(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets local host address used by this IP finder.
setLocalAddress(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets local host IP address that discovery SPI uses.
setLocalAddress(InetAddress) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Sets local address.
setLocalAddressAsString(String) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Convenient way to set local address.
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.
setLocalInboundHost(String) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets local host name receiver hub TCP server is bound to.
setLocalInboundPort(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets local port receiver hub TCP server is bound to.
setLocalListener(CacheEntryUpdatedListener<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets a local callback.
setLocalListener(ContinuousQueryWithTransformer.EventListener<T>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets local callback.
setLocalOutboundAddress(String) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets local outbound address.
setLocalOutboundHost(String) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
setLocalPort(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets local port to listen to.
setLocalPort(int) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Sets local port.
setLocalPortRange(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Range for local ports.
setLocksCount(int) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
 
setLockWaitTime(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Timeout in milliseconds to wait when acquiring persistence store lock file before failing the local node.
setLockWaitTime(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Time out in milliseconds to wait when acquiring persistence store lock file before failing the local node.
setLocScores(double[]) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation.TaskResult
 
setLog(IgniteLogger) - Method in class org.apache.ignite.ml.FileExporter
 
setLogger(IgniteLogger) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the logger.
setLogin(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets login.
setLoginContextName(String) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Sets new login context name.
setLoginContextName(String) - Method in interface org.gridgain.grid.security.jaas.JaasAuthenticatorMBean
Sets new login context name.
setLoginTimeout(int) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
setLogWriter(PrintWriter) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
setLongOperationsDumpTimeout(long) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Setting a timeout (in millis) for printing to log long-running transactions as well as transactions that cannot receive locks for all their keys for a long time.
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets timeout in milliseconds after which long query warning will be printed.
setLongTransactionTimeDumpThreshold(long) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets threshold timeout in milliseconds for long transactions, if transaction exceeds it, it will be dumped in log with information about how much time did it spent in system time (time while aquiring locks, preparing, commiting, etc.)
setLowerCase(boolean) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Sets whether to use strings in lower case or not.
setManagementEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setManagementThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets management thread pool size to use within grid.
setMapCapacity(int) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets initial internal hash map capacity.
setMapSegments(int) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets number of map segments.
setMarshaller(Marshaller) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Since 2.1. Some Ignite features will not work if non-null marshaller is set (IgniteCache.withKeepBinary(), .NET, CPP, ODBC)
setMarshalLocalJobs(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets marshal local jobs flag.
setMasterKeyName(String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Sets master key Name that will be used for keys encryption in EncryptionSpi.encryptKey(Serializable) and EncryptionSpi.decryptKey(byte[]) methods and in the EncryptionSpi.masterKeyDigest() method.
setMasterKeyName(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets master key Name that will be used for keys encryption in EncryptionSpi.encryptKey(Serializable) and EncryptionSpi.decryptKey(byte[]) methods and in the EncryptionSpi.masterKeyDigest() method.
setMasterKeyName(String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Sets master key Name that will be used for keys encryption in EncryptionSpi.encryptKey(Serializable) and EncryptionSpi.decryptKey(byte[]) methods and in the EncryptionSpi.masterKeyDigest() method.
setMasterUrl(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Sets the host name of the Kubernetes API server.
setMasterUrl(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setMaxAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets maximum timeout for receiving acknowledgement for sent message.
setMaxActiveComputeTasksPerConnection(int) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Sets active compute tasks per connection limit.
setMaxActiveTxPerConnection(int) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Sets active transactions count per connection limit.
setMaxBackupQueueSize(int) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets maximum size of backup entries queue.
setMaxBatches(int) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets maximum amount of batches awaiting for sender hub acknowledge.
setMaxConcurrentAsyncOperations(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setMaxConcurrentAsyncOperations(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of concurrent asynchronous operations.
setMaxConnectionsPerNode(int) - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Sets maximum allowed number of active client connections per node.
setMaxDepth(int) - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Set up the max depth.
setMaxDepth(int) - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Set up the max depth.
setMaxErrors(int) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets maximum amount of sequential errors in receiver hub responses.
setMaxFailedConnectAttempts(int) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Set maximum failed connect attempts.
setMaxFilesCount(int) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets maximum amount of files files which can be used to store data.
setMaxFileSize(long) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets maximum size of each file where data is stored in bytes.
setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Sets maximum number of attempts to execute a failed job on another node.
setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Sets maximum number of attempts to execute a failed job on another node.
setMaximumPoolSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Set Max workers thread count.
setMaximumPoolSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Set Maximum workers thread count.
setMaximumStealingAttempts(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets maximum number of attempts to steal job by another node.
setMaximumStealingAttempts(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets maximum number of attempts to steal job by another node.
setMaximumWriteAttempts(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets maximum number of write attempts in case of database error.
setMaximumWriteAttempts(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets maximum number of write attempts in case of database error.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Sets maximum allowed cache size in bytes.
setMaxOpenCursors(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets maximum number of opened cursors per connection.
setMaxOpenCursorsPerConnection(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets maximum number of opened cursors per connection.
setMaxOpenCursorsPerConnection(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets maximum number of opened cursors per connection.
setMaxParameterCount(int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Set max query parameters count.
setMaxPerNodeCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets maximum number of deployed service instances on each node, 0 for unlimited.
setMaxPoolSize(int) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Set Maximum workers thread count.
setMaxQueryIteratorsCount(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setMaxQueryIteratorsCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of query iterators that can be stored.
setMaxQueueSize(int) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets maximum wait queue size.
setMaxSchemaAgreementWaitSeconds(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets maximum time to wait for schema agreement before returning from a DDL query.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets maximum memory region size defined by this data region.
setMaxSize(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets maximum memory region size defined by this memory policy.
setMaxSize(int) - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Sets maximum number of entries can be stored.
setMaxSparsity(float) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets maximum allowed file sparsity above which compaction has to start.
setMaxWalArchiveSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a max allowed size(in bytes) of WAL archives.
setMBeanServer(MBeanServer) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets initialized and started MBean server.
setMdlDescStorageBackups(Integer) - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
setMdlStorageBackups(Integer) - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
setMemoryAllocator(MemoryAllocator) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory allocator.
setMemoryAllocator(MemoryAllocator) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets default memory allocator for all memory regions.
setMemoryConfiguration(MemoryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
setMemoryPolicies(MemoryPolicyConfiguration...) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets memory policies configurations.
setMemoryPolicyName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
setMessageDigestFactory(MessageDigestFactory) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Allows to plug in a custom factory of MessageDigest objects to control the integrity of snapshot files.
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.gridgain.grid.configuration.DrReceiverConfiguration
Sets message queue limit for incoming and outgoing messages in receiver hub's TCP server.
setMeta(FeatureMetadata[]) - Method in class org.apache.ignite.ml.structures.Dataset
 
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.
setMetricExporterSpi(MetricExporterSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of MetricExporterSpi.
setMetricRegistry(ReadOnlyMetricManager) - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
Sets metrics registry that SPI should export.
setMetricRegistry(ReadOnlyMetricManager) - Method in interface org.apache.ignite.spi.metric.MetricExporterSpi
Sets metrics registry that SPI should export.
setMetricRegistry(ReadOnlyMetricManager) - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
Sets metrics registry that SPI should export.
setMetrics(ClusterMetrics) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Sets node metrics.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory metrics enabled flag.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag indicating whether persistence metrics collection is enabled.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory metrics enabled flag.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets flag indicating whether persistence metrics collection is enabled.
setMetricsExpireTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets time in milliseconds after which a certain metric value is considered expired.
setMetricsHistorySize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets number of metrics kept in history to compute totals and averages.
setMetricsLogFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets frequency of metrics log print out.
setMetricsProvider(DiscoveryMetricsProvider) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets discovery metrics provider.
setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets discovery metrics provider.
setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets discovery metrics provider.
setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets discovery metrics provider.
setMetricsRateTimeInterval(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
setMetricsRateTimeInterval(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
setMetricsSubIntervalCount(int) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
setMetricsSubIntervalCount(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
setMetricsUpdateFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite metrics update frequency in milliseconds.
setMinCompactSize(long) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets minimum file size for compaction.
setMinImpurityDecrease(double) - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Set up the min impurity decrease.
setMinImpurityDecrease(double) - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Set up the min impurity decrease.
setMinVal(double) - Method in class org.apache.ignite.ml.dataset.feature.BucketMeta
 
setMinWalArchiveSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a min allowed size(in bytes) of WAL archives.
setMissingNode(DecisionTreeNode) - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
setModelsComposition(ModelsComposition) - Method in class org.apache.ignite.ml.xgboost.XGModelComposition
 
setMulticastGroup(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets IP address of multicast group.
setMulticastPort(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets port number which multicast messages are sent to.
setMultipleTupleExtractor(StreamMultipleTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
 
setMutationRate(double) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the mutation rate.
setMvccVacuumFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
setMvccVacuumThreadCount(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
setName(String) - Method in class org.apache.ignite.cache.QueryIndex
Sets index name.
setName(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache name.
setName(String) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets data region name.
setName(String) - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Set thread pool name.
setName(String) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory policy name.
setName(String) - Method in class org.apache.ignite.ml.structures.FeatureMetadata
 
setName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Sets SPI name.
setNameMapper(BinaryNameMapper) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets name mapper.
setNameMapper(BinaryNameMapper) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets name mapper.
setNameMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setNamespace(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Sets the namespace the Kubernetes service belongs to.
setNamespace(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setNearConfiguration(NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets the near cache configuration to use on all cache nodes.
setNearEvictionPolicy(EvictionPolicy<K, V>) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
setNearEvictionPolicyFactory(Factory<? extends EvictionPolicy<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Sets cache eviction policy factory.
setNearStartSize(int) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Start size for near cache.
setNeedClientAuth(boolean) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets whether SSL needs client authentication.
setNettyOptions(NettyOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets netty options to use.
setNetworkCompressionLevel(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Compression level for internal network messages.
setNetworkInterface(NetworkInterface) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
In case address is bound to several interfaces this method should be used to explicitly provide necessary interface.
setNetworkInterfaceAddress(InetAddress) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Sets network interface address to check reachability through.
setNetworkInterfaceAddressAsString(String) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Convenient way to set network interface address.
setNetworkSendRetryCount(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets message send retries count.
setNetworkSendRetryDelay(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets interval in milliseconds between message send retries.
setNetworkTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Maximum timeout in milliseconds for network requests.
setNetworkTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets maximum network timeout to use for network operations.
setNmClient(NMClient) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets NMClient.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets filter which determines on what nodes the cache should be started.
setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets node filter used to filter nodes on which the service will be deployed.
setNodeId(UUID) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setNodeId(UUID) - Method in interface org.apache.ignite.logger.LoggerNodeIdAndApplicationAware
Sets node ID.
setNodeId(UUID) - Method in interface org.apache.ignite.logger.LoggerNodeIdAware
Deprecated.
Sets node ID.
setNoDelay(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets whether TCP_NODELAY option should be set for all accepted client connections.
setNodeName(Marshaller, String) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Set node name to marshaller context if possible.
setNodeWeight(int) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Sets weight of this node.
setNotNullFields(Set<String>) - Method in class org.apache.ignite.cache.QueryEntity
Sets names of fields that must checked for null.
setNumberOfRetries(int) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets number of retries in case of any database errors.
setOdbcConfiguration(OdbcConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setOdbcEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether access through ODBC is enabled.
setOffHeapMaxMemory(long) - Method in class org.apache.ignite.configuration.CollectionConfiguration
Deprecated.
No longer used.
setOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Configures on-heap cache for the off-heap based page memory.
setOutgoingPayload(Map<String, ByteBuffer>) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setOverflowCallback(IgniteRunnable) - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Sets overflow callback.
setOverflowMode(DrSenderStoreOverflowMode) - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Sets overflow mode defining how store will behave in case of overflow.
setOverflowMode(DrSenderStoreOverflowMode) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets overflow mode defining how store will behave in case of overflow.
setOverflowMode(DrSenderStoreOverflowMode) - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Sets overflow mode defining how store will behave in case of overflow.
setPageEvictionMode(DataPageEvictionMode) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory pages eviction mode.
setPageEvictionMode(DataPageEvictionMode) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory pages eviction mode.
setPageReplacementMode(PageReplacementMode) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory pages replacement mode.
setPageSize(int) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.Query
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.TextQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Changes the page size.
setPageSize(int) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Changes the page size.
setParallelJobsNumber(int) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Sets number of jobs that can be executed in parallel.
setParallelJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Sets number of jobs that can be executed in parallel.
setParallelJobsNumber(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets number of jobs that can be executed in parallel.
setParallelJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets number of jobs that can be executed in parallel.
setParallelLoadCacheMinimumThreshold(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Parallel load cache minimum row count threshold.
setParallelLoadCacheMinimumThreshold(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Parallel load cache minimum row count threshold.
setParameters(Vector) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Set parameters.
setParamMap(Map<String, Double>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation.TaskResult
 
setPartition(Integer) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets partition number over which this query should iterate.
setPartition(Integer) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets partition number over which this query should iterate.
setPartitionLossPolicy(PartitionLossPolicy) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setPartitionLossPolicy(PartitionLossPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets partition loss policy.
setPartitions(int) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Sets total number of partitions.If the number of partitions is a power of two, the PowerOfTwo hashing method will be used.
setPartitions(int...) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets partitions for a query.
setPartitions(int...) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets partitions for a query.
setParts(int[]) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets parts.
setPassphrase(String) - Method in class org.gridgain.grid.configuration.SftpConfiguration
Sets passphrase for JKS key in builder style.
setPassword(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets password to use for authentication.
setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets password for database access.
setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets password for database access.
setPassword(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setPassword(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets password.
setPath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Sets path.
setPath(String) - Method in class org.gridgain.grid.segmentation.sharedfs.SharedFsSegmentationResolver
Sets path to shared folder.
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.
setPermissions(Map<? extends IgnitePredicate<Certificate[]>, SecurityPermissionSet>) - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
Sets mapping of certificate predicates to permissions.
setPermissionsJson(Map<P, String>) - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
Sets mapping of certificate predicates to permissions.
setPermissionsProvider(JaasPermissionsProvider) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Set permissions provider.
setPerNodeBufferSize(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets per-node data buffer size.
setPerNodeParallelLoadOperations(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets per-node parallel load operations.
setPersistenceEnabled(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets persistence enabled flag.
setPersistenceSettings(KeyValuePersistenceSettings) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets persistence settings.
setPersistenceSettingsBean(String) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStoreFactory
Sets persistence settings bean name.
setPersistentStoreConfiguration(PersistentStoreConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Part of old API. Use DataStorageConfiguration for configuring persistence instead.
setPersistentStorePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a path to the root directory where the Persistent Store will persist data and indexes.
setPerTask(boolean) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Configuration parameter indicating whether a new round robin order should be created for every task.
setPessimisticTxLogLinger(int) - Method in class org.apache.ignite.configuration.TransactionConfiguration
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.
setPlatformCacheConfiguration(PlatformCacheConfiguration) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets platform cache configuration.
setPlatformConfiguration(PlatformConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets platform configuration.
setPluginConfigurations(CachePluginConfiguration...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache plugin configurations.
setPluginConfigurations(PluginConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets plugin configurations.
setPluginProviders(PluginProvider...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets plugin providers.
setPointInTimeRecoveryEnabled(boolean) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Deprecated.
Use control.sh/.bat '--property' command to set 'pointInTimeRecoveryEnabled' property cluster-wide.
setPoolingOptions(PoolingOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets pooling options.
setPopulationSize(int) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the population size
setPort(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets port to use for Cassandra connection.
setPort(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set port.
setPort(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets port for TCP binary protocol server.
setPort(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set port.
setPort(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets port number.
setPort(int) - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
setPort(int) - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
Convenient way to set address.
setPortRange(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set port range.
setPortRange(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets number of ports to try if configured one is in use.
setPortRange(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set port range.
setPreferLocalSender(boolean) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets whether to prefer the local sender hub.
setPreviousUpdates(Vector) - Method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Set previous step parameters updates.
setPriorityAttributeKey(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets task priority attribute key.
setPriorProbabilities(double[]) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
Sets prior probabilities.
setPriorProbabilities(double[]) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
Sets prior probabilities.
setProcessorCoefficient(double) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets coefficient of every CPU processor.
setProjectName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets Google Cloud Platforms project name.
setProperties(Map<String, Serializable>) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
Sets a map of properties.
setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Set properties.
setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Set properties.
setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Set properties.
setProtocol(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets protocol for secure transport.
setProtocols(String...) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets enabled protocols.
setProtocolVersion(int) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets the native protocol version to use.
setProvider(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets the cloud provider to use.
setPublicThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets thread pool size to use within grid.
setPwd(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint database password.
setQueryDetailMetricsSize(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setQueryDetailMetricsSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets size of queries detail metrics that will be stored in memory for monitoring purposes.
setQueryEntities(QueryEntity...) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setQueryEntities(Collection<QueryEntity>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets query entities configuration.
setQueryInitiatorId(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
setQueryParallelism(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setQueryParallelism(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets query parallelism.
setQueryThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets query thread pool size to use within grid.
setRateTimeInterval(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
setRateTimeInterval(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
setRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Sets value.
setRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Sets value.
setRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
setRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
setRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
setRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
setRaw(Serializable) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector.Element
Sets any serializable object value.
setRaw(int, Serializable) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Sets value.
setRaw(int, Serializable) - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
 
setRawX(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Sets value without checking for index boundaries.
setRawX(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Sets value without checking for index boundaries.
setRawX(int, Serializable) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Sets value without checking for index boundaries.
setReadBufferSize(int) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets read buffer size.
setReadBufferSize(int) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets read buffer size.
setReadConsistency(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Set consistency level for READ operations.
setReadFromBackup(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setReadFromBackup(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets read from backup flag.
setReadThrough(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setReadTimeout(long) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets read timeout.
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
The number of batches generated by supply node at rebalancing procedure start.
setRebalanceBatchSize(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceBatchSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
The supply message size in bytes to be loaded within a single rebalance batch.
setRebalanceDelay(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
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.client.ClientCacheConfiguration
 
setRebalanceMode(CacheRebalanceMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache rebalance mode.
setRebalanceOrder(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceOrder(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache rebalance order.
setRebalanceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
setRebalanceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Max count of threads can be used at rebalancing.
setRebalanceThrottle(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceThrottle(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceThrottle(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
setRebalanceTimeout(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Rebalance timeout for supply and demand messages in milliseconds.
setReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server receive buffer size in bytes.
setReceiverAddresses(String...) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets addresses of remote receiver hubs.
setReconnectCount(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Number of times node tries to (re)establish connection to another node.
setReconnectDelay(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets the amount of time in milliseconds that node waits before retrying to (re)connect to the cluster.
setReconnectionPolicy(ReconnectionPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets reconnection policy.
setReconnectOnFailureTimeout(long) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets reconnect-on-failure timeout.
setReconnectThrottlingPeriod(long) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets reconnect throttling period.
setReconnectThrottlingRetries(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets reconnect throttling retries.
setReencryptionBatchSize(int) - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Sets the number of pages that is scanned during re-encryption under checkpoint lock.
setReencryptionRateLimit(double) - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Sets re-encryption rate limit.
setRegion(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Sets AWS Application Load Balancer's region.
setRegion(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Sets Classic load balancer's region.
setRegion(Region) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
AWS region.
setRegion(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
AWS region.
setRegions(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets list of regions where VMs are located.
setRegistryTransformer(SnapshotRegistryTransformer) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Allows to plug in custom transformer for snapshot file registry to enable its authenticity.
setRemoteFilter(CacheEntryEventSerializableFilter<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
setRemoteFilterFactory(Factory<? extends CacheEntryEventFilter<K, V>>) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets optional key-value filter factory.
setRemoteFilterFactory(Factory<? extends CacheEntryEventFilter<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets optional key-value filter factory.
setRemoteTransformerFactory(Factory<? extends IgniteClosure<CacheEntryEvent<? extends K, ? extends V>, T>>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets transformer factory.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setRequireDictionary(boolean) - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Sets flag that enables compression without dictionary.
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.
setRestoreOperationParallelism(int) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
setRetries(int) - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
setRetryLimit(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the retry limit.
setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets retry policy.
setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setRetryPolicy(ClientRetryPolicy) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the retry policy.
setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setRmClient(AMRMClientAsync<AMRMClient.ContainerRequest>) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets RMClient
setRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
Modify the transaction associated with the current thread such that the only possible outcome of the transaction is to roll back the transaction.
setRollingUpdatesEnabled(boolean) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets rolling updates enabled flag.
setRootPath(String) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets root directory path for storage.
setRoutingKey(ByteBuffer) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setRoutingKey(ByteBuffer...) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setRow(int, double[]) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Sets values for given row.
setRow(int, double[]) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Sets values for given row.
setSamplesBufferSize(int) - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Returns size of the buffer that should hold samples collected for dictionary training.
setScanners(UriDeploymentScanner...) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets scanners.
setSchedulerTimeout(long) - Method in class org.apache.ignite.yarn.ApplicationMaster
Sets scheduler timeout.
setSchema(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Set schema for the query.
setSchema(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSecretKey(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets secret key to authenticate REST requests.
setSecretKey(Key) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionService
The key used to encrypt and decrypt the data.
setSecurityCredentialsProvider(SecurityCredentialsProvider) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets security credentials.
setSecurityThreadPoolSize(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Set thread pool size that will be used to handle authorization of thin clients and expiration events.
setSegmentationPolicy(SegmentationPolicy) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets segmentation policy.
setSegmentationResolveAttempts(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets segmentation resolve attempts count.
setSegmentationResolvers(SegmentationResolver...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets segmentation resolvers.
setSegmentCheckFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets network segment check frequency.
setSelectionMtd(GAGridConstants.SELECTION_METHOD) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the selection method
setSelectorCount(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets count of selectors to use in TCP server.
setSelectorCount(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets number of selector threads for REST TCP server.
setSelectorCount(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets amount of selector threads in receiver hub's TCP server.
setSendBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSendBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server send buffer size.
setSendConsistentId(boolean) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
If true then OpenCensusMetricExporterSpi.CONSISTENT_ID_TAG will be added to each exported measure.
setSenderGroup(String) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets sender group name which sender will be used for replication.
setSenderGroups(String...) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Set groups this sender hub will participate in.
setSendInstanceName(boolean) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
If true then OpenCensusMetricExporterSpi.INSTANCE_NAME_TAG will be added to each exported measure.
setSendNodeId(boolean) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
If true then OpenCensusMetricExporterSpi.NODE_ID_TAG will be added to each exported measure.
setSendQueueLimit(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server send queue limit.
setSendServerExceptionStackTraceToClient(boolean) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Sets a value indicating whether full exception stack trace should be sent to the client.
setSerialConsistencyLevel(ConsistencyLevel) - Method in class org.apache.ignite.cache.store.cassandra.session.WrappedPreparedStatement
setSerializer(BinarySerializer) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets serializer.
setSerializer(BinarySerializer) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets serializer.
setSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setServerUri(String) - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
setService(Service) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service instance.
setServiceAccountId(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets the service account ID (typically an e-mail address).
setServiceAccountP12FilePath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets a full path to the private key in PKCS12 format of the Service Account.
setServiceConfiguration(ServiceConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets configurations for services to be deployed on the grid.
setServiceName(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Sets the name of Kubernetes service for Ignite pods' IP addresses lookup.
setServiceName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setServiceName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setServicePermissions(Map<String, Collection<SecurityPermission>>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set service permission map.
setServiceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets thread pool size to use within grid.
setSessionExpirationTimeout(long) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets expiration timeout for Cassandra driver session.
setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
Sets session factory.
setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
Sets session factory.
setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
Sets Hibernate session factory.
setSessionFactoryBean(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
Sets name of the data source bean.
setSessionTimeout(long) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setSftpConfiguration(SftpConfiguration) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Allows to use sftp storage in snapshot commands.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Sets shared flag.
setShutdownPolicy(ShutdownPolicy) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets shutdown policy.
setSimpleName(boolean) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Sets whether to use simple name of class or not.
setSingleton(boolean) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
setSingleTupleExtractor(StreamSingleTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
 
setSize(int) - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Set thread pool size.
setSkipReducerOnUpdate(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Switches update mode on server side.
setSkipReducerOnUpdate(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSkipStore(boolean) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
setSnapshotConfiguration(SnapshotConfiguration) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets snapshot configuration.
setSnapshotDirectory(String) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
 
setSnapshotMetrics(SnapshotMetricsMXBean) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Set SnapshotMetricsMXBean reference.
setSnapshotOperationParallelism(int) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
 
setSnapshotProgressThrottlingInterval(long) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Set time in ms which would be used to update snapshot operation progress (progress couldn't be updated more often) -1 means that throttling would turn off
setSnapshotsCatalogConnectorConfiguration(SnapshotsCatalogConnectorConfiguration) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Deprecated.
Snapshot Catalog functionality was removed from GridGain completely as obsolete. Providing configuration for Catalog Connectior won't have any effect.
setSnapshotsPath(String) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Sets database snapshot SPI.
setSocketOptions(SocketOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets socket options to use.
setSocketReceiveBuffer(int) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSocketReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets socket receive buffer size.
setSocketReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets socket receive buffer size.
setSocketReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets socket receive buffer size.
setSocketReceiveBufferSize(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets socket receive buffer size in bytes.
setSocketReceiveBufferSize(int) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets socjet receive buffer size in bytes.
setSocketSendBuffer(int) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSocketSendBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets socket send buffer size.
setSocketSendBufferSize(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets socket send buffer size.
setSocketSendBufferSize(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets socket send buffer size.
setSocketSendBufferSize(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets socket send buffer size in bytes.
setSocketSendBufferSize(int) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets socket send buffer size in bytes.
setSocketTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets socket operations timeout.
setSoLinger(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets SO_LINGER to use for all created sockets.
setSparsityCheckFrequency(long) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets frequency to check sparsity of files for compaction.
setSpeculativeExecutionPolicy(SpeculativeExecutionPolicy) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets speculative execution policy.
setSql(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets SQL clause.
setSql(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets SQL clause.
setSqlConfiguration(SqlConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setSqlConnectorConfiguration(SqlConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
setSqlFunctionClasses(Class<?>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets classes with methods annotated by QuerySqlFunction to be used as user-defined functions from SQL queries.
setSqlGlobalMemoryQuota(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlGlobalMemoryQuota(String) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets global memory pool size for SQL queries.
setSqlIndexMaxInlineSize(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setSqlIndexMaxInlineSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum inline size for sql indexes.
setSqlOffloadingEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlOffloadingEnabled(boolean) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets the SQL query offloading enabled flag.
setSqlOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets whether SQL on-heap cache is enabled.
setSqlOnheapCacheMaxSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum SQL on-heap cache.
setSqlQueryHistorySize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlQueryHistorySize(int) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets number of SQL query history elements kept in memory.
setSqlQueryMemoryQuota(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlQueryMemoryQuota(String) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets per-query memory quota.
setSqlSchema(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setSqlSchema(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets sql schema to be used for current cache.
setSqlSchemas(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlSchemas(String...) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets SQL schemas to be created on node startup.
setSSEAlgorithm(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
Sets server-side encryption algorithm for Amazon S3-managed encryption keys.
setSSEAlgorithm(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Sets server-side encryption algorithm for Amazon S3-managed encryption keys.
setSslClientAuth(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets flag indicating whether or not SSL client authentication is required.
setSslClientAuth(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets flag indicating whether or not SSL client authentication is required.
setSslClientCertificateKeyStorePassword(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslClientCertificateKeyStorePassword(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets key store password.
setSslClientCertificateKeyStorePath(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslClientCertificateKeyStoreType(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslClientCertificateKeyStoreType(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets key store type used in context initialization.
setSslClientCertificateKeyStoreUrl(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets path to the key store file.
setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets SSL context factory that will be used for creating a secure socket layer.
setSslContextFactory(GridSslContextFactory) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets SSL context factory that will be used for creating a secure socket layer.
setSslContextFactory(Factory<SSLContext>) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets SSL context factory.
setSslContextFactory(Factory<SSLContext>) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets SSL context factory.
setSslEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether Secure Socket Layer should be enabled for client connector.
setSslEnabled(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets whether Secure Socket Layer should be enabled for REST TCP binary protocol.
setSslFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets instance of Factory that will be used to create an instance of SSLContext for Secure Socket Layer on TCP binary protocol.
setSslFactory(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets the class name of the custom implementation of the Factory<SSLSocketFactory>.
setSslKeyAlgorithm(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslKeyAlgorithm(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets key manager algorithm that will be used to create a key manager.
setSslMode(SslMode) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslMode(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Use SSL connection to Ignite node.
setSslOptions(SSLOptions) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets SSL options.
setSslProtocol(SslProtocol) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslProtocol(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets protocol for secure transport.
setSslTrustAll(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustAll(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets to true to trust any server certificate (revoked, expired or self-signed SSL certificates).
setSslTrustCertificateKeyStorePassword(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustCertificateKeyStorePassword(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets trust store password.
setSslTrustCertificateKeyStorePath(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustCertificateKeyStoreType(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustCertificateKeyStoreType(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets trust store type.
setSslTrustCertificateKeyStoreUrl(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets path to the trust store file.
setStarvationIncrement(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets value to increment job priority by every time a lower priority job gets behind a higher priority job.
setStarvationIncrement(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets value to increment job priority by every time a lower priority job gets behind a higher priority job.
setStarvationPreventionEnabled(boolean) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets flag indicating whether job starvation prevention is enabled.
setStarvationPreventionEnabled(boolean) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets flag indicating whether job starvation prevention is enabled.
setStateTransferBatchSendSizeBytes(int) - Method in class org.gridgain.grid.configuration.GridGainConfiguration
Sets full state transfer batch send size in bytes.
setStateTransferThreadsCount(int) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
setStateTransferThrottle(long) - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Sets state transfer throttle.
setStateTransferThrottle(long) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Deprecated.
setStateTransferThrottleBytes(int) - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
Sets state transfer throttle bytes.
setStatisticsEnabled(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setStatisticsEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setStatisticsPrintFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets statistics print frequency.
setStatus(SpanStatus) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Explicitly set status for span.
setStatus(SpanStatus) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Explicitly set status for span.
setStatus(SpanStatus) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Explicitly set status for span.
setStealingAttributes(Map<String, ? extends Serializable>) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Configuration parameter to enable stealing to/from only nodes that have these attributes set (see ClusterNode.attribute(String) and IgniteConfiguration.getUserAttributes() methods).
setStealingEnabled(boolean) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
setStealingEnabled(boolean) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
setStorage(MatrixStorage) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
 
setStorage(VectorStorage) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Set storage.
setStoragePath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path to the root directory where the Persistent Store will persist data and indexes.
setStore(DrSenderStore) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets store.
setStore(DrSenderStore) - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
Sets store for connection.
setStoreByValue(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setStoreConcurrentLoadAllThreshold(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets the concurrent load-all threshold used for cases when keys' values are being loaded from CacheStore in parallel.
setStoreKeepBinary(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets keep binary in store flag.
setStreamer(IgniteDataStreamer<K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
 
setStripedPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets striped pool size that should be used for cache requests processing.
setSubIntervals(int) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
setSubIntervals(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
setSumOfValues(double) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.MeanValueStatistic
 
setSupportedCompressionCodecs(EnumSet<CompressionOption>) - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
Sets collection of supported compression codecs.
setSwapFilePath(String) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets a path to the memory-mapped file.
setSwapPath(String) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets a path to the memory-mapped files.
setSynchronousWrites(boolean) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Sets synchronous mode flag.
setSystemCacheInitialSize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets initial size of a memory region reserved for system cache.
setSystemCacheMaxSize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets maximum memory region size reserved for system cache.
setSystemPermissions(Collection<SecurityPermission>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set collection system permission.
setSystemRegionInitialSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets initial size of a data region reserved for system cache.
setSystemRegionMaxSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets maximum data region size reserved for system cache.
setSystemRequestTimeout(long) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets system request timeout.
setSystemThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets system thread pool size to use within grid.
setSystemViewExporterSpi(SystemViewExporterSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of SystemViewExporterSpi.
setSystemViewRegistry(ReadOnlySystemViewRegistry) - Method in interface org.apache.ignite.spi.systemview.SystemViewExporterSpi
Sets system view registry that SPI should export.
setSystemWorkerBlockedTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets maximum inactivity period for system worker.
setSystemWorkerBlockedTimeout(long) - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
setTableName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets table name for this query entity.
setTarget(Object) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
Sets target object for method execution.
setTargetGrpARN(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Sets AWS Application Load Balancer's target group ARN.
setTaskPermissions(Map<String, Collection<SecurityPermission>>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set task permission map.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setTcpNoDelay(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set TCP NO_DELAY flag.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set TCP NO_DELAY flag.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setTcpNodelay(boolean) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets TCP_NODELAY flag in receiver hub's TCP server.
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.
setTerminateCriteria(ITerminateCriteria) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set the termination criteria.
setText(String) - Method in class org.apache.ignite.cache.query.TextQuery
Sets text search string.
setTextQuery(boolean) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets text query.
setThenNode(DecisionTreeNode) - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
 
setThinClientConfiguration(ThinClientConfiguration) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets thin-client specific configuration.
setThinClientEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether access through thin client is enabled.
setThreadCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets thread count for warmup.
setThreadedQueryInitiatorId(String) - Static method in class org.apache.ignite.cache.query.SqlFieldsQuery
Used at the Job worker to setup originator by default for current thread.
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets thread pool that is in charge of processing client requests.
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets thread pool size to use for processing of client messages (REST requests).
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets thread pool that is in charge of processing ODBC tasks.
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets thread pool that is in charge of processing SQL requests.
setThreadPriority(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets thread priority.
setThreads(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets threadds amount.
setThreadsCount(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets number of worker threads.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets time interval.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets time interval.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets time interval.
setTimeout(int, TimeUnit) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets the query execution timeout.
setTimeout(int, TimeUnit) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets the query execution timeout.
setTimeout(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setTimeout(int) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets timeout.
setTimeout(int) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Sets timeout to use when checking reachability.
setTimeServerPortBase(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets time server port base.
setTimeServerPortRange(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets time server port range.
setTimeToLive(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Set the default time-to-live for multicast packets sent out on this IP finder in order to control the scope of the multicast.
setTlbSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
setTopHistorySize(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets size of topology snapshots history.
setTopologyValidator(TopologyValidator) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets topology validator.
setTotalCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets total number of deployed service instances in the cluster, 0 for unlimited.
setTracingPermissions(Collection<SecurityPermission>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set tracing permissions.
setTracingSpi(TracingSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set fully configured instance of TracingSpi.
setTransactionConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
Sets transaction concurrency level.
setTransactionConfiguration(ClientTransactionConfiguration) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets transactions configuration.
setTransactionConfiguration(TransactionConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets transactions configuration.
setTransactionManager(PlatformTransactionManager) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Sets transaction manager.
setTransactionManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
setTransactionTimeDumpSamplesCoefficient(double) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets the coefficient for samples of completed transactions that will be dumped in log.
setTransactionTimeDumpSamplesPerSecondLimit(int) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets the limit of samples of completed transactions that will be dumped in log per second, if TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient() is above 0.0.
setTransformer(JdbcTypesTransformer) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets types transformer.
setTransformer(JdbcTypesTransformer) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets types transformer.
setTruncateRate(double) - Method in class org.apache.ignite.ml.genetic.parameter.GAConfiguration
Set truncatePercentage
setTrustManagers(TrustManager...) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets pre-configured trust managers.
setTrustStoreFilePath(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets path to the trust store file.
setTrustStorePassword(char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets trust store password.
setTrustStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets trust store type used in context initialization.
setTtl(int) - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
Sets TTL to use when checking reachability.
setTupleExtractor(StreamTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
Deprecated.
setTxKeyCollisionsInterval(int) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Set timeout interval for tx key contention analysis.
setTxManagerFactory(Factory<T>) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets transaction manager factory for available javax.transaction.TransactionManager implementation, if any.
setTxManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.TransactionConfiguration
setTxOwnerDumpRequestsAllowed(boolean) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets if dump requests from local node to near node are allowed, when long running transaction is found.
setTxSerializableEnabled(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
This method has no effect, TransactionIsolation.SERIALIZABLE isolation is always enabled.
setTxTimeoutOnPartitionMapExchange(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets transaction timeout on partition map exchange. 0 means transactions will never be rolled back on partition map exchange.
setTxTimeoutOnPartitionMapExchange(long) - Method in interface org.apache.ignite.IgniteCluster
Sets transaction timeout on partition map exchange.
setTxTimeoutOnPartitionMapExchange(long) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets transaction timeout on partition map exchange. 0 means transactions will never be rolled back on partition map exchange.
setType(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets type for query.
setType(Class<?>) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
 
setType(Class<?>) - Method in class org.apache.ignite.cache.query.TextQuery
Sets type for query.
setType(String) - Method in class org.apache.ignite.cache.query.TextQuery
Sets type for query.
setTypeConfigurations(Collection<BinaryTypeConfiguration>) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets type configurations.
setTypeName(String) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets type name.
setTypeName(String) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
 
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Sets .NET type name.
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Sets .NET type name.
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Set type name.
setTypes(JdbcType...) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets store configurations.
setTypes(JdbcType...) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets store configurations.
setTypes(Class<K>, Class<V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setTypes(Collection<String>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setTypesConfiguration(Collection<PlatformDotNetBinaryTypeConfiguration>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setU(double[]) - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRPartitionContext
 
setUpdateBatchSize(int) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets update internal bach size.
setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets update entry query.
setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets update entry query.
setUpdatesMask(Vector) - Method in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Set updates mask (values by which updateCache is multiplied).
setupFile(Path, FileSystem, LocalResourceType) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
setUriList(List<String>) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets list of URI which point to a directory with packages and which should be scanned by SPI for the new tasks.
setURL(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Different application servers us different format (URL & url).
setUrl(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets flag indicating whether to use average CPU load vs. current.
setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Sets flag indicating whether to use average job counts vs. current.
setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Sets flag indicating whether to use average execution time vs. current.
setUseConsistentId(Boolean) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets use consistent ID flag.
setUseIgniteSslContextFactory(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether to use Ignite SSL context factory.
setUseIgniteSslContextFactory(boolean) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets whether to use Ignite SSL context factory.
setUseIgniteSslContextFactory(boolean) - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
Sets whether to use Ignite SSL context factory.
setUseJtaSynchronization(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets the flag that defines whether to use lightweight JTA synchronization callback to enlist into JTA transaction instead of creating a separate XA resource.
setUseProcessors(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets flag indicating whether to use average CPU load vs. current (default is true).
setUser(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Sets user name to use for authentication.
setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets user name for database access.
setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets user name for database access.
setUser(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint database user name.
setUserAttributes(Map<String, String>) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets user attributes which can be used to send additional info to the server nodes.
setUserAttributes(Map<String, ?>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets user attributes for this node.
setUserName(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setUsername(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setUserObject(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets user-specific object.
setUserPassword(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setUseSSL(boolean) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Enables SSL for communications with Cassandra.
setUseWeights(boolean) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Sets a flag to indicate whether node weights should be checked when doing random load balancing.
setUtilityCacheKeepAliveTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets keep alive time of thread pool size that will be used to process utility cache messages.
setUtilityCachePoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets default thread pool size that will be used to process utility cache messages.
setVal(Object) - Method in class org.apache.ignite.ml.genetic.Gene
Set the Gene value
setVal(double) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
 
setValue(Object, Object) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoFieldAccessor
Assigns value for the object field.
setValue(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
 
setValue(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
setValue(String) - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Sets value.
setValueFieldName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets value field name.
setValueFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint value field name.
setValueFields(JdbcTypeField...) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets optional persistent value fields (needed only if CacheJdbcPojoStore is used).
setValueFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint value field type.
setValueFromRow(Row, Object, Serializer) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PojoField
Sets object field value from a Row returned by Cassandra CQL statement.
setValuesForLeaves(ArrayList<TreeRoot>, Dataset<EmptyContext, BootstrappedDatasetPartition>) - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.LeafValuesComputer
Takes a list of all built trees and in one map-reduceImpurityStatistics step collect statistics for evaluating leaf-values for each tree and sets values for leaves.
setValueType(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets value type for this query pair.
setValueType(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets value type.
setValueType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets value type.
setValueTypeName(String) - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Sets fully-qualified platform type name of the cache value used for the local map.
SetView - Class in org.apache.ignite.spi.systemview.view.datastructures
Set representation for a SystemView.
SetView(GridCacheSetProxy<?>) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
setWaitForSegmentOnStart(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets wait for segment on start flag.
setWaitingJobsNumber(int) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Sets maximum number of jobs that are allowed to wait in waiting queue.
setWaitingJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Sets maximum number of jobs that are allowed to wait in waiting queue.
setWaitingJobsNumber(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Maximum number of jobs that are allowed to wait in waiting queue.
setWaitingJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Maximum number of jobs that are allowed to wait in waiting queue.
setWaitJobsThreshold(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Sets job count threshold at which this node will start stealing jobs from other nodes.
setWaitJobsThreshold(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Sets job count threshold at which this node will start stealing jobs from other nodes.
setWalArchivePath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path for the WAL archive directory.
setWalArchivePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a path for the WAL archive directory.
setWalAutoArchiveAfterInactivity(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Note: setting this value with WALMode.FSYNC may generate file size overhead for WAL segments in case grid is used rarely.
setWalAutoArchiveAfterInactivity(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Note: setting this value with WALMode.FSYNC may generate file size overhead for WAL segments in case grid is used rarely.
setWalBufferSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property defines size(in bytes) of WAL buffer.
setWalBufferSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
setWalCompactionEnabled(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag indicating whether WAL compaction is enabled.
setWalCompactionLevel(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
setWalCompactionLevel(int) - Method in interface org.apache.ignite.mxbean.DataStorageMXBean
Sets ZIP compression level to WAL compaction.
setWalFlushFrequency(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property define how often WAL will be fsync-ed in BACKGROUND mode.
setWalFlushFrequency(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property define how often WAL will be fsync-ed in BACKGROUND mode.
setWalFsyncDelayNanos(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets property that allows to trade latency for throughput in WALMode.FSYNC mode.
setWalFsyncDelayNanos(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setWalHistorySize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Instead of walHistorySize use maxWalArchiveSize for manage of archive size.
setWalHistorySize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a total number of checkpoints to keep in the WAL history.
setWalMode(WALMode) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets property that defines behavior of wal fsync.
setWalMode(WALMode) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setWalPageCompression(DiskPageCompression) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets compression algorithm for WAL page snapshot records.
setWalPageCompressionLevel(Integer) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets algorithm specific page compression level.
setWalPath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path to the directory where WAL is stored.
setWalRecordIteratorBufferSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets property defining how many bytes iterator read from disk (for one reading), during go ahead wal.
setWalRecordIteratorBufferSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setWalSegments(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a number of WAL segments to work with.
setWalSegments(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a number of WAL segments to work with.
setWalSegmentSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets size(in bytes) of a WAL segment.
setWalSegmentSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets size of a WAL segment.
setWalStorePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a path to the directory where WAL is stored .
setWalThreadLocalBufferSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets size of thread local buffer.
setWarmupClosure(IgniteInClosure<IgniteConfiguration>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets warmup closure to execute before grid startup.
setWarmUpConfiguration(WarmUpConfiguration) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets warm-up configuration.
setWarmupMethods(String...) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets warmup methods to use for cache warmup.
setWeight(int, int, int, double) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Set the weight of neuron with given index in previous layer to neuron with given index in given layer.
setWeights(int, Matrix) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Sets the weighs of layer with a given index.
setWithMdlDescStorage(boolean) - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
setWithMdlStorage(boolean) - Method in class org.apache.ignite.ml.util.plugin.MLPluginConfiguration
 
setWorkDirectory(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite work folder.
setWorkDirectory(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Set work directory.
setWorkerThreads(int) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets amount of threads responsible for sender hub batches processing.
setWriteBehindBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum batch size for write-behind cache.
setWriteBehindCoalescing(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write coalescing flag for write-behind cache.
setWriteBehindEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets flag indicating whether write-behind is enabled.
setWriteBehindFlushFrequency(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write-behind flush frequency.
setWriteBehindFlushSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write-behind flush size.
setWriteBehindFlushThreadCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets flush thread count for write-behind cache.
setWriteBufferSize(int) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets write buffer size in bytes.
setWriteConsistency(String) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
Set consistency level for WRITE operations.
setWriteDelay(long) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets write delay after which write buffer can be flushed to the disk.
setWriteMode(CacheFileLocalStoreWriteMode) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Sets write mode.
setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write synchronization mode.
setWriteThrottlingEnabled(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag indicating whether write throttling is enabled.
setWriteThrottlingEnabled(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets flag indicating whether write throttling is enabled.
setWriteThrough(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setWriteTimeout(long) - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
Sets write timeout for receiver hub's TCP server connection.
setX(int, int, double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Sets given value without checking for index bounds.
setX(int, int, double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Sets given value without checking for index bounds.
setX(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Sets value without checking for index boundaries.
setX(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Sets value without checking for index boundaries.
setX(int, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Sets value without checking for index boundaries.
setZkConnectionString(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
 
setZkConnectionString(String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setZkRootPath(String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setZones(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Sets list of zones where VMs are located.
sftp() - Static method in class org.gridgain.grid.persistentstore.SnapshotPath
 
SftpConfiguration - Class in org.gridgain.grid.configuration
Configuration for access to SFTP server.
SftpConfiguration() - Constructor for class org.gridgain.grid.configuration.SftpConfiguration
 
SHA256UniformMapper<K,V> - Class in org.apache.ignite.ml.selection.split.mapper
Implementation of uniform mappers based on SHA-256 hashing algorithm.
SHA256UniformMapper() - Constructor for class org.apache.ignite.ml.selection.split.mapper.SHA256UniformMapper
Constructs a new instance of SHA-256 uniform mapper.
SHA256UniformMapper(Random) - Constructor for class org.apache.ignite.ml.selection.split.mapper.SHA256UniformMapper
Constructs a new instance of SHA-256 uniform mapper.
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.
SharedFsSegmentationResolver - Class in org.gridgain.grid.segmentation.sharedfs
Segmentation resolver implementation that checks whether node is in the correct segment or not by writing to and reading from shared directory.
SharedFsSegmentationResolver() - Constructor for class org.gridgain.grid.segmentation.sharedfs.SharedFsSegmentationResolver
 
shmemPort() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
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.ServiceEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.TaskEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.gridgain.grid.events.AuthenticationEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.gridgain.grid.events.AuthorizationEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.gridgain.grid.events.LicenseEvent
Gets a shortened version of toString() result.
shortMessage() - Method in exception org.gridgain.grid.product.ProductLicenseException
 
shortString() - Method in class org.apache.ignite.lang.IgniteUuid
Gets a short string version of this ID.
shouldProceedWithMaintenance() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Called by MaintenanceRegistry and enables it to check if maintenance is still needed for component that provided this callback.
shouldRetry(ClientRetryPolicyContext) - Method in class org.apache.ignite.client.ClientRetryAllPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(ClientRetryPolicyContext) - Method in class org.apache.ignite.client.ClientRetryNonePolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(ClientRetryPolicyContext) - Method in interface org.apache.ignite.client.ClientRetryPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(ClientRetryPolicyContext) - Method in class org.apache.ignite.client.ClientRetryReadPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
showAscii(Vector, IgniteLogger, String) - Static method in class org.apache.ignite.ml.math.Tracer
 
showAscii(Vector, IgniteLogger) - Static method in class org.apache.ignite.ml.math.Tracer
 
showAscii(Vector, String) - Static method in class org.apache.ignite.ml.math.Tracer
 
showAscii(Matrix) - Static method in class org.apache.ignite.ml.math.Tracer
 
showAscii(Matrix, String) - Static method in class org.apache.ignite.ml.math.Tracer
 
showAscii(Matrix, IgniteLogger, String) - Static method in class org.apache.ignite.ml.math.Tracer
 
showAscii(Vector) - Static method in class org.apache.ignite.ml.math.Tracer
 
showClassificationDatasetHtml(DataStreamGenerator, int, int, int, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
Open browser and shows given dataset generator's data on two dimensional plane.
showClassificationDatasetHtml(String, DataStreamGenerator, int, int, int, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
Open browser and shows given dataset generator's data on two dimensional plane.
showFullStackOnClientSide(boolean) - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
If sets to true shows full stack trace otherwise highlevel short error message.
showHtml(Matrix) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given matrix in the browser with D3-based visualization.
showHtml(Matrix, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given matrix in the browser with D3-based visualization.
showHtml(Matrix, Tracer.ColorMapper) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given matrix in the browser with D3-based visualization.
showHtml(Matrix, Tracer.ColorMapper, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given matrix in the browser with D3-based visualization.
showHtml(Vector) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given vector in the browser with D3-based visualization.
showHtml(Vector, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given vector in the browser with D3-based visualization.
showHtml(Vector, Tracer.ColorMapper) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given vector in the browser with D3-based visualization.
showHtml(Vector, Tracer.ColorMapper, boolean) - Static method in class org.apache.ignite.ml.math.Tracer
Shows given vector in the browser with D3-based visualization.
showRegressionDatasetInHtml(String, DataStreamGenerator, int, int) - Static method in class org.apache.ignite.ml.math.Tracer
Open browser and shows given dataset generator's data on two dimensional plane.
showRegressionDatasetInHtml(DataStreamGenerator, int, int) - Static method in class org.apache.ignite.ml.math.Tracer
Open browser and shows given dataset generator's data on two dimensional plane.
shrink() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Shrinks backed container to maximum allowed size.
shrink0() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
shrink0() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Tries to remove one item from queue.
shrink0() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Tries to remove one item from queue.
shrink0() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Tries to remove one item from queue.
shuffle() - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Creates a permanent rearrangement mapping of features in vector and applies this rearrangement for each vectors of current generator.
shuffle(Long) - Method in interface org.apache.ignite.ml.util.generators.primitives.vector.VectorGenerator
Creates a permanent rearrangement mapping of features in vector and applies this rearrangement for each vectors of current generator.
shutdown - Variable in class org.apache.ignite.configuration.IgniteConfiguration
Shutdown policy for cluster.
shutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
shutdownNow() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
shutdownPolicy() - Method in interface org.apache.ignite.IgniteCluster
Returns a policy of shutdown or default value IgniteConfiguration.DFLT_SHUTDOWN_POLICY if the property is not set.
shutdownPolicy(ShutdownPolicy) - Method in interface org.apache.ignite.IgniteCluster
Sets a shutdown policy on a cluster.
ShutdownPolicy - Enum in org.apache.ignite
This class reperesents a policy of shutdown.
shutdownPolicyToHandleFailure() - Method in class org.apache.ignite.failure.AbstractFailureHandler
Returns ShutdownPolicy to be used when handling critical situation by FailureProcessor mechanism.
SIGMOID - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns 1 / (1 + exp(-a)
SIGMOID - Static variable in class org.apache.ignite.ml.nn.Activators
Sigmoid activation function.
SIGMOIDGRADIENT - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns a * (1-a)
SIGN - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns {@code a < 0 ?
signal() - Method in interface org.apache.ignite.IgniteCondition
Wakes up one waiting thread.
signalAll() - Method in interface org.apache.ignite.IgniteCondition
Wakes up all waiting threads.
SimpleDataset<C extends Serializable> - Class in org.apache.ignite.ml.dataset.primitive
A simple dataset introduces additional methods based on a matrix of features.
SimpleDataset(Dataset<C, SimpleDatasetData>) - Constructor for class org.apache.ignite.ml.dataset.primitive.SimpleDataset
Creates a new instance of simple dataset that introduces additional methods based on a matrix of features.
SimpleDatasetData - Class in org.apache.ignite.ml.dataset.primitive.data
A partition data of the SimpleDataset containing matrix of features in flat column-major format stored in heap.
SimpleDatasetData(double[], int) - Constructor for class org.apache.ignite.ml.dataset.primitive.data.SimpleDatasetData
Constructs a new instance of partition data of the SimpleDataset containing matrix of features in flat column-major format stored in heap.
SimpleDatasetDataBuilder<K,V,C extends Serializable,CO extends Serializable> - Class in org.apache.ignite.ml.dataset.primitive.builder.data
A partition data builder that makes SimpleDatasetData.
SimpleDatasetDataBuilder(Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.dataset.primitive.builder.data.SimpleDatasetDataBuilder
Construct a new instance of partition data builder that makes SimpleDatasetData.
SimpleGDParameterUpdate - Class in org.apache.ignite.ml.optimization.updatecalculators
Parameters for SimpleGDUpdateCalculator.
SimpleGDParameterUpdate(int) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDParameterUpdate
Construct instance of this class.
SimpleGDParameterUpdate(Vector) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDParameterUpdate
Construct instance of this class.
SimpleGDUpdateCalculator - Class in org.apache.ignite.ml.optimization.updatecalculators
Simple gradient descent parameters updater.
SimpleGDUpdateCalculator() - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Construct instance of this class with default parameters.
SimpleGDUpdateCalculator(double) - Constructor for class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Construct SimpleGDUpdateCalculator.
SimpleLabeledDataset<C extends Serializable> - Class in org.apache.ignite.ml.dataset.primitive
A simple labeled dataset introduces additional methods based on a matrix of features and labels vector.
SimpleLabeledDataset(Dataset<C, SimpleLabeledDatasetData>) - Constructor for class org.apache.ignite.ml.dataset.primitive.SimpleLabeledDataset
Creates a new instance of simple labeled dataset that introduces additional methods based on a matrix of features and labels vector.
SimpleLabeledDatasetData - Class in org.apache.ignite.ml.dataset.primitive.data
A partition data of the SimpleLabeledDataset containing matrix of features in flat column-major format stored in heap and vector of labels stored in heap as well.
SimpleLabeledDatasetData(double[], double[], int) - Constructor for class org.apache.ignite.ml.dataset.primitive.data.SimpleLabeledDatasetData
Constructs a new instance of partition data of the SimpleLabeledDataset containing matrix of features in flat column-major format stored in heap and vector of labels stored in heap as well.
SimpleLabeledDatasetDataBuilder<K,V,C extends Serializable> - Class in org.apache.ignite.ml.dataset.primitive.builder.data
A partition data builder that makes SimpleLabeledDatasetData.
SimpleLabeledDatasetDataBuilder(Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.dataset.primitive.builder.data.SimpleLabeledDatasetDataBuilder
Constructs a new instance of partition data builder that makes SimpleLabeledDatasetData.
SimpleStackedDatasetTrainer<I,O,AM extends IgniteModel<I,O>,L> - Class in org.apache.ignite.ml.composition.stacking
DatasetTrainer with same type of input and output of submodels.
SimpleStackedDatasetTrainer(DatasetTrainer<AM, L>, IgniteBinaryOperator<I>, IgniteFunction<I, I>, IgniteFunction<Vector, I>, IgniteFunction<I, Vector>) - Constructor for class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Construct instance of this class.
SimpleStackedDatasetTrainer(DatasetTrainer<AM, L>, IgniteBinaryOperator<I>) - Constructor for class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Construct instance of this class.
SimpleStackedDatasetTrainer() - Constructor for class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Constructs instance of this class.
SimpleStepFunctionCompressor<T extends ImpurityMeasure<T>> - Class in org.apache.ignite.ml.tree.impurity.util
Simple step function compressor.
SimpleStepFunctionCompressor() - Constructor for class org.apache.ignite.ml.tree.impurity.util.SimpleStepFunctionCompressor
Constructs a new instance of simple step function compressor with default parameters.
SimpleStepFunctionCompressor(int, double, double) - Constructor for class org.apache.ignite.ml.tree.impurity.util.SimpleStepFunctionCompressor
Constructs a new instance of simple step function compressor.
simulateNodeFailure() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
you should you DI and get instances of [nioSrvWrapper, commWorker, clientPool] via it.
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
For TESTING only.
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
For TESTING only.
SINGLE_COPY_NO_PARTITION_SIZE - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
 
singleFileCopy() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
singleFileCopy(boolean) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets would copy partitions once (cluster-wide).
singleFileCopy() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
singleFileCopy(boolean) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets would copy partitions once (cluster-wide).
singleFileCopy() - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
 
SingleLabelDatasetTrainer<M extends IgniteModel> - Class in org.apache.ignite.ml.trainers
Interface for trainers that trains on dataset with singe label per object.
SingleLabelDatasetTrainer() - Constructor for class org.apache.ignite.ml.trainers.SingleLabelDatasetTrainer
 
SingleModelBuilder - Class in org.apache.ignite.ml.inference.builder
Implementation of synchronous inference model builder that builds a model processed locally in a single thread.
SingleModelBuilder() - Constructor for class org.apache.ignite.ml.inference.builder.SingleModelBuilder
 
SingularMatrixException - Exception in org.apache.ignite.ml.math.exceptions
Exception to be thrown when a non-singular matrix is expected.
SingularMatrixException() - Constructor for exception org.apache.ignite.ml.math.exceptions.SingularMatrixException
 
SingularMatrixException(String, Object...) - Constructor for exception org.apache.ignite.ml.math.exceptions.SingularMatrixException
 
size() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Returns entry size in bytes.
size() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all entries cached on this node.
size(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
size(CachePeekMode...) - Method in interface org.apache.ignite.client.ClientCache
Gets the number of all entries cached across all nodes.
size() - Method in interface org.apache.ignite.client.ClientIgniteSet
size(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached across all nodes.
size() - Method in interface org.apache.ignite.IgniteQueue
size() - Method in interface org.apache.ignite.IgniteSet
size() - Method in class org.apache.ignite.lang.IgniteBiTuple
size() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets cardinality of this vector (maximum number of the elements).
size() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets cardinality of this vector (maximum number of the elements).
size() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
size() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
size() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
size() - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
size() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets cardinality of this vector (maximum number of the elements).
size() - Method in interface org.apache.ignite.ml.math.primitives.vector.VectorStorage
 
size() - Method in class org.apache.ignite.ml.structures.DatasetRow
Gets cardinality of dataset row (maximum number of the elements).
size() - Method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
 
size() - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Returns the amount of genes in chromosome.
size() - Method in class org.apache.ignite.ml.util.genetic.Population
Returns the size of population.
size() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
size() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
size() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
size(CachePeekMode...) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Gets the number of all entries cached across all nodes.
size(CachePeekMode...) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Gets the number of all entries cached across all nodes.
size(CachePeekMode...) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Gets the number of all entries cached across all nodes.
size() - Method in class org.apache.ignite.springdata22.repository.query.IgniteRepositoryQuery.QueryCursorWrapper
size() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Return snapshot size in bytes.
SIZE_IN_BYTES - Static variable in class org.apache.ignite.lang.IgniteProductVersion
Size in bytes of serialized: 3 bytes (maj, min, maintenance version), 8 bytes - timestamp
sizeAsync(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeAsync(CachePeekMode...) - Method in interface org.apache.ignite.client.ClientCache
Gets the number of all entries cached across all nodes.
sizeAsync(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached across all nodes.
sizeBytes() - Method in interface org.gridgain.grid.dr.store.DrSenderStore
 
sizeBytes() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
sizeBytes() - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
sizeLong() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets the number of all entries cached on this node as a long value.
sizeLong(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeLong(int, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeLong(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached across all nodes as a long value.
sizeLong(int, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached in a partition as a long value.
sizeLongAsync(CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeLongAsync(int, CachePeekMode[]) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
sizeLongAsync(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached across all nodes as a long value.
sizeLongAsync(int, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached in a partition as a long value.
sizeOf(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.ArrayLikeVectorizer
Size of array-like structure of upstream object.
sizeOf(K, double[]) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.DoubleArrayVectorizer
Size of array-like structure of upstream object.
sizeOf(K, Vector) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.DummyVectorizer
Size of array-like structure of upstream object.
sizeWithoutIndexes() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfoEx
Total snapshot size in bytes without indexes
skip() - Method in class org.apache.ignite.messaging.MessagingListenActor
Skips current message and continues to listen for new message.
skipCertificates() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
This field using for old versions compatibility.
skipCrc() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
skipCrc(boolean) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets flag to skip CRC check, default is false.
skipStore() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
skipStore() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag indicating that write-through behavior should be disabled for data streaming.
skipStore(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag indicating that write-through behavior should be disabled for data streaming.
skipWalMove() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
skipWalMove(boolean) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets skip moving WAL files in PITR case.
skipWalMove() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
skipWalMove(boolean) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets skip moving WAL files in PITR case.
slaveLost(SchedulerDriver, Protos.SlaveID) - Method in class org.apache.ignite.mesos.IgniteScheduler
sleep() - Method in class org.apache.ignite.cache.store.cassandra.common.RandomSleeper
Sleeps
Slf4jLogger - Class in org.apache.ignite.logger.slf4j
SLF4J-based implementation for logging.
Slf4jLogger() - Constructor for class org.apache.ignite.logger.slf4j.Slf4jLogger
Creates new logger.
Slf4jLogger(Logger) - Constructor for class org.apache.ignite.logger.slf4j.Slf4jLogger
Creates new logger with given implementation.
SmoothParametrized<M extends Parametrized<M>> - Interface in org.apache.ignite.ml.optimization
Interface for models which are smooth functions of their parameters.
snapshot() - Static method in class org.apache.ignite.IgniteSystemProperties
Gets snapshot of system properties.
snapshot() - Method in interface org.gridgain.grid.GridGain
Gets an instance of Snapshot facade.
snapshot(long, Collection<File>) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
snapshot(SnapshotInfoParams) - Method in interface org.gridgain.grid.persistentstore.GridSnapshot
Collects extended snapshot information based on the snapshot ID.
snapshot(long, Collection<SnapshotPath>, IgniteBiClosure<String, CacheConfiguration, CacheConfiguration>, boolean, SnapshotSecurityLevel, boolean) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Getting snapshot.
SNAPSHOT_DIR_SUFFIX - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Snapshot directory suffix.
SNAPSHOT_OPERATION_CANCEL_ERROR_MSG - Static variable in interface org.gridgain.grid.persistentstore.SnapshotFuture
Snap op cancel message.
SNAPSHOT_WAL_DIR - Static variable in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Snapshot wal directory.
snapshotAttributes() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
ConsistentId -> (AttributeName -> AttributeValue) Snapshot attributes (for example, path where snapshot files saved)
snapshotAttributes() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
 
SnapshotChainMode - Enum in org.gridgain.grid.persistentstore
There could be connection between different snapshots.
SnapshotCommonParams - Class in org.gridgain.grid.persistentstore
Common parameters for all snapshot operations.
SnapshotCommonParams() - Constructor for class org.gridgain.grid.persistentstore.SnapshotCommonParams
Default constructor.
SnapshotCommonParams(int) - Constructor for class org.gridgain.grid.persistentstore.SnapshotCommonParams
 
snapshotCompressionOption() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Compression option.
SnapshotConfiguration - Class in org.gridgain.grid.configuration
GridGain snapshot configuration.
SnapshotConfiguration() - Constructor for class org.gridgain.grid.configuration.SnapshotConfiguration
 
SnapshotConfiguration(SnapshotConfiguration) - Constructor for class org.gridgain.grid.configuration.SnapshotConfiguration
 
SnapshotCreateParams - Class in org.gridgain.grid.persistentstore
Additional parameters to perform snapshot create operation.
SnapshotCreateParams() - Constructor for class org.gridgain.grid.persistentstore.SnapshotCreateParams
Default constructor.
SnapshotCreateParams(CompressionOption, int) - Constructor for class org.gridgain.grid.persistentstore.SnapshotCreateParams
 
SnapshotCreateParams(CompressionOption, int, int) - Constructor for class org.gridgain.grid.persistentstore.SnapshotCreateParams
 
SnapshotCreateParams(CompressionOption, int, int, boolean) - Constructor for class org.gridgain.grid.persistentstore.SnapshotCreateParams
 
SnapshotCreateParams(CompressionOption, int, int, boolean, String) - Constructor for class org.gridgain.grid.persistentstore.SnapshotCreateParams
 
SnapshotCreateParams(CompressionOption, int, int, boolean, String, String) - Constructor for class org.gridgain.grid.persistentstore.SnapshotCreateParams
 
SnapshotDigestRegistryCache - Class in org.gridgain.grid.persistentstore.snapshot.file
Loads and caches snapshot digest registries.
SnapshotDigestRegistryCache(IgniteConfiguration, long, SnapshotPath, MessageDigestFactory, SnapshotRegistryTransformer, SnapshotSecurityLevel) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
 
snapshotDirectory() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
 
SnapshotEncryptionDigestOutputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
Encryption output stream with a digest.
SnapshotEncryptionDigestOutputStream(OutputStream, MessageDigest, SnapshotOutputStreamListener, GroupKey, EncryptionSpi, int) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.SnapshotEncryptionDigestOutputStream
 
snapshotEncryptionOptions() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
Returns an encryption options for snapshot.
SnapshotEncryptionOutputStream - Class in org.gridgain.grid.persistentstore.snapshot.file
Encryption output stream.
SnapshotEncryptionOutputStream(OutputStream, SnapshotOutputStreamListener, GroupKey, EncryptionSpi, int) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.SnapshotEncryptionOutputStream
 
SnapshotEvent - Class in org.gridgain.grid.events
Grid snapshot event.
SnapshotEvent() - Constructor for class org.gridgain.grid.events.SnapshotEvent
No-arg constructor.
SnapshotEvent(ClusterNode, String, int) - Constructor for class org.gridgain.grid.events.SnapshotEvent
Creates snapshot event with given parameters.
SnapshotEvent(ClusterNode, String, int, long, Throwable) - Constructor for class org.gridgain.grid.events.SnapshotEvent
Creates snapshot event with given parameters.
snapshotFinishTime(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets one of the last snapshot finish times by it's relative index.
SnapshotFuture<T> - Interface in org.gridgain.grid.persistentstore
Snapshot creation future that completes when snapshot is finished.
snapshotId() - Method in class org.gridgain.grid.events.SnapshotEvent
Returns snapshot ID.
snapshotId() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
 
snapshotId(long) - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
Sets snapshot ID to check.
snapshotId() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
 
snapshotId(long) - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
Sets snapshot ID to copy.
snapshotId() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
 
snapshotId(long) - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
Sets snapshot ID to move.
snapshotId() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
 
snapshotId(long) - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
Sets id of snapshot to restore.
snapshotId() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Gets snapshot ID.
snapshotId() - Method in class org.gridgain.grid.persistentstore.SnapshotInfoParams
 
snapshotId(long) - Method in class org.gridgain.grid.persistentstore.SnapshotInfoParams
Sets snapshot ID to copy.
snapshotId(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets one of the last snapshot IDs by it's relative index.
snapshotId() - Method in interface org.gridgain.grid.persistentstore.SnapshotOperationInfo
 
SnapshotInfo - Interface in org.gridgain.grid.persistentstore
Interface provides basic information about snapshot.
SnapshotInfoEx - Interface in org.gridgain.grid.persistentstore
Extended snapshot info
SnapshotInfoParams - Class in org.gridgain.grid.persistentstore
Parameters for getting extended snapshot operation.
SnapshotInfoParams() - Constructor for class org.gridgain.grid.persistentstore.SnapshotInfoParams
 
SnapshotInputStreamFactory - Class in org.gridgain.grid.persistentstore.snapshot.file
Factory of snapshot input streams.
SnapshotInputStreamFactory(IgniteConfiguration, long, SnapshotPath, MessageDigestFactory, SnapshotRegistryTransformer, SnapshotSecurityLevel, RecordSerializerFactory, SnapshotEncryptionOptions, EncryptionSpi) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.SnapshotInputStreamFactory
 
SnapshotIssue - Class in org.gridgain.grid.persistentstore
DTO fro snapshot issue
SnapshotIssue(String, int, String) - Constructor for class org.gridgain.grid.persistentstore.SnapshotIssue
 
SnapshotMetricsMXBean - Interface in org.gridgain.grid.persistentstore
Snapshot metrics used to obtain statistics on snapshots.
SnapshotMXBean - Interface in org.gridgain.grid.persistentstore
Snapshot metrics used to obtain statistics on snapshots.
snapshotOperation() - Method in interface org.gridgain.grid.persistentstore.SnapshotFuture
 
snapshotOperation(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets one of the last snapshot operation types by it's relative index.
SnapshotOperationInfo - Interface in org.gridgain.grid.persistentstore
Snapshot operation information.
SnapshotOperationIssue - Class in org.gridgain.grid.persistentstore
Class which describe issue during snapshot operations.
SnapshotOperationIssue() - Constructor for class org.gridgain.grid.persistentstore.SnapshotOperationIssue
Default constructor for serialization.
SnapshotOperationIssue(UUID, String, int, String) - Constructor for class org.gridgain.grid.persistentstore.SnapshotOperationIssue
 
snapshotOperationParallelism() - Method in class org.gridgain.grid.persistentstore.SnapshotCommonParams
Snapshot Operation parallelism level.
SnapshotOperationType - Enum in org.gridgain.grid.persistentstore
Snapshot operation types.
SnapshotOutputStreamFactory - Class in org.gridgain.grid.persistentstore.snapshot.file
Factory of SnapshotOutputStream, creates either compressed or uncompressed input stream depending on configuration.
SnapshotOutputStreamFactory(CompressionOption, int, MessageDigestFactory, SnapshotMetricsMXBeanImpl, SnapshotEncryptionOptions, EncryptionSpi, int) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.SnapshotOutputStreamFactory
 
SnapshotPath - Class in org.gridgain.grid.persistentstore
Snapshot path representation.
SnapshotPath.FileSnapshotPathBuilder - Class in org.gridgain.grid.persistentstore
Builder for file system location.
SnapshotPath.SftpSnapshotPathBuilder - Class in org.gridgain.grid.persistentstore
Builder for SFTP location.
SnapshotPathFactory - Class in org.gridgain.grid.persistentstore.snapshot.file.remote
Factory for SnapshotPath.
SnapshotPathFactory() - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathFactory
 
SnapshotPathOperationsHelper - Class in org.gridgain.grid.persistentstore.snapshot.file.remote
Helper for operations with SnapshotPath.
SnapshotPathOperationsHelper() - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.remote.SnapshotPathOperationsHelper
 
SnapshotProgress - Class in org.gridgain.grid.persistentstore
Per node snapshot operation progress
SnapshotProgress(long, long, double, long) - Constructor for class org.gridgain.grid.persistentstore.SnapshotProgress
 
SnapshotRegistryTransformer - Interface in org.gridgain.grid.persistentstore
Snapshot file registry transformer.
SnapshotsCatalogConnectorConfiguration - Class in org.gridgain.grid.configuration
Deprecated.
Snapshot Catalog functionality was removed from GridGain completely as obsolete. Providing configuration for Catalog Connector won't have any effect.
SnapshotsCatalogConnectorConfiguration() - Constructor for class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
 
SnapshotSecurityLevel - Enum in org.gridgain.grid.persistentstore
The possible modes of snapshot security.
snapshotStartTime(int) - Method in interface org.gridgain.grid.persistentstore.SnapshotMetricsMXBean
Gets one of the last snapshot start times by it's relative index.
SnapshotStatus - Class in org.gridgain.grid.persistentstore
Reflect the status of ongoing snapshot operation
SnapshotStatus(IgniteUuid, SnapshotOperationInfo, Map<UUID, SnapshotProgress>, long, long, int, boolean) - Constructor for class org.gridgain.grid.persistentstore.SnapshotStatus
 
SnapshotUpdateOperationParams - Class in org.gridgain.grid.persistentstore
Class which contain additional parameters for snapshot operation (COPY, MOVE, DELETE).
SnapshotUpdateOperationParams() - Constructor for class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
Default constructor.
SnapshotUpdateOperationParams(SnapshotChainMode) - Constructor for class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
 
SnapshotUpdateOperationParams(SnapshotChainMode, boolean, boolean, Integer) - Constructor for class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
 
SnapshotUpdateOperationParams.Builder - Class in org.gridgain.grid.persistentstore
Builder for SnapshotUpdateOperationParameters
snapshotWorkingDirectory() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
sndMsgLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
SocketMessageConverter<T> - Interface in org.apache.ignite.stream.socket
Socket message converter.
SocketStreamer<T,K,V> - Class in org.apache.ignite.stream.socket
Server that receives data from TCP socket, converts it to key-value pairs using StreamTupleExtractor and streams into IgniteDataStreamer instance.
SocketStreamer() - Constructor for class org.apache.ignite.stream.socket.SocketStreamer
 
solve(double, double, double, double, double, boolean, double[]) - Method in class org.apache.ignite.ml.math.isolve.lsqr.AbstractLSQR
Solves given Sparse Linear Systems.
solve(Vector) - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
 
solve(Matrix) - Method in class org.apache.ignite.ml.math.primitives.matrix.LUDecomposition
 
sort() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Sorts this vector in ascending order.
sort() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Sorts this vector in ascending order.
sort() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Sorts this vector in ascending order.
sort(int) - Method in class org.apache.ignite.ml.tree.data.DecisionTreeData
Sorts data by specified column in ascending order.
SortedEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.sorted
Cache eviction policy which will select the minimum cache entry for eviction.
SortedEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with all defaults.
SortedEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with maximum size.
SortedEvictionPolicy(int, Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with given maximum size and given entry comparator.
SortedEvictionPolicy(int, int, Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with given maximum size, eviction batch size and entries comparator.
SortedEvictionPolicy(Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with given maximum size and given entry comparator.
SortedEvictionPolicyFactory<K,V> - Class in org.apache.ignite.cache.eviction.sorted
Factory class for SortedEvictionPolicy.
SortedEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
 
SortedEvictionPolicyFactory(int) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
 
SortedEvictionPolicyFactory(int, int, long) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
 
SortedEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.sorted
MBean for sorted eviction policy.
SPACE - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
span() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets span instance.
span(Span) - Method in class org.apache.ignite.events.DiscoveryEvent
Set span.
SpanStatus - Enum in org.apache.ignite.spi.tracing
Various statuses for Spans execution.
SparkModelParser - Class in org.apache.ignite.ml.sparkmodelparser
Parser of Spark models.
SparkModelParser() - Constructor for class org.apache.ignite.ml.sparkmodelparser.SparkModelParser
 
SparseMatrix - Class in org.apache.ignite.ml.math.primitives.matrix.impl
Sparse local onheap matrix with SparseVector as rows.
SparseMatrix() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
 
SparseMatrix(int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.SparseMatrix
Construct new SparseMatrix.
SparseMatrixStorage - Class in org.apache.ignite.ml.math.primitives.matrix.storage
Storage for sparse, local, on-heap matrix.
SparseMatrixStorage() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
 
SparseMatrixStorage(int, int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
 
SparseVector - Class in org.apache.ignite.ml.math.primitives.vector.impl
Local on-heap sparse vector based on hash map storage.
SparseVector() - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
 
SparseVector(Map<Integer, Double>, boolean) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
 
SparseVector(int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
 
SparseVectorStorage - Class in org.apache.ignite.ml.math.primitives.vector.storage
Sparse, local, on-heap vector storage.
SparseVectorStorage() - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
 
SparseVectorStorage(Map<Integer, ? extends Serializable>, boolean) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
 
SparseVectorStorage(int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
 
SpatialIndex<L> - Interface in org.apache.ignite.ml.knn.utils.indices
An index that works with spatial data and allows to quickly find k closest element.
SpatialIndexType - Enum in org.apache.ignite.ml.knn.utils.indices
Spatial index type.
specificity() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
Returns Specificity (SPC) or True Negative Rate (TNR).
spiAdapter - Variable in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
 
spiContext() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
 
spiCtx - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
SpiQuery<K,V> - Class in org.apache.ignite.cache.query
Query to be used by IndexingSpi implementations.
SpiQuery() - Constructor for class org.apache.ignite.cache.query.SpiQuery
 
SpiSpecificSpan - Interface in org.apache.ignite.spi.tracing
Logical piece of a trace that insulates spi specific logic.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.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.isolated.IsolatedDiscoverySpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This method is called to start SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.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.isolated.IsolatedDiscoverySpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called to stop SPI.
spiStop() - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This method is called to stop SPI.
split(int, T) - Method in class org.apache.ignite.compute.ComputeTaskSplitAdapter
This is a simplified version of ComputeTask.map(List, Object) method.
split(double) - Method in class org.apache.ignite.ml.selection.split.TrainTestDatasetSplitter
Splits dataset into train and test subsets.
split(double, double) - Method in class org.apache.ignite.ml.selection.split.TrainTestDatasetSplitter
Splits dataset into train and test subsets.
split(TreeNode) - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeSplit
Split node from parameter onto two children nodes.
spr(Double, DenseVector, DenseVector) - Static method in class org.apache.ignite.ml.math.Blas
Adds alpha * v * v.t to a matrix in-place.
spr(Double, SparseVector, DenseVector) - Static method in class org.apache.ignite.ml.math.Blas
 
SpringApplicationContextResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of Spring ApplicationContext resource.
SpringCacheManager - Class in org.apache.ignite.cache.spring
Implementation of Spring cache abstraction based on Ignite cache.
SpringCacheManager() - Constructor for class org.apache.ignite.cache.spring.SpringCacheManager
 
SpringResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of resource from Spring ApplicationContext.
SpringResource.DEFAULT - Class in org.apache.ignite.resources
Dummy class to compensate for impossibility of having default null value for annotation method.
SpringTransactionManager - Class in org.apache.ignite.transactions.spring
Implementation of Spring transaction abstraction based on Ignite transaction.
SpringTransactionManager() - Constructor for class org.apache.ignite.transactions.spring.SpringTransactionManager
Constructs the transaction manager with no target Ignite instance.
sql() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
sql() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
SqlCacheException - Exception in org.apache.ignite.cache.query.exceptions
General SQL query exception.
SqlCacheException(String, int, Throwable) - Constructor for exception org.apache.ignite.cache.query.exceptions.SqlCacheException
 
SqlConfiguration - Class in org.apache.ignite.configuration
The configuration of the SQL query subsystem.
SqlConfiguration() - Constructor for class org.apache.ignite.configuration.SqlConfiguration
 
SqlConnectorConfiguration - Class in org.apache.ignite.configuration
Deprecated.
SqlConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Creates SQL connector configuration with all default values.
SqlConnectorConfiguration(SqlConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Creates SQL connector configuration by copying all properties from given configuration.
SqlDatasetBuilder - Class in org.apache.ignite.ml.sql
Subclass of CacheBasedDatasetBuilder that should be used to work with SQL tables.
SqlDatasetBuilder(Ignite, String) - Constructor for class org.apache.ignite.ml.sql.SqlDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset with default predicate that passes all upstream entries to dataset.
SqlDatasetBuilder(Ignite, String, IgniteBiPredicate<Object, BinaryObject>) - Constructor for class org.apache.ignite.ml.sql.SqlDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset.
SqlDatasetBuilder(Ignite, String, IgniteBiPredicate<Object, BinaryObject>, UpstreamTransformerBuilder) - Constructor for class org.apache.ignite.ml.sql.SqlDatasetBuilder
Constructs a new instance of cache based dataset builder that makes CacheBasedDataset.
SqlFieldsQuery - Class in org.apache.ignite.cache.query
SQL Fields query.
SqlFieldsQuery(SqlFieldsQuery) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
Copy constructs SQL fields query.
SqlFieldsQuery(String) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
Constructs SQL fields query.
SqlFieldsQuery(String, boolean) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
Constructs SQL fields query.
SQLFunctions - Class in org.apache.ignite.ml.sql
SQL functions that should be defined and passed into cache configuration to extend list of functions available in SQL interface.
SQLFunctions() - Constructor for class org.apache.ignite.ml.sql.SQLFunctions
 
sqlIndexMaxInlineSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
SqlIndexView - Class in org.apache.ignite.spi.systemview.view
Sql index representation for a SystemView.
SqlIndexView(GridH2Table, IndexInformation) - Constructor for class org.apache.ignite.spi.systemview.view.SqlIndexView
 
SqlMemoryQuotaExceededException - Exception in org.apache.ignite.cache.query.exceptions
The exception is thrown when query memory quota is exceeded.
SqlMemoryQuotaExceededException(String) - Constructor for exception org.apache.ignite.cache.query.exceptions.SqlMemoryQuotaExceededException
 
sqlOnheapCacheMaxSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
SqlQuery<K,V> - Class in org.apache.ignite.cache.query
Deprecated.
Since 2.8, please use SqlFieldsQuery instead.
SqlQuery(String, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Constructs query for the given type name and SQL query.
SqlQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Constructs query for the given type and SQL query.
SqlQueryHistoryView - Class in org.apache.ignite.spi.systemview.view
SQL query history representation for a SystemView.
SqlQueryHistoryView(QueryHistory) - Constructor for class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
SqlQueryView - Class in org.apache.ignite.spi.systemview.view
SQL query representation for a SystemView.
SqlQueryView(GridRunningQueryInfo) - Constructor for class org.apache.ignite.spi.systemview.view.SqlQueryView
 
sqlSchema() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
SqlSchemaView - Class in org.apache.ignite.spi.systemview.view
Sql schema system view representation.
SqlSchemaView(H2Schema) - Constructor for class org.apache.ignite.spi.systemview.view.SqlSchemaView
 
SQLServerDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the Microsoft SQL Server database.
SQLServerDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
 
sqlState() - Method in exception org.apache.ignite.cache.query.exceptions.SqlCacheException
 
SqlTableColumnView - Class in org.apache.ignite.spi.systemview.view
Sql table column representation for a SystemView.
SqlTableColumnView(GridH2Table, Column) - Constructor for class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
SqlTableView - Class in org.apache.ignite.spi.systemview.view
Sql table representation for a SystemView.
SqlTableView(GridH2Table) - Constructor for class org.apache.ignite.spi.systemview.view.SqlTableView
 
SqlViewColumnView - Class in org.apache.ignite.spi.systemview.view
Sql view column representation for a SystemView.
SqlViewColumnView(SqlSystemView, Column) - Constructor for class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
SqlViewView - Class in org.apache.ignite.spi.systemview.view
Sql view representation for a SystemView.
SqlViewView(SqlSystemView) - Constructor for class org.apache.ignite.spi.systemview.view.SqlViewView
 
SQRT - Static variable in class org.apache.ignite.ml.tree.randomforest.data.FeaturesCountSelectionStrategies
 
SQUARE - Static variable in class org.apache.ignite.ml.math.functions.Functions
Function that returns a * a.
SquaredError - Class in org.apache.ignite.ml.composition.boosting.loss
Represent error function as E(label, modelAnswer) = 1/N * (label - prediction)^2
SquaredError() - Constructor for class org.apache.ignite.ml.composition.boosting.loss.SquaredError
 
SslContextFactory - Class in org.apache.ignite.ssl
SSL context factory that provides SSL context configuration with specified key and trust stores.
SslContextFactory() - Constructor for class org.apache.ignite.ssl.SslContextFactory
 
sslEnable - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
SSL enable/disable flag.
SslMode - Enum in org.apache.ignite.client
SSL/TLS modes.
SslProtocol - Enum in org.apache.ignite.client
SSL Protocol.
sslSockFactory - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
SSL socket factory.
sslSrvSockFactory - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
SSL server socket factory.
StackedDatasetTrainer<IS,IA,O,AM extends IgniteModel<IA,O>,L> - Class in org.apache.ignite.ml.composition.stacking
DatasetTrainer encapsulating stacking technique for model training.
StackedDatasetTrainer(DatasetTrainer<AM, L>, IgniteBinaryOperator<IA>, IgniteFunction<IS, IA>, List<DatasetTrainer<IgniteModel<IS, IA>, L>>, IgniteFunction<Vector, IS>, IgniteFunction<IA, Vector>) - Constructor for class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Create instance of this class.
StackedDatasetTrainer(DatasetTrainer<AM, L>, IgniteBinaryOperator<IA>, IgniteFunction<IS, IA>) - Constructor for class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Constructs instance of this class.
StackedDatasetTrainer() - Constructor for class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Constructs instance of this class.
StackedModel<IS,IA,O,AM extends IgniteModel<IA,O>> - Class in org.apache.ignite.ml.composition.stacking
This is a wrapper for model produced by StackedDatasetTrainer.
StackedVectorDatasetTrainer<O,AM extends IgniteModel<Vector,O>,L> - Class in org.apache.ignite.ml.composition.stacking
StackedDatasetTrainer with Vector as submodels input and output.
StackedVectorDatasetTrainer(DatasetTrainer<AM, L>) - Constructor for class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Constructs instance of this class.
StackedVectorDatasetTrainer() - Constructor for class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Constructs instance of this class.
stage() - Method in class org.apache.ignite.lang.IgniteProductVersion
 
stamp() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current stamp.
stamp() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
StandardScalerData - Class in org.apache.ignite.ml.preprocessing.standardscaling
A Service class for StandardScalerTrainer which used for sums holing.
StandardScalerData(double[], double[], long) - Constructor for class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerData
Creates StandardScalerData.
StandardScalerPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.standardscaling
The preprocessing function that makes standard scaling, transforms features to make mean equal to 0 and variance equal to 1.
StandardScalerPreprocessor(double[], double[], Preprocessor<K, V>) - Constructor for class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerPreprocessor
Constructs a new instance of standardscaling preprocessor.
StandardScalerTrainer<K,V> - Class in org.apache.ignite.ml.preprocessing.standardscaling
Trainer of the standard scaler preprocessor.
StandardScalerTrainer() - Constructor for class org.apache.ignite.ml.preprocessing.standardscaling.StandardScalerTrainer
 
start(Map<Object, Object>) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
 
start(SessionFactoryOptions, Map) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
start() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Starts grid component, called on grid start.
start(ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts grid with default configuration.
start(IgniteConfiguration, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts grid with given configuration.
start(String, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts all grids specified within given Spring XML configuration file.
start(URL, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts all grids specified within given Spring XML configuration file URL.
start() - Static method in class org.apache.ignite.Ignition
Starts grid with default configuration.
start(IgniteConfiguration) - Static method in class org.apache.ignite.Ignition
Starts grid with given configuration.
start(String) - Static method in class org.apache.ignite.Ignition
Starts all grids specified within given Spring XML configuration file.
start(URL) - Static method in class org.apache.ignite.Ignition
Starts all grids specified within given Spring XML configuration file URL.
start(InputStream) - Static method in class org.apache.ignite.Ignition
Starts all grids specified within given Spring XML configuration input stream.
start() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
Starts grid component, called on grid start.
start(Handler, ClusterProperties) - Method in class org.apache.ignite.mesos.resource.JettyServer
Starts jetty server.
start(PluginContext) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Starts grid component.
start() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Starts grid component, called on grid start.
start() - Method in interface org.apache.ignite.plugin.CachePluginProvider
Starts grid component.
start(PluginContext) - Method in interface org.apache.ignite.plugin.PluginProvider
Starts grid component.
start(String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
Starts trace exporter on given node with name igniteInstanceName.
start() - Method in class org.apache.ignite.stream.socket.SocketStreamer
Starts streamer.
start(List<LongRunningProcess>) - Method in class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcessManager
Starts the processes by the given specifications.
start(List<R>) - Method in interface org.apache.ignite.tensorflow.core.ProcessManager
Starts the processes by the given specifications.
start(List<R>) - Method in class org.apache.ignite.tensorflow.core.ProcessManagerWrapper
Starts the processes by the given specifications.
start() - Method in class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Starts the process in separate thread.
start(GridKernalContext, CacheConfiguration) - Method in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
Initializes entry compression strategy.
start() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Starts data center replication for this cache.
start() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Starts grid component, called on grid start.
start() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Starts grid component, called on grid start.
start() - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Starts grid component, called on grid start.
start() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Starts SPI.
start() - Method in interface org.gridgain.grid.ru.GridGainRollingUpgrade
Enables rolling upgrade mode.
start() - Method in interface org.gridgain.grid.ru.RollingUpgradeMXBean
Allows to enable rolling upgrade mode.
start() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Starts grid component, called on grid start.
start() - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Starts grid component, called on grid start.
START_TIMESTAMP_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
START_TIMESTAMP_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
startAndWait() - Method in class org.apache.ignite.tensorflow.core.util.NativeProcessRunner
Starts the native process and waits it to be completed successfully or with exception.
startClient(ClientConfiguration) - Static method in class org.apache.ignite.Ignition
Initializes new instance of IgniteClient.
StartCommand - Class in org.apache.ignite.tensorflow.submitter.command
Command "start" that is used to start a new TensorFlow cluster on top of Apache Ignite.
StartCommand() - Constructor for class org.apache.ignite.tensorflow.submitter.command.StartCommand
 
startCopy(long, SnapshotPath) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Marks directory with copy marker file, to indicate the beginning of copy operation.
started() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Checks if IgniteSpiAdapter.onBeforeStart() has been called on this SPI instance.
startedCaches() - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
startInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformly formatted message for SPI start.
startMessageProcess(TcpDiscoveryAbstractMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
startNodes(File, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s).
startNodes(Collection<Map<String, Object>>, Map<String, Object>, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s).
startNodesAsync(File, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s) asynchronously.
startNodesAsync(Collection<Map<String, Object>>, Map<String, Object>, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s) asynchronously.
startReplication(String) - Method in interface org.gridgain.grid.GridDr
Starts data center replication for particular sender cache.
startStopwatch() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Starts startup stopwatch.
startTime() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Get defragmentation's start time.
startTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
startTime() - Method in interface org.apache.ignite.transactions.Transaction
Start time of this transaction.
startTime() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets state transfer start timestamp.
startTime() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
 
state() - Method in interface org.apache.ignite.client.ClientCluster
Gets current cluster state.
state(ClusterState) - Method in interface org.apache.ignite.client.ClientCluster
Changes current cluster state to given newState cluster state.
state() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
 
state() - Method in class org.apache.ignite.events.ClusterStateChangeStartedEvent
 
state() - Method in interface org.apache.ignite.IgniteCluster
Gets current cluster state.
state(ClusterState) - Method in interface org.apache.ignite.IgniteCluster
Changes current cluster state to given newState cluster state.
state() - Static method in class org.apache.ignite.Ignition
Gets state of grid default grid.
state(String) - Static method in class org.apache.ignite.Ignition
Gets states of named Ignite instance.
state() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Gets current read state.
state() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Gets current message state.
state() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
state() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
state() - Method in interface org.apache.ignite.transactions.Transaction
Gets current transaction state value.
stateless() - Method in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
Gets flag indicating whether this strategy is stateless.
stateTransfer(String, byte...) - Method in interface org.gridgain.grid.GridDr
Starts full state transfer for the given sender cache.
stateTransfer(String, boolean, byte...) - Method in interface org.gridgain.grid.GridDr
Starts full state transfer for the given sender cache.
stateTransferBufferSize() - Method in interface org.gridgain.grid.dr.DrSenderOutMetrics
Gets current state transfer buffer size.
stateTransferId() - Method in interface org.gridgain.grid.dr.store.DrSenderStoreEntry
Deprecated.
staticallyConfigured() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
staticCreateEntityKey(Object, EntityPersister, String) - Static method in class org.apache.ignite.cache.hibernate.HibernateKeyWrapper
 
stats - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Statistics.
statsPrintFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Statistics print frequency.
status() - Method in interface org.gridgain.grid.cache.dr.CacheDrSenderMetrics
Gets data center replication status.
statusCode() - Method in exception org.apache.ignite.cache.query.exceptions.SqlCacheException
 
StatusMatchTable - Class in org.apache.ignite.spi.tracing.opencensus
Table to match OpenCensus span statuses with declared in Tracing SPI.
statusUpdate(SchedulerDriver, Protos.TaskStatus) - Method in class org.apache.ignite.mesos.IgniteScheduler
std() - Method in class org.apache.ignite.ml.dataset.primitive.SimpleDataset
Calculates standard deviation by all columns.
std() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
 
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.
StepFunction<T extends ImpurityMeasure<T>> - Class in org.apache.ignite.ml.tree.impurity.util
Step function described by x and y points.
StepFunction(double[], T[]) - Constructor for class org.apache.ignite.ml.tree.impurity.util.StepFunction
Constructs a new instance of step function.
StepFunctionCompressor<T extends ImpurityMeasure<T>> - Interface in org.apache.ignite.ml.tree.impurity.util
Base interface for step function compressors which reduces step function size.
stgy - Variable in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
 
stgy - Variable in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
 
stop() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
stop() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
Stops grid component, called on grid shutdown.
stop(boolean) - Static method in class org.apache.ignite.Ignition
Stops default grid.
stop(String, boolean) - Static method in class org.apache.ignite.Ignition
Stops named Ignite instance.
stop() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.mesos.resource.JettyServer
Stops server.
stop() - Method in class org.apache.ignite.messaging.MessagingListenActor
This method instructs underlying implementation to stop receiving new messages and unregister the message listener.
stop(Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method sends the response message to the original sender node and instructs underlying implementation to stop receiving new messages and unregister the message listener.
stop(boolean) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Stops grid component.
stop(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops default grid instance.
stop(String, boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops named Ignite instance.
stop() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Stops grid component, called on grid shutdown.
stop(boolean) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Stops grid component.
stop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
Stops grid component.
stop() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
Stops trace exporter.
stop() - Method in class org.apache.ignite.stream.socket.SocketStreamer
Stops streamer.
stop(Map<UUID, List<UUID>>, boolean) - Method in class org.apache.ignite.tensorflow.core.longrunning.LongRunningProcessManager
Stops the given processes.
stop(Map<UUID, List<UUID>>, boolean) - Method in interface org.apache.ignite.tensorflow.core.ProcessManager
Stops the given processes.
stop(Map<UUID, List<UUID>>, boolean) - Method in class org.apache.ignite.tensorflow.core.ProcessManagerWrapper
Stops the given processes.
stop() - Method in class org.apache.ignite.tensorflow.core.util.AsyncNativeProcessRunner
Stops the process.
stop() - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Stops data center replication for this cache.
stop() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
Stops grid component, called on grid shutdown.
stop() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Stops grid component, called on grid shutdown.
stop() - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Stops grid component, called on grid shutdown.
stop() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileDatabaseSnapshotSpi
Stops SPI.
stop() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Stops grid component, called on grid shutdown.
stop() - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Stops grid component, called on grid shutdown.
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.
stopClusterIfExists(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGatewayManager
Stops TensorFlow cluster.
stopClusterIfExists(UUID) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Stops TensorFlow cluster.
StopCommand - Class in org.apache.ignite.tensorflow.submitter.command
Command "stop" that is used to stop TensorFlow cluster.
StopCommand() - Constructor for class org.apache.ignite.tensorflow.submitter.command.StopCommand
 
stopInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformly format message for SPI stop.
stopLocalListen(IgnitePredicate<? extends Event>, int...) - Method in interface org.apache.ignite.IgniteEvents
Removes local event listener.
stopLocalListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Unregisters local listener for given topic on local node only.
StopNodeFailureHandler - Class in org.apache.ignite.failure
Handler will stop node in case of critical error using IgnitionEx.stop(nodeName, true, true) call.
StopNodeFailureHandler() - Constructor for class org.apache.ignite.failure.StopNodeFailureHandler
 
StopNodeOrHaltFailureHandler - Class in org.apache.ignite.failure
Handler will try to stop node if tryStop value is true.
StopNodeOrHaltFailureHandler() - Constructor for class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Default constructor.
StopNodeOrHaltFailureHandler(boolean, long) - Constructor for class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
 
stopNodes() - Method in interface org.apache.ignite.IgniteCluster
Stops nodes satisfying optional set of predicates.
stopNodes(Collection<UUID>) - Method in interface org.apache.ignite.IgniteCluster
Stops nodes defined by provided IDs.
stopped() - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
Gets stop flag.
stopProcess() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
Called on discovery coordinator node after listener is notified.
stopRemoteListen(UUID) - Method in interface org.apache.ignite.IgniteEvents
Stops listening to remote events.
stopRemoteListen(UUID) - Method in interface org.apache.ignite.IgniteMessaging
Unregisters all listeners identified with provided operation ID on all nodes in the cluster group.
stopRemoteListenAsync(UUID) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously stops listening to remote events.
stopRemoteListenAsync(UUID) - Method in interface org.apache.ignite.IgniteMessaging
Asynchronously unregisters all listeners identified with provided operation ID on all nodes in the cluster group.
stopReplication(String) - Method in interface org.gridgain.grid.GridDr
Stops data center replication for particular sender cache.
stopThreadById(long) - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Stops thread by id, if exists.
stopThreadByUniqueName(String) - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Stops thread by name, if exists and unique.
stopWarmUp() - Method in interface org.apache.ignite.mxbean.WarmUpMXBean
Stop warm-up.
StorageConstants - Interface in org.apache.ignite.ml.math
Support for different modes of accessing data storage.
storageGet(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
 
storageGet(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
storageGetRaw(int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets serializable value from storage and casts it to targe type T.
storageMode() - Method in interface org.apache.ignite.ml.math.primitives.matrix.MatrixStorage
 
storageMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
storageMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
storageMode() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
StorageOpsMetrics - Interface in org.apache.ignite.ml.math
Storage and operation cost characteristics.
storageSet(int, int, double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
 
storageSet(int, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
 
storageSetRaw(int, Serializable) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Sets serializable value.
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(byte[], byte[], int, IgniteUuid) - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Store data.
store(byte[], byte[], int, IgniteUuid) - Method in interface org.gridgain.grid.dr.store.DrSenderStore
Deprecated.
Synchronous state transfer uses dedicated FST buffer.
store(byte[], byte[], int) - Method in interface org.gridgain.grid.dr.store.DrSenderStore
Store data.
store0(byte[], byte[], int, IgniteUuid) - Method in class org.gridgain.grid.dr.store.DrAbstractSenderStore
Add data to store.
store0(byte[], byte[], int, IgniteUuid) - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Add data to store.
store0(byte[], byte[], int, IgniteUuid) - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
Add data to store.
storeSize() - Method in interface org.gridgain.grid.dr.DrSenderOutMetrics
Deprecated.
Because this is a store metric. It doesn't have any relations to per cache, per-DC sender output metrics.
strategies() - Method in class org.gridgain.grid.cache.compress.GzipCompressionConfiguration
Getting cache entry compression strategies.
strategies() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
Getting cache entry compression strategies.
StreamAdapter<T,K,V> - Class in org.apache.ignite.stream
Convenience adapter for streamers.
StreamAdapter() - Constructor for class org.apache.ignite.stream.StreamAdapter
Empty constructor.
StreamAdapter(IgniteDataStreamer<K, V>, StreamSingleTupleExtractor<T, K, V>) - Constructor for class org.apache.ignite.stream.StreamAdapter
Stream adapter.
StreamAdapter(IgniteDataStreamer<K, V>, StreamMultipleTupleExtractor<T, K, V>) - Constructor for class org.apache.ignite.stream.StreamAdapter
Stream adapter.
StreamMultipleTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
Stream tuple extractor to convert a single message to zero, one or many tuples.
StreamReceiver<K,V> - Interface in org.apache.ignite.stream
Updates cache with batch of entries.
StreamSingleTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
Stream tuple extractor to convert a message to a single Ignite key-value tuple.
StreamTransformer<K,V> - Class in org.apache.ignite.stream
Convenience adapter to transform update existing values in streaming cache based on the previously cached value.
StreamTransformer() - Constructor for class org.apache.ignite.stream.StreamTransformer
 
StreamTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
Deprecated.
Will be removed in 2.0.0.
StreamVisitor<K,V> - Class in org.apache.ignite.stream
Convenience adapter to visit every key-value tuple in the stream.
StreamVisitor() - Constructor for class org.apache.ignite.stream.StreamVisitor
 
STRING - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
STRING - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
STRING() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
StringCoordVectorizer(String...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.StringCoordVectorizer
Creates an instance of Vectorizer.
StringEncoderPreprocessor<K,V> - Class in org.apache.ignite.ml.preprocessing.encoding.stringencoder
Preprocessing function that makes String encoding.
StringEncoderPreprocessor(Map<String, Integer>[], Preprocessor<K, V>, Set<Integer>) - Constructor for class org.apache.ignite.ml.preprocessing.encoding.stringencoder.StringEncoderPreprocessor
Constructs a new instance of String Encoder preprocessor.
stripe() - Method in class org.apache.ignite.thread.IgniteThread
 
StripedExecutorMXBean - Interface in org.apache.ignite.mxbean
MBean that provides access to information about striped executor service.
StripedExecutorTaskView - Class in org.apache.ignite.spi.systemview.view
StripedExecutor task representation for a SystemView.
StripedExecutorTaskView(StripedExecutor.Stripe, Runnable) - Constructor for class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
stripeIndex() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
stripesCount() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
Stub(T) - Constructor for class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy.Stub
Create an instance of Stub
subIntervals(int) - Method in interface org.apache.ignite.mxbean.DataRegionMetricsMXBean
subIntervals(int) - Method in interface org.apache.ignite.mxbean.DataStorageMetricsMXBean
subIntervals(int) - Method in interface org.apache.ignite.mxbean.MemoryMetricsMXBean
Deprecated.
Sets a number of sub-intervals the whole MemoryMetricsMXBean.rateTimeInterval(long) will be split into to calculate MemoryMetricsMXBean.getAllocationRate() and MemoryMetricsMXBean.getEvictionRate() rates (5 by default).
subIntervals(int) - Method in interface org.apache.ignite.mxbean.PersistenceMetricsMXBean
Deprecated.
Sets a number of sub-intervals the whole PersistenceMetricsMXBean.rateTimeInterval(long) will be split into to calculate rate-based metrics.
subject() - Method in class org.gridgain.grid.events.AuthorizationEvent
Gets authenticated subject.
subject(SecuritySubject) - Method in class org.gridgain.grid.events.AuthorizationEvent
Sets authenticated subject.
subjectAddress() - Method in class org.gridgain.grid.events.AuthenticationEvent
Gets subject address of the event.
subjectAddress(InetSocketAddress) - Method in class org.gridgain.grid.events.AuthenticationEvent
Sets subject address of the event.
subjectAllAddress() - Method in class org.gridgain.grid.events.AuthenticationEvent
Gets All the subject addresses of the event.
subjectAllAddresses(List<InetSocketAddress>) - Method in class org.gridgain.grid.events.AuthenticationEvent
Sets All the subject addresses of the event.
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.ServiceEvent
Gets security subject ID initiated this service event.
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.
subjectId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
subjectId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
subjectId() - Method in class org.gridgain.grid.events.AuthenticationEvent
Gets subject ID that triggered the event.
subjectId(UUID) - Method in class org.gridgain.grid.events.AuthenticationEvent
Sets subject ID that triggered the event.
SubjectRegexPredicate - Class in org.gridgain.grid.security.certificate
This predicate checks X.509 certificates' Subject Distinguished Names to match supplied regular expression Pattern.
SubjectRegexPredicate(String) - Constructor for class org.gridgain.grid.security.certificate.SubjectRegexPredicate
Constructs X.509 Subject DN regular expression predicate.
subjectType() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets subject type.
subjectType(SecuritySubjectType) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets subject type.
subjectType() - Method in class org.gridgain.grid.events.AuthenticationEvent
Gets subject type that triggered the event.
subjectType(SecuritySubjectType) - Method in class org.gridgain.grid.events.AuthenticationEvent
Sets subject type that triggered the event.
submit(IgniteSupplier<T>) - Method in class org.apache.ignite.ml.environment.parallelism.DefaultParallelismStrategy
Submit task.
submit(IgniteSupplier<T>) - Method in class org.apache.ignite.ml.environment.parallelism.NoParallelismStrategy
Submit task.
submit(IgniteSupplier<T>) - Method in interface org.apache.ignite.ml.environment.parallelism.ParallelismStrategy
Submit task.
submit(List<IgniteSupplier<T>>) - Method in interface org.apache.ignite.ml.environment.parallelism.ParallelismStrategy
Submit the list of tasks.
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
submodels() - Method in class org.apache.ignite.ml.composition.combinators.parallel.ModelsParallelComposition
List of submodels constituting this model.
subscribe(Consumer<Optional<TensorFlowCluster>>) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGateway
Subscribers the specified subscriber on the upstream events.
subtract(GiniImpurityMeasure) - Method in class org.apache.ignite.ml.tree.impurity.gini.GiniImpurityMeasure
Subtracts the given impurity for this.
subtract(T) - Method in interface org.apache.ignite.ml.tree.impurity.ImpurityMeasure
Subtracts the given impurity for this.
subtract(MSEImpurityMeasure) - Method in class org.apache.ignite.ml.tree.impurity.mse.MSEImpurityMeasure
Subtracts the given impurity for this.
sum() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Gets sum of all elements in the matrix.
sum() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Gets sum of all elements in the matrix.
sum() - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets the sum of all elements in this vector.
sum() - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets the sum of all elements in this vector.
sum() - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets the sum of all elements in this vector.
sum(List<NesterovParameterUpdate>) - Static method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovParameterUpdate
Get sum of parameters updates.
SUM - Static variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Sums updates returned by different trainings.
SUM_LOCAL - Static variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Sums updates during one training.
SUM_LOCAL - Static variable in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDParameterUpdate
Method used to get total update of all parallel trainings.
sums() - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Gets the array of sums of values in partition for each feature in the dataset.
supported(SecuritySubjectType) - Method in interface org.gridgain.grid.security.Authenticator
Checks if given subject is supported by this authenticator.
supported(SecuritySubjectType) - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
Checks if given subject is supported by this authenticator.
supported(SecuritySubjectType) - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Checks if given subject is supported by this authenticator.
supported(SecuritySubjectType) - Method in interface org.gridgain.grid.security.jaas.JaasCallbackHandlerFactory
Checks if given subject is supported by this factory.
supported(SecuritySubjectType) - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Checks if given subject is supported by this authenticator.
SupportedSparkModels - Enum in org.apache.ignite.ml.sparkmodelparser
List of supported Spark models.
supportsCommunicationFailureResolve() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
supportsCommunicationFailureResolve() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
supportsCommunicationFailureResolve() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
suspend() - Method in interface org.apache.ignite.transactions.Transaction
Suspends a transaction.
SVMLinearClassificationModel - Class in org.apache.ignite.ml.svm
Base class for SVM linear classification model.
SVMLinearClassificationModel(Vector, double) - Constructor for class org.apache.ignite.ml.svm.SVMLinearClassificationModel
 
SVMLinearClassificationTrainer - Class in org.apache.ignite.ml.svm
Base class for a soft-margin SVM linear classification trainer based on the communication-efficient distributed dual coordinate ascent algorithm (CoCoA) with hinge-loss function.
SVMLinearClassificationTrainer() - Constructor for class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
 
swap() - Method in class org.apache.ignite.lang.IgniteBiTuple
Swaps values.
swapColumns(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Swaps two columns in this matrix.
swapColumns(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Swaps two columns in this matrix.
swapRows(int, int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Swaps two rows in this matrix.
swapRows(int, int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Swaps two rows in this matrix.
SymmetricKeyEncryptionService - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt
Service to encrypt data using symmetric key encryption.
SymmetricKeyEncryptionService() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionService
 
sync() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Tries to sync this file.
syncMode() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
Gets state transfer mode flag.
SyncModelBuilder - Interface in org.apache.ignite.ml.inference.builder
Builder of synchronous inference model.
SyncronousFstAwareStore - Annotation Type in org.gridgain.grid.dr.store
Deprecated.
Synchronous state transfer uses dedicated FST buffer.
syr(Double, SparseVector, DenseMatrix) - Static method in class org.apache.ignite.ml.math.Blas
 
system() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
SystemHelper - Class in org.apache.ignite.cache.store.cassandra.common
Helper class providing system information about the host (ip, hostname, os and etc.)
SystemHelper() - Constructor for class org.apache.ignite.cache.store.cassandra.common.SystemHelper
 
systemPermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Collection of system-wide permissions (events enable/disable, Visor task execution).
systemPermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Collection of system-wide permissions (events enable/disable, Visor task execution).
SystemProperty - Annotation Type in org.apache.ignite
Ignite system property info.
SystemView<R> - Interface in org.apache.ignite.spi.systemview.view
Implementation provides data for some internal Ignite objects.
SystemViewExporterSpi - Interface in org.apache.ignite.spi.systemview
Exporter of system view to the external recepient.
SystemViewRowAttributeWalker<R> - Interface in org.apache.ignite.spi.systemview.view
Utility class for quick iteration over row properties.
SystemViewRowAttributeWalker.AttributeVisitor - Interface in org.apache.ignite.spi.systemview.view
Attribute visitor.
SystemViewRowAttributeWalker.AttributeWithValueVisitor - Interface in org.apache.ignite.spi.systemview.view
Attribute visitor.

T

tableExistenceRequired() - Method in interface org.apache.ignite.cache.store.cassandra.session.BatchExecutionAssistant
Indicates if Cassandra tables existence is required for this batch operation.
tableExistenceRequired() - Method in interface org.apache.ignite.cache.store.cassandra.session.ExecutionAssistant
Indicates if Cassandra table existence is required for an operation.
tableExistenceRequired() - Method in class org.apache.ignite.cache.store.cassandra.session.GenericBatchExecutionAssistant
Indicates if Cassandra tables existence is required for this batch operation.
tableExistenceRequired() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Indicates if Cassandra tables existence is required for this operation.
tableExistenceRequired() - Method in interface org.apache.ignite.cache.store.cassandra.session.transaction.Mutation
Indicates if Cassandra tables existence is required for this operation.
tableExistenceRequired() - Method in class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Indicates if Cassandra tables existence is required for this operation.
tableName() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.BasicJdbcIpFinderDialect
Gets table name in a valid form to use as IP addresses
tableName() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.JdbcIpFinderDialect
Gets table name in a valid form to use as IP addresses
tableName() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.OracleJdbcIpFinderDialect
Gets table name in a valid form to use as IP addresses
tableName() - Method in class org.apache.ignite.spi.systemview.view.SqlIndexView
Returns table name.
tableName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
tableName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns table name.
tag() - Method in interface org.apache.ignite.IgniteCluster
User-defined tag describing the cluster.
tag(String) - Method in interface org.apache.ignite.IgniteCluster
Enables user to add a specific label to the cluster e.g. to describe purpose of the cluster or any its characteristics.
tag(String) - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Changes cluster tag to provided value.
take() - Method in interface org.apache.ignite.IgniteQueue
targetVersion() - Method in class org.gridgain.grid.ru.GridRollingUpgradeStatus
Returns the target version.
taskClassName() - Method in class org.apache.ignite.events.JobEvent
Gets name of task class that triggered this event.
taskClassName(String) - Method in class org.apache.ignite.events.JobEvent
Sets name of the task class that triggered this event.
taskClassName() - Method in class org.apache.ignite.events.TaskEvent
Gets name of task class that triggered this event.
taskClassName() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
taskClassName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
TaskContinuousMapperResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeTaskContinuousMapper resource.
TaskEvent - Class in org.apache.ignite.events
Grid task event.
TaskEvent(ClusterNode, String, int, IgniteUuid, String, String, boolean, UUID) - Constructor for class org.apache.ignite.events.TaskEvent
Creates task event with given parameters.
taskName() - Method in class org.apache.ignite.events.CacheEvent
Gets task name if cache event was caused by an operation initiated within task execution.
taskName() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets the name of the task that executed the query (if any).
taskName() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets the name of the task that executed the query (if any).
taskName() - Method in class org.apache.ignite.events.JobEvent
Gets name of the task that triggered the event.
taskName(String) - Method in class org.apache.ignite.events.JobEvent
Sets name of the task that triggered this event.
taskName() - Method in class org.apache.ignite.events.TaskEvent
Gets name of the task that triggered the event.
taskName() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
taskName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
taskName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
taskName() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
taskNode() - Method in class org.apache.ignite.events.JobEvent
Get node where parent task of the job has originated.
taskNode(ClusterNode) - Method in class org.apache.ignite.events.JobEvent
Sets node where parent task of the job has originated.
taskNodeId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
taskPermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of task names to task permissions.
taskPermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of task names to task permissions.
TaskResult(Map<String, Double>, double[]) - Constructor for class org.apache.ignite.ml.selection.cv.AbstractCrossValidation.TaskResult
 
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.
TaskWithAttributesEvent - Class in org.apache.ignite.events
Grid task event.
TaskWithAttributesEvent(ClusterNode, String, int, IgniteUuid, String, String, boolean, UUID, Map<Object, Object>) - Constructor for class org.apache.ignite.events.TaskWithAttributesEvent
 
TcpCommunicationMetricsListener - Class in org.apache.ignite.spi.communication.tcp
Statistics for TcpCommunicationSpi.
TcpCommunicationMetricsListener(Ignite, IgniteSpiContext) - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
 
TcpCommunicationSpi - Class in org.apache.ignite.spi.communication.tcp
TcpCommunicationSpi is default communication SPI which uses TCP/IP protocol and Java NIO to communicate with other nodes.
TcpCommunicationSpi() - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
TcpCommunicationSpiMBean - Interface in org.apache.ignite.spi.communication.tcp
MBean provide access to TCP-based communication SPI.
TcpDiscoveryAlbIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.elb
AWS Application load balancer(ALB) based IP finder.
TcpDiscoveryAlbIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Creates Application load balancer IP finder instance.
TcpDiscoveryCloudIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.cloud
IP finder for automatic lookup of nodes running in a cloud.
TcpDiscoveryCloudIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Constructor.
TcpDiscoveryElbIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.elb
AWS Classic load balancer based IP finder.
TcpDiscoveryElbIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Creates Classic load balancer IP finder instance.
TcpDiscoveryGoogleStorageIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.gce
Google Cloud Storage based IP finder.
TcpDiscoveryGoogleStorageIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
 
TcpDiscoveryIpFinder - Interface in org.apache.ignite.spi.discovery.tcp.ipfinder
IP finder interface for TcpDiscoverySpi.
TcpDiscoveryIpFinderAdapter - Class in org.apache.ignite.spi.discovery.tcp.ipfinder
IP finder interface implementation adapter.
TcpDiscoveryIpFinderAdapter() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
 
TcpDiscoveryJdbcIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
JDBC-based IP finder.
TcpDiscoveryJdbcIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Constructor.
TcpDiscoveryJdbcIpFinder(JdbcIpFinderDialect) - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
 
TcpDiscoveryKubernetesIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes
IP finder for automatic lookup of Ignite nodes running in Kubernetes environment.
TcpDiscoveryKubernetesIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Creates an instance of Kubernetes IP finder.
TcpDiscoveryKubernetesIpFinder(KubernetesConnectionConfiguration) - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Creates an instance of Kubernetes IP finder.
TcpDiscoveryMulticastIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.multicast
Multicast-based IP finder.
TcpDiscoveryMulticastIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Constructs new IP finder.
TcpDiscoveryS3IpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.s3
AWS S3-based IP finder.
TcpDiscoveryS3IpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Constructor.
TcpDiscoverySharedFsIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs
Shared filesystem-based IP finder.
TcpDiscoverySharedFsIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Constructor.
TcpDiscoverySpi - Class in org.apache.ignite.spi.discovery.tcp
Discovery SPI implementation that uses TCP/IP for node discovery.
TcpDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
TcpDiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery.tcp
Management bean for TcpDiscoverySpi.
TcpDiscoveryVmIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.vm
IP Finder which works only with pre-configured list of IP addresses specified via TcpDiscoveryVmIpFinder.setAddresses(Collection) method.
TcpDiscoveryVmIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Constructs new IP finder.
TcpDiscoveryVmIpFinder(boolean) - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Constructs new IP finder.
TcpDiscoveryZookeeperIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.zk
This TCP Discovery IP Finder uses Apache ZooKeeper (ZK) to locate peer nodes when bootstrapping in order to join the cluster.
TcpDiscoveryZookeeperIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Constructor.
TcpSegmentationResolver - Class in org.gridgain.grid.segmentation.tcp
Segmentation resolver implementation that checks whether node is in the correct segment or not by establishing TCP connection to configured host and port and immediately closing it.
TcpSegmentationResolver() - Constructor for class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
 
tdeMasterKeyName() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Returns master key name that is used for snapshot encryption.
TensorFlowBaseModelParser<I,O> - Class in org.apache.ignite.ml.inference.parser
Base class for TensorFlow model parsers.
TensorFlowBaseModelParser() - Constructor for class org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser
 
TensorFlowBaseModelParser.InputTransformer<I> - Interface in org.apache.ignite.ml.inference.parser
Input transformer that accepts input and transforms it into tensor.
TensorFlowBaseModelParser.OutputTransformer<O> - Interface in org.apache.ignite.ml.inference.parser
Output transformer that accepts tensors and transforms them into output.
TensorFlowChiefRunner - Class in org.apache.ignite.tensorflow.cluster.util
Utils class that helps to start and stop chief process.
TensorFlowChiefRunner(Ignite, ExecutorService, TensorFlowClusterSpec, Consumer<String>, Consumer<String>) - Constructor for class org.apache.ignite.tensorflow.cluster.util.TensorFlowChiefRunner
Constructs a new instance of TensorFlow chief runner.
TensorFlowCluster - Class in org.apache.ignite.tensorflow.cluster
TensorFlow Cluster metadata.
TensorFlowCluster(TensorFlowClusterSpec, Map<UUID, List<UUID>>) - Constructor for class org.apache.ignite.tensorflow.cluster.TensorFlowCluster
Constructs a new instance of TensorFlow cluster.
TensorFlowClusterGateway - Class in org.apache.ignite.tensorflow.cluster
TensorFlow cluster gateway that allows to subscribe on changes in cluster configuration.
TensorFlowClusterGateway(SerializableConsumer<TensorFlowClusterGateway>) - Constructor for class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGateway
Constructs a new instance of TensorFlow cluster gateway.
TensorFlowClusterGatewayManager - Class in org.apache.ignite.tensorflow.cluster
TensorFlow cluster manager that allows to start, maintain and stop TensorFlow cluster using TensorFlowClusterManager and Ignite Service Grid.
TensorFlowClusterGatewayManager(Ignite) - Constructor for class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGatewayManager
Constructs a new instance of TensorFlow cluster manager with maintenance.
TensorFlowClusterMaintainer - Class in org.apache.ignite.tensorflow.cluster
TensorFlow cluster service that maintains TensorFlow cluster.
TensorFlowClusterMaintainer(UUID, TensorFlowJobArchive, String) - Constructor for class org.apache.ignite.tensorflow.cluster.TensorFlowClusterMaintainer
Constructs a new instance of TensorFlow cluster service.
TensorFlowClusterManager - Class in org.apache.ignite.tensorflow.cluster
TensorFlow cluster manager that allows to start, maintain and stop TensorFlow cluster.
TensorFlowClusterManager(Ignite) - Constructor for class org.apache.ignite.tensorflow.cluster.TensorFlowClusterManager
Constructs a new instance of TensorFlow cluster manager.
TensorFlowClusterResolver - Class in org.apache.ignite.tensorflow.cluster.util
TensorFlow cluster resolver based on Ignite Cache affinity.
TensorFlowClusterResolver(Ignite, String, int, int) - Constructor for class org.apache.ignite.tensorflow.cluster.util.TensorFlowClusterResolver
Constructs a new instance of TensorFlow cluster resolver.
TensorFlowClusterSpec - Class in org.apache.ignite.tensorflow.cluster.spec
TensorFlow cluster specification.
TensorFlowClusterSpec() - Constructor for class org.apache.ignite.tensorflow.cluster.spec.TensorFlowClusterSpec
 
TensorFlowGraphModelParser<I,O> - Class in org.apache.ignite.ml.inference.parser
Implementation of TensorFlow model parser that accepts serialized graph definition.
TensorFlowGraphModelParser() - Constructor for class org.apache.ignite.ml.inference.parser.TensorFlowGraphModelParser
 
TensorFlowJobArchive - Class in org.apache.ignite.tensorflow.cluster
TensorFlow job archive that keeps archived working directory and command to be executed.
TensorFlowJobArchive(String, byte[], String[]) - Constructor for class org.apache.ignite.tensorflow.cluster.TensorFlowJobArchive
Constructs a new instance of TensorFlow job archive.
TensorFlowProcessBuilderSupplier - Class in org.apache.ignite.tensorflow.cluster.util
Python process builder supplier that is used to create TensorFlow worker process builder.
TensorFlowProcessBuilderSupplier(boolean, Boolean, String...) - Constructor for class org.apache.ignite.tensorflow.cluster.util.TensorFlowProcessBuilderSupplier
Constructs a new instance of Python process builder supplier.
TensorFlowSavedModelModelParser<I,O> - Class in org.apache.ignite.ml.inference.parser
Implementation of TensorFlow model parser that accepts serialized directory with "SavedModel" as an input.
TensorFlowSavedModelModelParser(String...) - Constructor for class org.apache.ignite.ml.inference.parser.TensorFlowSavedModelModelParser
Constructs a new instance of TensorFlow model parser.
TensorFlowServer - Class in org.apache.ignite.tensorflow.cluster.tfrunning
TensorFlow server specification.
TensorFlowServer(TensorFlowClusterSpec, String) - Constructor for class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
Constructs a new instance of TensorFlow server specification.
TensorFlowServer(TensorFlowClusterSpec, String, Integer) - Constructor for class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
Constructs a new instance of TensorFlow server specification.
TensorFlowServer(TensorFlowClusterSpec, String, Integer, String) - Constructor for class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServer
Constructs a new instance of TensorFlow server specification.
TensorFlowServerAddressSpec - Class in org.apache.ignite.tensorflow.cluster.spec
TensorFlow server address specification.
TensorFlowServerManager - Class in org.apache.ignite.tensorflow.cluster.tfrunning
TensorFlow server manager that allows to start, stop and make other actions with TensorFlow servers.
TensorFlowServerManager(Ignite) - Constructor for class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServerManager
Constructs a new instance of TensorFlow server manager.
TensorFlowServerManager(ProcessManager<NativeProcess>) - Constructor for class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServerManager
Constructs a new instance of TensorFlow server manager.
TensorFlowServerScriptFormatter - Class in org.apache.ignite.tensorflow.cluster.tfrunning
Utils class that helps to format Python script that starts TensorFlow server.
TensorFlowServerScriptFormatter() - Constructor for class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServerScriptFormatter
 
TensorFlowUserScriptRunner - Class in org.apache.ignite.tensorflow.cluster.util
Utils class that helps to start and stop user script process.
TensorFlowUserScriptRunner(Ignite, ExecutorService, TensorFlowJobArchive, TensorFlowClusterSpec, Consumer<String>, Consumer<String>) - Constructor for class org.apache.ignite.tensorflow.cluster.util.TensorFlowUserScriptRunner
Constructs a new instance of TensorFlow user script runner.
terminate() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
Closes files without flushing checkpoint.
terminateWorker(String) - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Terminates worker.
terminationPageReached() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
Whether termination page was reached while reading pages stream.
test() - Method in class org.apache.ignite.ml.structures.LabeledVectorSetTestTrainPair
Test subset of the whole dataset.
TextQuery<K,V> - Class in org.apache.ignite.cache.query
Full text queries based on Apache Lucene engine.
TextQuery(String, String) - Constructor for class org.apache.ignite.cache.query.TextQuery
Constructs query for the given search string.
TextQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.TextQuery
Constructs query for the given search string.
textQuery() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Whether must use TextQuery search.
THIEF_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Job context attribute for storing thief node UUID (this attribute is used in job stealing failover SPI).
ThinClientConfiguration - Class in org.apache.ignite.configuration
Server-side thin-client configuration.
ThinClientConfiguration() - Constructor for class org.apache.ignite.configuration.ThinClientConfiguration
Creates thin-client configuration with all default values.
ThinClientConfiguration(ThinClientConfiguration) - Constructor for class org.apache.ignite.configuration.ThinClientConfiguration
Creates thin-client configuration by copying all properties from given configuration.
ThinClientKubernetesAddressFinder - Class in org.apache.ignite.client
Address finder for automatic lookup of Ignite server nodes running in Kubernetes environment.
ThinClientKubernetesAddressFinder(KubernetesConnectionConfiguration) - Constructor for class org.apache.ignite.client.ThinClientKubernetesAddressFinder
 
ThinClientKubernetesAddressFinder(KubernetesConnectionConfiguration, int) - Constructor for class org.apache.ignite.client.ThinClientKubernetesAddressFinder
 
ThreadedModelBuilder - Class in org.apache.ignite.ml.inference.builder
Implementation of asynchronous inference model builder that builds model processed locally utilizing specified number of threads.
ThreadedModelBuilder(int) - Constructor for class org.apache.ignite.ml.inference.builder.ThreadedModelBuilder
Constructs a new instance of threaded inference model builder.
threadedQueryInitiatorId() - Static method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
threadId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
threadId(int) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
 
threadId() - Method in interface org.apache.ignite.transactions.Transaction
ID of the thread in which this transaction started.
threadName() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
ThreadPoolMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use GridMetricManager instead.
threadPri - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Thread priority for all threads started by SPI.
threshold() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Gets the threshold.
threshold() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Gets the threshold.
throwable() - Method in class org.apache.ignite.client.events.ConnectionClosedEvent
Get a cause of the failure if any.
throwable() - Method in class org.apache.ignite.client.events.HandshakeFailEvent
Get a cause of the failure.
throwable() - Method in class org.apache.ignite.client.events.RequestFailEvent
Get a cause of the failure.
timeout() - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Get stop node timeout.
timeout(long) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets the timeout that is used in the following cases: any data addition method can be blocked when all per node parallel operations are exhausted.
timeout() - Method in interface org.apache.ignite.IgniteDataStreamer
timeout() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
timeout() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Query timeout in millis.
timeout() - Method in interface org.apache.ignite.transactions.Transaction
Gets timeout value in milliseconds for this transaction.
timeout(long) - Method in interface org.apache.ignite.transactions.Transaction
Sets transaction timeout value.
TimeoutStrategy - Interface in org.apache.ignite.spi
Strategy to calculate next timeout and check if total timeout reached.
times(double) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix containing the product of given value and values in this matrix.
times(Vector) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix that is the product of multiplying this matrix and the argument vector.
times(Matrix) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix that is the product of multiplying this matrix and the argument matrix.
times(double) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix containing the product of given value and values in this matrix.
times(Matrix) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix that is the product of multiplying this matrix and the argument matrix.
times(Vector) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix that is the product of multiplying this matrix and the argument vector.
times(double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets a new vector that contains product of each element and the argument.
times(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Gets a new vector that is an element-wie product of this vector and the argument.
times(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets a new vector that contains product of each element and the argument.
times(Vector) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Gets a new vector that is an element-wie product of this vector and the argument.
times(double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.SparseVector
Gets a new vector that contains product of each element and the argument.
times(double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets a new vector that contains product of each element and the argument.
times(Vector) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Gets a new vector that is an element-wie product of this vector and the argument.
timestamp() - Method in interface org.apache.ignite.events.Event
Gets event timestamp.
timestamp() - Method in class org.apache.ignite.events.EventAdapter
Gets event timestamp.
tn() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
 
toArray() - Method in interface org.apache.ignite.client.ClientIgniteSet
toArray(T1[]) - Method in interface org.apache.ignite.client.ClientIgniteSet
toArray() - Method in interface org.apache.ignite.IgniteQueue
toArray(T[]) - Method in interface org.apache.ignite.IgniteQueue
toArray() - Method in interface org.apache.ignite.IgniteSet
toArray(T1[]) - Method in interface org.apache.ignite.IgniteSet
toArray() - Method in class org.apache.ignite.lang.IgniteBiTuple
Convert tuple to array.
toBinary(Object) - Method in interface org.apache.ignite.IgniteBinary
Converts provided object to instance of BinaryObject.
toBuilder() - Method in interface org.apache.ignite.binary.BinaryObject
Creates a new BinaryObjectBuilder based on this binary object.
toBytes(Object) - Method in class org.apache.ignite.cache.store.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.
toConditional(int, double) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
Convert node to conditional node.
toDoubleArray() - Method in class org.apache.ignite.ml.util.genetic.Chromosome
Returns the double array chromosome representation.
toEnvs() - Method in class org.apache.ignite.yarn.ClusterProperties
Convert to properties to map.
toJdbcException() - Method in exception org.apache.ignite.cache.query.exceptions.SqlCacheException
Converts this exception to SQLException.
tokenNames - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Deprecated.
tokenNames - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Deprecated.
toLeaf(double) - Method in class org.apache.ignite.ml.tree.randomforest.data.TreeNode
Convert node to leaf.
toMap() - Method in interface org.apache.ignite.ml.selection.scoring.metric.MetricValues
Returns the pair of metric name and metric value.
toMatrix(boolean) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Converts this vector into [N x 1] or [1 x N] matrix where N is this vector cardinality.
toMatrix(boolean) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Converts this vector into [N x 1] or [1 x N] matrix where N is this vector cardinality.
toMatrix(boolean) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Converts this vector into [N x 1] or [1 x N] matrix where N is this vector cardinality.
toMatrixPlusOne(boolean, double) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
Converts this vector into [N+1 x 1] or [1 x N+1] matrix where N is this vector cardinality
toMatrixPlusOne(boolean, double) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
Converts this vector into [N+1 x 1] or [1 x N+1] matrix where N is this vector cardinality
toMatrixPlusOne(boolean, double) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
Converts this vector into [N+1 x 1] or [1 x N+1] matrix where N is this vector cardinality
topHistSize - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Size of topology snapshots history.
topic() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
topology(long) - Method in interface org.apache.ignite.IgniteCluster
Gets a topology by version.
topology() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
topology() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfoEx
Cluster topology on the moment when snapshot was created
topologyNodes() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets topology nodes from topology snapshot.
topologySnapshot() - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
topologySnapshot(long, Collection<ClusterNode>) - Method in class org.apache.ignite.events.DiscoveryEvent
Sets the topology snapshot.
topologySnapshot() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service deployment topology snapshot.
TopologyValidator - Interface in org.apache.ignite.configuration
Topology validator is used to verify that cluster topology is valid for further cache operations.
topologyValidator() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
topologyValidator() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
topologyVersion() - Method in interface org.apache.ignite.cache.CacheEntryVersion
 
topologyVersion() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets topology version if this event is raised on topology change and configured discovery SPI implementation supports topology versioning.
topologyVersion() - Method in interface org.apache.ignite.IgniteCluster
Gets current topology version.
topologyVersion() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's topology version in initiator data center.
topVer() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
toString() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
toString() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
toString() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
toString() - Method in class org.apache.ignite.cache.affinity.AffinityKey
toString() - Method in class org.apache.ignite.cache.affinity.AffinityUuid
toString() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
toString() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
toString() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
toString() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
toString() - Method in class org.apache.ignite.cache.hibernate.HibernateKeyWrapper
toString() - Method in class org.apache.ignite.cache.query.Query
toString() - Method in class org.apache.ignite.cache.query.ScanQuery
toString() - Method in class org.apache.ignite.cache.query.SpiQuery
toString() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
toString() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
toString() - Method in class org.apache.ignite.cache.query.TextQuery
toString() - Method in class org.apache.ignite.cache.QueryEntity
toString() - Method in class org.apache.ignite.cache.QueryEntityPatch
toString() - Method in class org.apache.ignite.cache.QueryIndex
toString() - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
toString() - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
toString() - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
toString() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
toString() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
toString() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
toString() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
toString() - Method in class org.apache.ignite.cache.websession.WebSessionFilter
toString() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
toString() - Method in class org.apache.ignite.client.ClientCacheConfiguration
toString() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
toString() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
toString() - Method in class org.apache.ignite.configuration.AtomicConfiguration
toString() - Method in class org.apache.ignite.configuration.BasicAddressResolver
toString() - Method in class org.apache.ignite.configuration.BinaryConfiguration
toString() - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
toString() - Method in class org.apache.ignite.configuration.CacheConfiguration
toString() - Method in class org.apache.ignite.configuration.ClientConfiguration
toString() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
toString() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
toString() - Method in class org.apache.ignite.configuration.CollectionConfiguration
toString() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
toString() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
toString() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
toString() - Method in class org.apache.ignite.configuration.DefaultCommunicationFailureResolver
toString() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
toString() - Method in class org.apache.ignite.configuration.IgniteConfiguration
toString() - Method in class org.apache.ignite.configuration.LoadAllWarmUpConfiguration
toString() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
toString() - Method in class org.apache.ignite.configuration.NoOpWarmUpConfiguration
toString() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
toString() - Method in class org.apache.ignite.configuration.SqlConfiguration
toString() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
toString() - Method in class org.apache.ignite.configuration.TransactionConfiguration
toString() - Method in class org.apache.ignite.events.CacheEvent
toString() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
toString() - Method in class org.apache.ignite.events.CacheQueryReadEvent
toString() - Method in class org.apache.ignite.events.CacheRebalancingEvent
toString() - Method in class org.apache.ignite.events.CheckpointEvent
toString() - Method in class org.apache.ignite.events.DeploymentEvent
toString() - Method in class org.apache.ignite.events.DiscoveryEvent
toString() - Method in class org.apache.ignite.events.EventAdapter
toString() - Method in class org.apache.ignite.events.JobEvent
toString() - Method in class org.apache.ignite.events.ServiceEvent
toString() - Method in class org.apache.ignite.events.TaskEvent
toString() - Method in class org.apache.ignite.events.TaskWithAttributesEvent
toString() - Method in class org.apache.ignite.failure.AbstractFailureHandler
toString() - Method in class org.apache.ignite.failure.FailureContext
toString() - Method in class org.apache.ignite.failure.NoOpFailureHandler
toString() - Method in class org.apache.ignite.failure.RestartProcessFailureHandler
toString() - Method in class org.apache.ignite.failure.StopNodeFailureHandler
toString() - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
toString() - Method in exception org.apache.ignite.IgniteCheckedException
toString() - Method in exception org.apache.ignite.IgniteException
toString() - Method in exception org.apache.ignite.IgniteIllegalStateException
toString() - Method in class org.apache.ignite.IgniteSpringBean
toString() - Method in class org.apache.ignite.lang.IgniteBiTuple
toString() - Method in class org.apache.ignite.lang.IgniteProductVersion
toString() - Method in class org.apache.ignite.lang.IgniteUuid
toString() - Method in class org.apache.ignite.logger.java.JavaLogger
toString() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
toString() - Method in class org.apache.ignite.logger.java.JavaLoggerFormatter
toString() - Method in class org.apache.ignite.logger.jcl.JclLogger
toString() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
toString() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
toString() - Method in class org.apache.ignite.logger.NullLogger
toString() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
toString() - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
toString() - Method in class org.apache.ignite.mesos.IgniteTask
 
toString() - Method in class org.apache.ignite.messaging.MessagingListenActor
toString() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
toString(boolean) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
toString() - Method in class org.apache.ignite.ml.composition.ModelOnFeaturesSubspace
toString(boolean) - Method in class org.apache.ignite.ml.composition.ModelOnFeaturesSubspace
toString() - Method in class org.apache.ignite.ml.composition.ModelsComposition
toString(boolean) - Method in class org.apache.ignite.ml.composition.ModelsComposition
toString(boolean) - Method in interface org.apache.ignite.ml.composition.predictionsaggregator.PredictionsAggregator
Represents aggregator as String.
toString() - Method in class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
toString(boolean) - Method in class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
Represents aggregator as String.
toString() - Method in class org.apache.ignite.ml.genetic.Chromosome
toString() - Method in class org.apache.ignite.ml.genetic.Gene
toString(boolean) - Method in interface org.apache.ignite.ml.IgniteModel
 
toString() - Method in class org.apache.ignite.ml.inference.ModelDescriptor
toString() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
toString(boolean) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel
toString() - Method in class org.apache.ignite.ml.knn.NNClassificationModel
toString(boolean) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
toString() - Method in class org.apache.ignite.ml.math.isolve.IterativeSolverResult
 
toString() - Method in class org.apache.ignite.ml.math.isolve.lsqr.LSQRResult
 
toString() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
toString() - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
toString(boolean) - Method in class org.apache.ignite.ml.multiclass.MultiClassModel
toString() - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
toString(boolean) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
toString() - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
 
toString() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
toString(boolean) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel
toString() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
toString(boolean) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
toString() - Method in class org.apache.ignite.ml.selection.cv.CrossValidationResult
toString() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
toString(boolean) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
toString() - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
toString(boolean) - Method in class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
toString() - Method in class org.apache.ignite.ml.tree.DecisionTreeLeafNode
toString(boolean) - Method in class org.apache.ignite.ml.tree.DecisionTreeLeafNode
toString() - Method in class org.apache.ignite.ml.util.ModelTrace
toString() - Method in class org.apache.ignite.platform.cpp.PlatformCppConfiguration
toString() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
toString() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
toString() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
toString() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
toString() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
toString() - Method in class org.apache.ignite.services.ServiceConfiguration
toString() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
toString() - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
toString() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
toString() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
toString() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
toString() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
toString() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
toString() - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
toString() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
toString() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
toString() - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
toString() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
toString() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AsymmetricKeyEncryptionService
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.AwsKmsEncryptionService
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.encrypt.SymmetricKeyEncryptionService
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.discovery.zk.ZookeeperDiscoverySpi
toString() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
toString() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
toString() - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
toString() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
toString() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
toString() - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
toString() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
toString() - Method in class org.apache.ignite.spi.IgniteSpiThread
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
toString() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
toString() - Method in class org.apache.ignite.springdata22.repository.query.IgniteQuery
 
toString() - Method in class org.apache.ignite.ssl.SslContextFactory
toString() - Method in class org.apache.ignite.startup.BasicWarmupClosure
toString() - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
toString() - Method in class org.apache.ignite.startup.servlet.ServletStartup
toString() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
toString() - Method in class org.apache.ignite.thread.IgniteThread
toString() - Method in class org.apache.ignite.thread.IgniteThreadFactory
toString() - Method in class org.apache.ignite.yarn.IgniteContainer
toString() - Method in class org.gridgain.grid.cache.compress.GzipCompressionConfiguration
toString() - Method in class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
toString() - Method in class org.gridgain.grid.cache.dr.CacheDrSenderConfiguration
toString() - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
toString() - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
toString() - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
toString() - Method in class org.gridgain.grid.configuration.DrReceiverConfiguration
toString() - Method in class org.gridgain.grid.configuration.DrSenderConfiguration
toString() - Method in class org.gridgain.grid.configuration.GridGainCacheConfiguration
toString() - Method in class org.gridgain.grid.configuration.GridGainConfiguration
toString() - Method in class org.gridgain.grid.configuration.SnapshotConfiguration
toString() - Method in class org.gridgain.grid.configuration.SnapshotsCatalogConnectorConfiguration
Deprecated.
toString() - Method in class org.gridgain.grid.dr.DrSenderConnectionConfiguration
toString() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
toString() - Method in class org.gridgain.grid.dr.store.memory.DrSenderInMemoryStore
toString() - Method in class org.gridgain.grid.events.AuthenticationEvent
toString() - Method in class org.gridgain.grid.events.AuthorizationEvent
toString() - Method in class org.gridgain.grid.events.DrCacheFstEvent
toString() - Method in class org.gridgain.grid.events.DrCacheReplicationEvent
toString() - Method in class org.gridgain.grid.events.DrRemoteDcNodeEvent
toString() - Method in class org.gridgain.grid.events.DrRemoteDcReplicationEvent
toString() - Method in class org.gridgain.grid.events.DrStoreEvent
toString() - Method in class org.gridgain.grid.events.LicenseEvent
toString() - Method in class org.gridgain.grid.events.SnapshotEvent
toString() - Method in class org.gridgain.grid.interop.cpp.InteropCppConfiguration
toString() - Method in class org.gridgain.grid.persistentstore.CheckSnapshotParams
toString() - Method in class org.gridgain.grid.persistentstore.CopySnapshotParams
toString() - Method in class org.gridgain.grid.persistentstore.ListSnapshotParams
toString() - Method in class org.gridgain.grid.persistentstore.MoveSnapshotParams
toString() - Method in class org.gridgain.grid.persistentstore.RestoreSnapshotParams
toString() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
toString() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotInputStream
toString() - Method in class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotCommonParams
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotInfoParams
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotIssue
 
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotPath
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotProgress
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotStatus
toString() - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams
toString() - Method in exception org.gridgain.grid.product.ProductLicenseException
toString() - Method in class org.gridgain.grid.security.certificate.CertificateAuthenticator
toString() - Method in class org.gridgain.grid.security.certificate.IssuerRegexPredicate
toString() - Method in class org.gridgain.grid.security.certificate.SubjectRegexPredicate
toString() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
toString() - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
toString() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
toString() - Method in class org.gridgain.grid.segmentation.reachability.ReachabilitySegmentationResolver
toString() - Method in class org.gridgain.grid.segmentation.sharedfs.SharedFsSegmentationResolver
toString() - Method in class org.gridgain.grid.segmentation.tcp.TcpSegmentationResolver
totalBackoffTimeout(long, long, long) - Static method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Compute expected max backoff timeout based on initTimeout, maxTimeout and reconCnt and backoff coefficient.
totalBytes() - Method in class org.gridgain.grid.dr.store.fs.DrSenderFsStore
 
totalCnt - Variable in class org.apache.ignite.services.ServiceConfiguration
Total count.
TotalCostAndCounts() - Constructor for class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer.TotalCostAndCounts
 
totalCount() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets maximum allowed total number of deployed services in the grid, 0 for unlimited.
totalCount() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets maximum allowed total number of deployed services in the grid, 0 for unlimited.
totalCount() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
totalMemoryPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
 
totalPartitions() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Get total count of partitions.
totalRowCount() - Method in class org.apache.ignite.ml.clustering.gmm.NewComponentStatisticsAggregator
 
totalTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets total time of all query executions.
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
 
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
 
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
 
touch(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Updates the time to live value for the given key.
touch(K) - Method in interface org.apache.ignite.IgniteCache
Updates the time to live value for the given key.
tp() - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetricValues
 
trace(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out trace message.
trace(String, String) - Method in interface org.apache.ignite.IgniteLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.EchoingLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out trace message.
trace(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out trace message.
trace(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out trace message.
Tracer - Class in org.apache.ignite.ml.math
Utility methods to support output of Vector and Matrix instances to plain text or HTML.
Tracer() - Constructor for class org.apache.ignite.ml.math.Tracer
 
Tracer.ColorMapper - Interface in org.apache.ignite.ml.math
Double to color mapper.
TRACING_PERMISSIONS_SET - Static variable in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Prefix key taht is used to track tracing permissions.
tracingConfiguration() - Method in interface org.apache.ignite.Ignite
Returns the TracingConfigurationManager instance that allows to Configure tracing parameters such as sampling rate for the specific tracing coordinates such as scope and label.
tracingConfiguration() - Method in class org.apache.ignite.IgniteSpringBean
Returns the TracingConfigurationManager instance that allows to Configure tracing parameters such as sampling rate for the specific tracing coordinates such as scope and label.
TracingConfigurationCoordinates - Class in org.apache.ignite.spi.tracing
Specifies to which traces, specific configuration will be applied.
TracingConfigurationCoordinates.Builder - Class in org.apache.ignite.spi.tracing
TracingConfigurationCoordinates builder.
TracingConfigurationManager - Interface in org.apache.ignite.spi.tracing
Allows to configure tracing, read the configuration and restore it to the defaults.
TracingConfigurationParameters - Class in org.apache.ignite.spi.tracing
Set of tracing configuration parameters like sampling rate or included scopes.
TracingConfigurationParameters.Builder - Class in org.apache.ignite.spi.tracing
TracingConfigurationParameters builder.
tracingPermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Collection of tracing permissions.
tracingPermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Collection of tracing permissions.
TracingSpi<S extends SpiSpecificSpan> - Interface in org.apache.ignite.spi.tracing
Tracing SPI interface.
train() - Method in class org.apache.ignite.ml.structures.LabeledVectorSetTestTrainPair
Train subset of the whole dataset.
trainedDictionaries() - Method in interface org.gridgain.grid.cache.compress.DictionaryMetrics
Gets number of dictionaries trained by running instance.
trainer - Variable in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Trainer.
trainerEnvironment - Variable in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Learning environment used for trainer.
TrainersParallelComposition<I,O,L> - Class in org.apache.ignite.ml.composition.combinators.parallel
This class represents a parallel composition of trainers.
TrainersParallelComposition(List<T>) - Constructor for class org.apache.ignite.ml.composition.combinators.parallel.TrainersParallelComposition
Construct an instance of this class from a list of trainers.
TrainersSequentialComposition<I,O1,O2,L> - Class in org.apache.ignite.ml.composition.combinators.sequential
Sequential composition of trainers.
TrainersSequentialComposition(DatasetTrainer<? extends IgniteModel<I, O1>, L>, DatasetTrainer<? extends IgniteModel<O1, O2>, L>, IgniteFunction<? super IgniteModel<I, O1>, IgniteFunction<LabeledVector<L>, LabeledVector<L>>>) - Constructor for class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Construct sequential composition of given two trainers.
TrainersSequentialComposition(DatasetTrainer<? extends IgniteModel<I, O1>, L>, DatasetTrainer<? extends IgniteModel<O1, O2>, L>, IgniteBiFunction<Integer, ? super IgniteModel<I, O1>, IgniteFunction<LabeledVector<L>, LabeledVector<L>>>) - Constructor for class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Create sequential composition of two trainers.
TrainerTransformers - Class in org.apache.ignite.ml.trainers
Class containing various trainer transformers.
TrainerTransformers() - Constructor for class org.apache.ignite.ml.trainers.TrainerTransformers
 
TrainTestDatasetSplitter<K,V> - Class in org.apache.ignite.ml.selection.split
Dataset splitter that splits dataset into train and test subsets.
TrainTestDatasetSplitter() - Constructor for class org.apache.ignite.ml.selection.split.TrainTestDatasetSplitter
Constructs a new instance of train test dataset splitter.
TrainTestDatasetSplitter(UniformMapper<K, V>) - Constructor for class org.apache.ignite.ml.selection.split.TrainTestDatasetSplitter
Constructs a new instance of train test dataset splitter.
TrainTestSplit<K,V> - Class in org.apache.ignite.ml.selection.split
Dataset split that encapsulates train and test subsets.
TrainTestSplit(IgniteBiPredicate<K, V>, IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.ml.selection.split.TrainTestSplit
Constructs a new instance of train test split.
transaction() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Gets transaction spanning multiple store operations, or null if there is no transaction.
Transaction - Interface in org.apache.ignite.transactions
Ignite cache transaction.
TransactionAlreadyCompletedException - Exception in org.apache.ignite.transactions
Exception thrown whenever Mvcc transaction has been finished before operation finished.
TransactionAlreadyCompletedException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionAlreadyCompletedException
Creates new exception with given error message and optional nested exception.
TransactionConcurrency - Enum in org.apache.ignite.transactions
Transaction concurrency control.
TransactionConfiguration - Class in org.apache.ignite.configuration
Transactions configuration.
TransactionConfiguration() - Constructor for class org.apache.ignite.configuration.TransactionConfiguration
Empty constructor.
TransactionConfiguration(TransactionConfiguration) - Constructor for class org.apache.ignite.configuration.TransactionConfiguration
 
TransactionDeadlockException - Exception in org.apache.ignite.transactions
Transaction deadlock exception.
TransactionDeadlockException(String) - Constructor for exception org.apache.ignite.transactions.TransactionDeadlockException
Creates new deadlock exception with given error message.
TransactionDuplicateKeyException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction tries to inserts entry with same mvcc version more than once.
TransactionDuplicateKeyException(String, Exception) - Constructor for exception org.apache.ignite.transactions.TransactionDuplicateKeyException
Creates new duplicate ket exception with given error message.
TransactionDuplicateKeyException(String) - Constructor for exception org.apache.ignite.transactions.TransactionDuplicateKeyException
Creates new duplicate ket exception with given error message.
TransactionException - Exception in org.apache.ignite.transactions
Base class for all transaction related exceptions.
TransactionException() - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates empty exception.
TransactionException(String) - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates new exception with given error message.
TransactionException(Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates new transaction exception with given throwable as a cause and source of error message.
TransactionException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates new exception with given error message and optional nested exception.
TransactionHeuristicException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid transaction enters an unknown state.
TransactionHeuristicException(String) - Constructor for exception org.apache.ignite.transactions.TransactionHeuristicException
Creates new heuristic exception with given error message.
TransactionHeuristicException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionHeuristicException
Creates new heuristic exception with given error message and optional nested exception.
TransactionIsolation - Enum in org.apache.ignite.transactions
Defines different cache transaction isolation levels.
TransactionMetrics - Interface in org.apache.ignite.transactions
Transaction metrics, shared across all caches.
TransactionMetricsMxBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use GridMetricManager instead.
TransactionMixedModeException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction spans over MVCC and non-MVCC caches.
TransactionMixedModeException(String) - Constructor for exception org.apache.ignite.transactions.TransactionMixedModeException
Creates new exception with given error message.
TransactionOptimisticException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid transactions fail optimistically.
TransactionOptimisticException(String) - Constructor for exception org.apache.ignite.transactions.TransactionOptimisticException
Creates new optimistic exception with given error message.
TransactionOptimisticException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionOptimisticException
Creates new optimistic exception with given error message and optional nested exception.
TransactionRollbackException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid transactions has been automatically rolled back.
TransactionRollbackException(String) - Constructor for exception org.apache.ignite.transactions.TransactionRollbackException
Creates new rollback exception with given error message.
TransactionRollbackException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionRollbackException
Creates new rollback exception with given error message and optional nested exception.
transactions() - Method in interface org.apache.ignite.client.IgniteClient
Gets client transactions facade.
transactions() - Method in interface org.apache.ignite.Ignite
Gets grid transactions facade.
transactions() - Method in class org.apache.ignite.IgniteSpringBean
Gets grid transactions facade.
TransactionSerializationException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction can't be serialized due to write conflict.
TransactionSerializationException(String, Exception) - Constructor for exception org.apache.ignite.transactions.TransactionSerializationException
Creates new transaction serialization exception with given error message.
TransactionsMXBean - Interface in org.apache.ignite.mxbean
Transactions MXBean interface.
TransactionState - Enum in org.apache.ignite.transactions
Cache transaction state.
TransactionStateChangedEvent - Class in org.apache.ignite.events
Event indicates transaction state change.
TransactionStateChangedEvent(ClusterNode, String, int, Transaction) - Constructor for class org.apache.ignite.events.TransactionStateChangedEvent
 
TransactionTimeoutException - Exception in org.apache.ignite.transactions
Exception thrown whenever transactions time out.
TransactionTimeoutException(String) - Constructor for exception org.apache.ignite.transactions.TransactionTimeoutException
Creates new timeout exception with given error message.
TransactionTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionTimeoutException
Creates new timeout exception with given error message and optional nested exception.
TransactionUnsupportedConcurrencyException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction concurrency level is not supported.
TransactionUnsupportedConcurrencyException(String) - Constructor for exception org.apache.ignite.transactions.TransactionUnsupportedConcurrencyException
Creates new exception with given error message.
TransactionView - Class in org.apache.ignite.spi.systemview.view
Transaction representation for a SystemView.
TransactionView(IgniteInternalTx) - Constructor for class org.apache.ignite.spi.systemview.view.TransactionView
 
transferTo(byte) - Method in interface org.gridgain.grid.cache.dr.CacheDrMBean
Performs full state data transfer of this cache to the specified data center.
transfomToListOrdered(Queue<PointWithDistance<L>>) - Static method in class org.apache.ignite.ml.knn.utils.PointWithDistanceUtil
Util method that transforms collection of PointWithDistance to array of LabeledVector.
transform(Object) - Method in interface org.apache.ignite.cache.hibernate.HibernateKeyTransformer
 
transform(Stream<UpstreamEntry>) - Method in interface org.apache.ignite.ml.dataset.UpstreamTransformer
Transform upstream.
transform(I) - Method in interface org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser.InputTransformer
Transforms input into tensor.
transform(Map<String, Tensor<?>>) - Method in interface org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser.OutputTransformer
Transforms tensors into output.
transform(Stream<UpstreamEntry>) - Method in class org.apache.ignite.ml.trainers.transformers.BaggingUpstreamTransformer
Transform upstream.
transform(String...) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
 
transform(byte[]) - Method in interface org.gridgain.grid.persistentstore.SnapshotRegistryTransformer
Compute the verification data over the content of snapshot file registry.
transformationLayerArchitecture(int) - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Get architecture of transformation layer (i.e. non-input layer) with given index.
TransformationLayerArchitecture - Class in org.apache.ignite.ml.nn.architecture
Class encapsulation architecture of transformation layer (i.e. non-input layer).
TransformationLayerArchitecture(int, boolean, IgniteDifferentiableDoubleToDoubleFunction) - Constructor for class org.apache.ignite.ml.nn.architecture.TransformationLayerArchitecture
Construct TransformationLayerArchitecture.
transformer - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Types transformer.
transformer() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
transformSpecification(TensorFlowServer) - Method in class org.apache.ignite.tensorflow.cluster.tfrunning.TensorFlowServerManager
Transforms accepted process specification into process specification delegate working with.
transformSpecification(NativeProcess) - Method in class org.apache.ignite.tensorflow.core.nativerunning.NativeProcessManager
Transforms accepted process specification into process specification delegate working with.
transformSpecification(R) - Method in class org.apache.ignite.tensorflow.core.ProcessManagerWrapper
Transforms accepted process specification into process specification delegate working with.
transpose() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new matrix that is transpose of this matrix.
transpose() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new matrix that is transpose of this matrix.
TreeDataIndex - Class in org.apache.ignite.ml.tree.data
Index for representing sorted dataset rows for each features.
TreeDataIndex(double[][], double[]) - Constructor for class org.apache.ignite.ml.tree.data.TreeDataIndex
Constructs an instance of TreeDataIndex.
TreeFilter - Interface in org.apache.ignite.ml.tree
Predicate used to define objects that placed in decision tree node.
treeId() - Method in class org.apache.ignite.ml.tree.randomforest.data.NodeId
 
TreeNode - Class in org.apache.ignite.ml.tree.randomforest.data
Decision tree node class.
TreeNode(long, int) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.TreeNode
Create an instance of TreeNode.
TreeNode.Type - Enum in org.apache.ignite.ml.tree.randomforest.data
Type of node.
TreeRoot - Class in org.apache.ignite.ml.tree.randomforest.data
Tree root class.
TreeRoot(TreeNode, Set<Integer>) - Constructor for class org.apache.ignite.ml.tree.randomforest.data.TreeRoot
Create an instance of TreeRoot.
TruncateSelectionJob - Class in org.apache.ignite.ml.genetic
Responsible for performing truncate selection
TruncateSelectionJob(Long, List<Long>) - Constructor for class org.apache.ignite.ml.genetic.TruncateSelectionJob
 
TruncateSelectionTask - Class in org.apache.ignite.ml.genetic
Responsible for performing truncate selection.
TruncateSelectionTask(List<Long>, int) - Constructor for class org.apache.ignite.ml.genetic.TruncateSelectionTask
 
tryAcquire() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, only if one is available at the time of invocation.
tryAcquire(long, TimeUnit) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
tryAcquire(int, long, TimeUnit) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, if all become available within the given waiting time and the current thread has not been interrupted.
tryAcquire(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
tryCompress(byte[]) - Method in class org.gridgain.grid.cache.compress.GzipCompressionStrategy
Tries to compress cache key or value data, as array of bytes.
tryFailNode(UUID, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
tryFlush() - Method in interface org.apache.ignite.IgniteDataStreamer
Makes an attempt to stream remaining data.
tryLock() - Method in interface org.apache.ignite.IgniteLock
Acquires the lock only if it is free at the time of invocation.
tryLock(long, TimeUnit) - Method in interface org.apache.ignite.IgniteLock
Acquires the lock if it is not held by another thread within the given waiting time and the current thread has not been interrupted.
tryStop() - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Get try stop.
tryToAddIntoHeap(Queue<PointWithDistance<L>>, int, LabeledVector<L>, double) - Static method in class org.apache.ignite.ml.knn.utils.PointWithDistanceUtil
Util method that adds data point into heap if it fits (if heap size is less than k or a distance from taget point to data point is less than a distance from target point to the most distant data point in heap).
tryToAddIntoHeap(Queue<PointWithDistance<L>>, int, Vector, List<LabeledVector<L>>, DistanceMeasure) - Static method in class org.apache.ignite.ml.knn.utils.PointWithDistanceUtil
Util method that adds data points into heap if they fits (if heap size is less than k or a distance from taget point to data point is less than a distance from target point to the most distant data point in heap).
ttl() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's TTL.
tuneHyperParamterers() - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Finds the best set of hyperparameters based on parameter search strategy.
twoDimensional(IgniteFunction<Double, Double>, double, double) - Static method in class org.apache.ignite.ml.util.generators.standard.RegressionDataStream
Creates two dimensional regression data stream.
twoDimensional(IgniteFunction<Double, Double>, double, double, long) - Static method in class org.apache.ignite.ml.util.generators.standard.RegressionDataStream
Creates two dimensional regression data stream.
TwoPhaseFilesCopyStrategy - Class in org.gridgain.grid.persistentstore.snapshot.file.copy
Strategy copies file to target directory in two phases: Copy to targetDirectory/file.tmp Rename tmp file to targetDirectory/file
TwoPhaseFilesCopyStrategy(boolean, IgniteLogger) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.copy.TwoPhaseFilesCopyStrategy
 
TwoSeparableClassesDataStream - Class in org.apache.ignite.ml.util.generators.standard
2D-Vectors data stream with two separable classes.
TwoSeparableClassesDataStream(double, double) - Constructor for class org.apache.ignite.ml.util.generators.standard.TwoSeparableClassesDataStream
Create an instance of TwoSeparableClassesDataStream.
TwoSeparableClassesDataStream(double, double, long) - Constructor for class org.apache.ignite.ml.util.generators.standard.TwoSeparableClassesDataStream
Create an instance of TwoSeparableClassesDataStream.
tx() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Gets transaction started by this thread or null if this thread does not have a transaction.
tx() - Method in class org.apache.ignite.events.TransactionStateChangedEvent
Provides transaction proxy allows all 'get' operations such as Transaction.label() and also Transaction.setRollbackOnly() method.
tx() - Method in interface org.apache.ignite.IgniteTransactions
Gets transaction started by this thread or null if this thread does not have a transaction.
TX_TIMEOUT_ON_PARTITION_MAP_EXCHANGE - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Transaction timeout on partition map synchronization.
txCommits() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The total number of commited transactions.
txCommits() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction commits.
txLabel() - Method in class org.apache.ignite.events.CacheEvent
Label of surrounding cache transaction or null if there either is no surrounding transaction or label was not set.
txRollbacks() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
Tne total number of rollbacked transactions.
txRollbacks() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction rollbacks.
txStart(TransactionConcurrency, TransactionIsolation) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Starts new transaction with the specified concurrency and isolation.
txStart(TransactionConcurrency, TransactionIsolation, long, int) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Starts transaction with specified isolation, concurrency, timeout, invalidation flag, and number of participating entries.
txStart() - Method in interface org.apache.ignite.client.ClientTransactions
Starts a new transaction with the default isolation level, concurrency and timeout.
txStart(TransactionConcurrency, TransactionIsolation) - Method in interface org.apache.ignite.client.ClientTransactions
Starts a new transaction with the specified concurrency and isolation.
txStart(TransactionConcurrency, TransactionIsolation, long) - Method in interface org.apache.ignite.client.ClientTransactions
Starts a new transaction with the specified isolation, concurrency and timeout.
txStart() - Method in interface org.apache.ignite.IgniteTransactions
Starts transaction with default isolation, concurrency, timeout, and invalidation policy.
txStart(TransactionConcurrency, TransactionIsolation) - Method in interface org.apache.ignite.IgniteTransactions
Starts new transaction with the specified concurrency and isolation.
txStart(TransactionConcurrency, TransactionIsolation, long, int) - Method in interface org.apache.ignite.IgniteTransactions
Starts transaction with specified isolation, concurrency, timeout, and number of participating entries.
txStartEx(TransactionConcurrency, TransactionIsolation) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
type() - Method in interface org.apache.ignite.binary.BinaryObject
Gets type information for this binary object.
type() - Method in interface org.apache.ignite.events.Event
Gets type of this event.
type(int) - Method in class org.apache.ignite.events.EventAdapter
Sets event type.
type() - Method in class org.apache.ignite.events.EventAdapter
Gets type of this event.
type() - Method in class org.apache.ignite.failure.FailureContext
 
type(Class<?>) - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for provided class.
type(String) - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for provided class name.
type(int) - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for provided type ID.
type() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject type for node.
type() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
type() - Method in interface org.apache.ignite.spi.metric.ObjectMetric
 
type() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
type() - Method in class org.apache.ignite.spi.systemview.view.SqlTableColumnView
 
type() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
type() - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
type() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
type() - Method in interface org.apache.ignite.spi.tracing.TracingSpi
 
type() - Method in class org.gridgain.grid.security.SecuritySubjectAdapter
Gets subject type for node.
typeId(String) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Get type ID.
typeId(String) - Method in interface org.apache.ignite.binary.BinaryIdMapper
Gets type ID for provided type name.
typeId() - Method in interface org.apache.ignite.binary.BinaryType
Gets binary type ID.
typeId(String) - Method in interface org.apache.ignite.IgniteBinary
Gets type ID for given type name.
typeIdForObject(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Calculate type ID for object.
typeIdForObject(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Calculate type ID for object.
typeIdForTypeName(CacheAbstractJdbcStore.TypeKind, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Calculate type ID for given type name.
typeIdForTypeName(CacheAbstractJdbcStore.TypeKind, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Calculate type ID for given type name.
typeName(String) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Gets type clsName.
typeName(String) - Method in interface org.apache.ignite.binary.BinaryNameMapper
Gets type clsName.
typeName() - Method in interface org.apache.ignite.binary.BinaryType
Gets binary type name.
types() - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for all known types.

U

uncaughtException(Thread, Throwable) - Method in class org.apache.ignite.thread.OomExceptionHandler
undeployTask(String) - Method in interface org.apache.ignite.IgniteCompute
Makes the best attempt to undeploy a task with given name within the underlying cluster group.
undeployTaskFromGrid(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Makes the best attempt to undeploy a task from the whole grid.
unflatten(double[], int, int) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
 
unflatten(double[], Matrix) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
 
uniform(int) - Static method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
Creates a producer of random values from uniform discrete distribution.
uniform(int, long) - Static method in class org.apache.ignite.ml.util.generators.primitives.scalar.DiscreteRandomProducer
Creates a producer of random values from uniform discrete distribution.
UniformMapper<K,V> - Interface in org.apache.ignite.ml.selection.split.mapper
Interface for util mappers that maps a key-value pair to a point on the segment (0, 1).
UniformRandomProducer - Class in org.apache.ignite.ml.util.generators.primitives.scalar
Pseudorandom producer generating values from uniform continuous distribution.
UniformRandomProducer(double, double) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.UniformRandomProducer
Creates an instance of UniformRandomProducer.
UniformRandomProducer(double, double, long) - Constructor for class org.apache.ignite.ml.util.generators.primitives.scalar.UniformRandomProducer
Creates an instance of UniformRandomProducer.
unitialized() - Static method in interface org.apache.ignite.ml.environment.deploy.DeployingContext
 
UNKNOWN_NODE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Initiator node is not in current topogy.
UNKNOWN_STORAGE_MODE - Static variable in interface org.apache.ignite.ml.math.StorageConstants
Storage mode is unknown.
UnknownCategorialFeatureValue - Exception in org.apache.ignite.ml.math.exceptions.preprocessing
Indicates an unknown categorial feature value for Encoder.
UnknownCategorialFeatureValue(String) - Constructor for exception org.apache.ignite.ml.math.exceptions.preprocessing.UnknownCategorialFeatureValue
 
UnknownClassLabelException - Exception in org.apache.ignite.ml.selection.scoring.metric.exceptions
Indicates an unknown class label for metric calculator.
UnknownClassLabelException(double, double, double) - Constructor for exception org.apache.ignite.ml.selection.scoring.metric.exceptions.UnknownClassLabelException
 
unlabeled() - Method in interface org.apache.ignite.ml.util.generators.DataStreamGenerator
 
UNLIMITED - Static variable in class org.apache.ignite.mesos.ClusterProperties
Unlimited.
UNLIMITED_WAL_ARCHIVE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Value used for making WAL archive size unlimited.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Unlocks given key only if current thread owns the lock.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
Called after Hibernate failed to update or successfully removed given key.
unlock() - Method in interface org.apache.ignite.IgniteLock
Releases the lock.
unlockAll(Collection) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
Unlocks given keys only if current thread owns the locks.
unlockItem(SessionImplementor, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
unlockItem(SharedSessionContractImplementor, Object, SoftLock) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
unlockRegion(SoftLock) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
unlockRegion() - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
Called after transaction clearing entire cache region completed.
unlockRegion(SoftLock) - Method in class org.apache.ignite.cache.hibernate.IgniteCachedDomainDataAccess
unmarshal(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from byte array using given class loader.
unmarshal(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from the input stream using given class loader.
unmarshal(InputStream, ClassLoader) - Method in interface org.apache.ignite.marshaller.Marshaller
Unmarshals object from the input stream using given class loader.
unmarshal(byte[], ClassLoader) - Method in interface org.apache.ignite.marshaller.Marshaller
Unmarshals object from byte array using given class loader.
unmarshal0(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from the input stream using given class loader.
unmarshal0(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from byte array using given class loader.
unmarshal0(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Unmarshals object from the input stream using given class loader.
unmarshal0(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Unmarshals object from byte array using given class loader.
unregister(String) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregister(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregister(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryAlbIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.elb.TcpDiscoveryElbIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
Unregisters provided addresses.
unregisterMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Deletes MaintenanceTask of given ID from maintenance registry.
unregisterMBean() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Unregisters MBean.
unsafeCoerce(DatasetTrainer<? extends M, L>) - Static method in class org.apache.ignite.ml.composition.CompositionUtils
Perform blurring of model type of given trainer to IgniteModel<I, O>, where I, O are input and output types of original model.
unsafeGet() - Method in interface org.apache.ignite.ml.environment.parallelism.Promise
Await result of Future and return it.
unsafeSimplyTyped() - Method in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Performs coersion of this trainer to DatasetTrainer<IgniteModel<I, O2>, L>.
unsubscribe(Consumer<Optional<TensorFlowCluster>>) - Method in class org.apache.ignite.tensorflow.cluster.TensorFlowClusterGateway
Unsubscribe the specified subscriber.
UnsupportedOperationException - Exception in org.apache.ignite.ml.math.exceptions
Indicate that a specific operation is not supported by the underlying implementation.
UnsupportedOperationException(String) - Constructor for exception org.apache.ignite.ml.math.exceptions.UnsupportedOperationException
 
UnsupportedOperationException() - Constructor for exception org.apache.ignite.ml.math.exceptions.UnsupportedOperationException
 
UnsupportedSparkModelException - Exception in org.apache.ignite.ml.sparkmodelparser
Indicates an unsupported Spark Model.
UnsupportedSparkModelException(String) - Constructor for exception org.apache.ignite.ml.sparkmodelparser.UnsupportedSparkModelException
 
unwrap(Class<T>) - Method in class org.apache.ignite.cache.CacheManager
unwrap(Class<T>) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
unwrapCacheEntry(Cache.Entry<K, V>, Class<T>) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Unwrap entry to specified type.
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(SharedSessionContractImplementor, Object, Object, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteEntityDataAccess
 
update(SharedSessionContractImplementor, Object, Object) - Method in class org.apache.ignite.cache.hibernate.IgniteNaturalIdDataAccess
 
update(BaggedModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.bagging.BaggedTrainer
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
update(GDBTrainer.GDBModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
update(IgniteModel<I, List<O>>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.combinators.parallel.TrainersParallelComposition
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
update(ModelsSequentialComposition<I, O1, O2>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
update(StackedModel<IS, IA, O, AM>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
update(M1, NesterovParameterUpdate) - Method in class org.apache.ignite.ml.optimization.updatecalculators.NesterovUpdateCalculator
Update given obj with this parameters.
update(M1, P) - Method in interface org.apache.ignite.ml.optimization.updatecalculators.ParameterUpdateCalculator
Update given obj with this parameters.
update(M1, RPropParameterUpdate) - Method in class org.apache.ignite.ml.optimization.updatecalculators.RPropUpdateCalculator
Update given obj with this parameters.
update(M1, SimpleGDParameterUpdate) - Method in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Update given obj with this parameters.
update(M, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
update(M, Ignite, IgniteCache<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Gets state of model in arguments, update in according to new data and return new model.
update(M, Ignite, IgniteCache<K, V>, IgniteBiPredicate<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Gets state of model in arguments, update in according to new data and return new model.
update(M, Map<K, V>, int, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Gets state of model in arguments, update in according to new data and return new model.
update(M, Map<K, V>, IgniteBiPredicate<K, V>, int, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Gets state of model in arguments, update in according to new data and return new model.
update(GDBTrainer.GDBModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.tree.boosting.GDBOnTreesLearningStrategy
Gets state of model in arguments, compare it with training parameters of trainer and if they are fit then trainer updates model in according to new data and return new model.
updateAttributes(String, Collection<T2<String, Object>>, int) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
updateAttributesV2(String, WebSessionV2) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
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.
updateLicense(String) - Method in interface org.gridgain.grid.GridProduct
Updates to a new license in enterprise edition.
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.
updateModel(GmmModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Trains new model taken previous one as a first approximation.
updateModel(KMeansModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Trains new model taken previous one as a first approximation.
updateModel(BaggedModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.bagging.BaggedTrainer
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(M) and DatasetTrainer.updateModel(M, org.apache.ignite.ml.dataset.DatasetBuilder<K, V>, org.apache.ignite.ml.preprocessing.Preprocessor<K, V>) in this class we explicitly override update method.
updateModel(ModelsComposition, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Trains new model taken previous one as a first approximation.
updateModel(IgniteModel<I, List<O>>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.combinators.parallel.TrainersParallelComposition
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(IgniteModel) and DatasetTrainer.updateModel(IgniteModel, DatasetBuilder, Preprocessor) in this class we explicitly override update method.
updateModel(ModelsSequentialComposition<I, O1, O2>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.combinators.sequential.TrainersSequentialComposition
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(IgniteModel) and DatasetTrainer.updateModel(IgniteModel, DatasetBuilder, Preprocessor) in this class we explicitly override update method.
updateModel(StackedModel<IS, IA, O, AM>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
This method is never called, instead of constructing logic of update from DatasetTrainer.isUpdateable(IgniteModel) and DatasetTrainer.updateModel(IgniteModel, DatasetBuilder, Preprocessor) in this class we explicitly override update method.
updateModel(ANNClassificationModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Trains new model taken previous one as a first approximation.
updateModel(M, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Trains new model taken previous one as a first approximation.
updateModel(MultiClassModel<M>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.multiclass.OneVsRestTrainer
Trains new model taken previous one as a first approximation.
updateModel(DiscreteNaiveBayesModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
Trains new model taken previous one as a first approximation.
updateModel(GaussianNaiveBayesModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
Trains new model taken previous one as a first approximation.
updateModel(MultilayerPerceptron, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Trains new model taken previous one as a first approximation.
updateModel(LinearRegressionModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionLSQRTrainer
Trains new model taken previous one as a first approximation.
updateModel(LinearRegressionModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Trains new model taken previous one as a first approximation.
updateModel(LogisticRegressionModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Trains new model taken previous one as a first approximation.
updateModel(SVMLinearClassificationModel, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Trains new model taken previous one as a first approximation.
updateModel(AdaptableDatasetModel<I, O, IW, OW, M>, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Trains new model taken previous one as a first approximation.
updateModel(M, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Trains new model taken previous one as a first approximation.
updateModel(DecisionTreeNode, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.tree.DecisionTree
Trains new model based on dataset because there is no valid approach to update decision trees.
updateModel(ModelsComposition, DatasetBuilder<K, V>, Preprocessor<K, V>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Trains new model taken previous one as a first approximation.
updateModifictaionTs(long) - Method in interface org.apache.ignite.ml.inference.storage.model.FileOrDirectory
Create new instance of filesystem object with modified timestamp.
updateModifictaionTs() - Method in interface org.apache.ignite.ml.inference.storage.model.FileOrDirectory
Create new instance of filesystem object with current timestamp.
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.
updatesMask - Variable in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Updates mask (values by which updateCache is multiplied).
updatesMask() - Method in class org.apache.ignite.ml.optimization.updatecalculators.RPropParameterUpdate
Get updates mask (values by which updateCache is multiplied).
UpdatesStrategy<M,U extends Serializable> - Class in org.apache.ignite.ml.nn
Class encapsulating update strategies for group trainers based on updates.
UpdatesStrategy(ParameterUpdateCalculator<M, U>, IgniteFunction<List<U>, U>, IgniteFunction<List<U>, U>) - Constructor for class org.apache.ignite.ml.nn.UpdatesStrategy
Construct instance of this class with given parameters.
UpstreamEntry<K,V> - Class in org.apache.ignite.ml.dataset
Entry of the upstream.
UpstreamEntry(K, V) - Constructor for class org.apache.ignite.ml.dataset.UpstreamEntry
Constructs a new instance of upstream entry.
UpstreamTransformer - Interface in org.apache.ignite.ml.dataset
Interface of transformer of upstream.
UpstreamTransformerBuilder - Interface in org.apache.ignite.ml.dataset
UPTIME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
UPTIME_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
uri(URI) - Method in class org.gridgain.grid.persistentstore.SnapshotPath.SftpSnapshotPathBuilder
URI for SFTP location.
uri() - Method in class org.gridgain.grid.persistentstore.SnapshotPath
 
UriDeploymentSpi - Class in org.apache.ignite.spi.deployment.uri
Implementation of DeploymentSpi which can deploy tasks from different sources like file system folders, email and HTTP.
UriDeploymentSpi() - Constructor for class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
 
UriDeploymentSpiMBean - Interface in org.apache.ignite.spi.deployment.uri
Management bean for UriDeploymentSpi.
URL_PREFIX - Static variable in class org.apache.ignite.IgniteJdbcDriver
URL prefix.
useIdx - Variable in class org.apache.ignite.ml.tree.impurity.ImpurityMeasureCalculator
Use index structure instead of using sorting while learning.
useNew() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictContext
Force cache to apply new entry overwriting old (existing) entry.
useOld() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictContext
Force cache to ignore new entry and leave old (existing) entry unchanged.
user() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
USER_ATTRS_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
userClass() - Method in interface org.apache.ignite.ml.environment.deploy.DeployingContext
 
userClass() - Method in class org.apache.ignite.ml.environment.deploy.DeployingContextImpl
userEmail() - Method in interface org.gridgain.grid.product.ProductLicense
Gets user organization e-mail.
userLibs() - Method in class org.apache.ignite.mesos.ClusterProperties
 
userLibs() - Method in class org.apache.ignite.yarn.ClusterProperties
 
userName() - Method in interface org.gridgain.grid.product.ProductLicense
Gets user organization contact name.
userOrganization() - Method in interface org.gridgain.grid.product.ProductLicense
Gets user organization.
usersLibsUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
 
userVersion() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
userWww() - Method in interface org.gridgain.grid.product.ProductLicense
Gets user organization URL.
usingIdx - Variable in class org.apache.ignite.ml.tree.DecisionTree
Use index structure instead of using sorting while learning.
Utils - Class in org.apache.ignite.ml.util
Class with various utility methods.
Utils() - Constructor for class org.apache.ignite.ml.util.Utils
 

V

validate(Collection<ClusterNode>) - Method in interface org.apache.ignite.configuration.TopologyValidator
Validates topology.
validate() - Method in interface org.apache.ignite.plugin.CachePluginProvider
Validates cache plugin configuration in process of cache creation.
validateNewNode(ClusterNode) - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
Validates that new node can join grid topology, this method is called on coordinator node before new node joins topology.
validateNewNode(ClusterNode) - Method in interface org.apache.ignite.plugin.PluginProvider
validateNewNode(ClusterNode, Serializable) - Method in interface org.apache.ignite.plugin.PluginProvider
Validates that new node can join grid topology, this method is called on coordinator node before new node joins topology.
validateNode(ClusterNode) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Validates that new node can join grid topology, this method is called on coordinator node before new node joins topology and before joining node discovery data is unmarshalled.
validateNode(ClusterNode, DiscoveryDataBag) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Validates that new node can join grid topology, this method is called on coordinator node before new node joins topology.
validateRemote(CacheConfiguration, CacheConfiguration, ClusterNode) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Checks that remote caches has configuration compatible with the local.
validationToken() - Method in interface org.gridgain.grid.security.AuthenticationValidator
Returns validation token.
validationToken() - Method in class org.gridgain.grid.security.jaas.JaasAuthenticator
Returns validation token.
validationToken() - Method in class org.gridgain.grid.security.passcode.PasscodeAuthenticator
Returns validation token.
value(BinaryObject) - Method in interface org.apache.ignite.binary.BinaryField
Get field's value from the given object.
value() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry value.
value() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current value.
value() - Method in interface org.apache.ignite.spi.metric.BooleanMetric
 
value() - Method in interface org.apache.ignite.spi.metric.DoubleMetric
 
value() - Method in interface org.apache.ignite.spi.metric.IntMetric
 
value() - Method in interface org.apache.ignite.spi.metric.LongMetric
 
value() - Method in interface org.apache.ignite.spi.metric.ObjectMetric
 
value() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicLongView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicReferenceView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
value() - Method in class org.apache.ignite.springdata22.repository.config.DynamicQueryConfig
Query text string.
value() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's value.
value() - Method in interface org.gridgain.grid.cache.dr.CacheDrEntry
Gets entry's value.
valueAlias() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns alias for value column.
valueBinary() - Method in interface org.gridgain.grid.cache.conflict.CacheConflictEntry
Gets entry's value object without unmarshaling.
valueColumns() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Gets value columns.
valueKind() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CachePeekMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheRebalanceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheWriteSynchronizationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.PartitionLossPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.QueryIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.store.cassandra.persistence.PersistenceStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField.SortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.TypeKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.client.ClientOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.client.SslMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.client.SslProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.compute.ComputeJobResultPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.compute.ComputeTaskSessionScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.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.CheckpointWriteOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.DataPageEvictionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.DeploymentMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.DiskPageCompression
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.PageReplacementMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.WALMode
Returns the enum constant of this type with the specified name.
valueOf(DataRegionMetrics) - Static method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
 
valueOf(DataStorageMetrics) - Static method in class org.apache.ignite.DataStorageMetricsAdapter
Deprecated.
 
valueOf(String) - Static method in enum org.apache.ignite.failure.FailureType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.IgniteState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.lifecycle.LifecycleEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.LabelCoordinate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.environment.logging.MLLogger.VerboseLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.environment.parallelism.ParallelismStrategy.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.genetic.parameter.GAGridConstants.SELECTION_METHOD
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor.Method
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.knn.utils.indices.SpatialIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.preprocessing.encoding.EncoderSortingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.preprocessing.encoding.EncoderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.preprocessing.imputing.ImputingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.sparkmodelparser.SupportedSparkModels
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.tree.randomforest.data.TreeNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.util.genetic.CrossoverStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.util.genetic.SelectionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ml.util.MLSandboxDatasets
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.platform.PlatformType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.security.SecurityPermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.security.SecuritySubjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.segmentation.SegmentationPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ShutdownPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.IgnitePortProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.systemview.view.ComputeJobView.ComputeJobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.tracing.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.tracing.SpanStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.tensorflow.core.longrunning.task.util.LongRunningProcessState
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.
valueOf(String) - Static method in enum org.gridgain.grid.cache.conflict.CacheConflictMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.cache.dr.CacheDrPauseReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.cache.store.local.CacheFileLocalStoreWriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.dr.DrReceiverLoadBalancingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.dr.DrSenderConnectionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.dr.DrSenderLoadBalancingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.dr.store.DrSenderStoreOverflowMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.persistentstore.SnapshotChainMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.persistentstore.SnapshotOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.gridgain.grid.persistentstore.SnapshotSecurityLevel
Returns the enum constant of this type with the specified name.
ValuePersistenceSettings - Class in org.apache.ignite.cache.store.cassandra.persistence
Stores persistence settings for Ignite cache value
ValuePersistenceSettings(Element) - Constructor for class org.apache.ignite.cache.store.cassandra.persistence.ValuePersistenceSettings
Creates class instance from XML configuration.
values() - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CachePeekMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheRebalanceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheWriteSynchronizationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.PartitionLossPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.QueryIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.store.cassandra.persistence.PersistenceStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.store.cassandra.persistence.PojoKeyField.SortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.TypeKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.client.ClientOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.client.SslMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.client.SslProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cluster.ClusterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.compute.ComputeJobResultPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.compute.ComputeTaskSessionScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.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.CheckpointWriteOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.DataPageEvictionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.DeploymentMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.DiskPageCompression
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.PageReplacementMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.WALMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.failure.FailureType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.IgniteState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.ignite.lang.IgniteBiTuple
values() - Static method in enum org.apache.ignite.lifecycle.LifecycleEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.LabelCoordinate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.environment.logging.MLLogger.VerboseLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.environment.parallelism.ParallelismStrategy.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.genetic.parameter.GAGridConstants.SELECTION_METHOD
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.inference.storage.model.thinclient.ModelStorateThinClientProcessor.Method
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.knn.utils.indices.SpatialIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.preprocessing.encoding.EncoderSortingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.preprocessing.encoding.EncoderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.preprocessing.imputing.ImputingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.sparkmodelparser.SupportedSparkModels
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.tree.randomforest.data.TreeNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.util.genetic.CrossoverStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.util.genetic.SelectionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ml.util.MLSandboxDatasets
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.platform.PlatformType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.security.SecurityPermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.security.SecuritySubjectType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.segmentation.SegmentationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ShutdownPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.IgnitePortProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.systemview.view.ComputeJobView.ComputeJobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.tracing.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.tracing.SpanStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.tensorflow.core.longrunning.task.util.LongRunningProcessState
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.
values() - Static method in enum org.gridgain.grid.cache.conflict.CacheConflictMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.cache.dr.CacheDrPauseReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.cache.store.local.CacheFileLocalStoreWriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.dr.DrReceiverLoadBalancingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.dr.DrSenderConnectionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.dr.DrSenderLoadBalancingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.dr.store.DrSenderStoreOverflowMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.persistentstore.SnapshotChainMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.persistentstore.SnapshotOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.gridgain.grid.persistentstore.SnapshotSecurityLevel
Returns an array containing the constants of this enum type, in the order they are declared.
valuesByFrequency() - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Gets the array of maps of frequencies by value in partition for each feature in the dataset.
valueType() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
valueTypeName() - Method in class org.apache.ignite.spi.systemview.view.SqlTableView
Returns name of value type.
variance() - Method in class org.apache.ignite.ml.tree.randomforest.data.statistics.NormalDistributionStatistics
 
vec2Num(Vector) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Turn Vector into number by looking at index of maximal element in vector.
Vector - Interface in org.apache.ignite.ml.math.primitives.vector
A vector interface.
vector - Variable in class org.apache.ignite.ml.structures.DatasetRow
Vector.
vector() - Method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.VectorWithDistributionId
 
Vector.Element - Interface in org.apache.ignite.ml.math.primitives.vector
Holder for vector's element.
VectorGenerator - Interface in org.apache.ignite.ml.util.generators.primitives.vector
Basic interface for pseudorandom vectors generators.
VectorGeneratorPrimitives - Class in org.apache.ignite.ml.util.generators.primitives.vector
Collection of predefined vector generators.
VectorGeneratorPrimitives() - Constructor for class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
 
VectorGeneratorsFamily - Class in org.apache.ignite.ml.util.generators.primitives.vector
Represents a distribution family of district vector generators.
VectorGeneratorsFamily.Builder - Class in org.apache.ignite.ml.util.generators.primitives.vector
Helper for distribution family building.
VectorGeneratorsFamily.VectorWithDistributionId - Class in org.apache.ignite.ml.util.generators.primitives.vector
Container for vector and distribution id.
vectorize(int) - Method in interface org.apache.ignite.ml.util.generators.primitives.scalar.RandomProducer
Create VectorGenerator with vectors having feature values generated by random producer.
vectorize(RandomProducer...) - Static method in interface org.apache.ignite.ml.util.generators.primitives.scalar.RandomProducer
Creates VectorGenerator with vectors having feature values in according to preudorandom producers.
VectorizedViewMatrix - Class in org.apache.ignite.ml.math.primitives.vector.impl
Row or column vector view off the matrix.
VectorizedViewMatrix() - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
 
VectorizedViewMatrix(Matrix, int, int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
 
VectorizedViewMatrixStorage - Class in org.apache.ignite.ml.math.primitives.vector.storage
Row, column or diagonal vector-based view of the matrix
VectorizedViewMatrixStorage() - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
 
VectorizedViewMatrixStorage(Matrix, int, int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
 
Vectorizer<K,V,C extends Serializable,L> - Class in org.apache.ignite.ml.dataset.feature.extractor
Class for extracting labeled vectors from upstream.
Vectorizer(C...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Creates an instance of Vectorizer.
Vectorizer.LabelCoordinate - Enum in org.apache.ignite.ml.dataset.feature.extractor
Shotrcuts for coordinates in feature vector.
Vectorizer.VectorizerAdapter<K,V,C extends Serializable,L> - Class in org.apache.ignite.ml.dataset.feature.extractor
Utility class for convenient overridings.
VectorizerAdapter() - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.VectorizerAdapter
 
VectorStorage - Interface in org.apache.ignite.ml.math.primitives.vector
Data storage support for Vector.
VectorUtils - Class in org.apache.ignite.ml.math.primitives.vector
Some utils for Vector.
VectorUtils() - Constructor for class org.apache.ignite.ml.math.primitives.vector.VectorUtils
 
VectorView - Class in org.apache.ignite.ml.math.primitives.vector.impl
Implements the partial view into the parent Vector.
VectorView() - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
Constructor for Externalizable interface.
VectorView(Vector, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
 
VectorView(VectorStorage, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.impl.VectorView
 
VectorViewStorage - Class in org.apache.ignite.ml.math.primitives.vector.storage
VectorStorage implementation that delegates to parent matrix.
VectorViewStorage() - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
 
VectorViewStorage(VectorStorage, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
 
VectorWithDistributionId(Vector, int) - Constructor for class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorsFamily.VectorWithDistributionId
Creates an instance of VectorWithDistributionId.
verifiedMetadata() - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshot
Allows to choose a moment when metadata is verified.
verify() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Verify that configuration is valid.
verify(byte[], byte[]) - Method in interface org.gridgain.grid.persistentstore.SnapshotRegistryTransformer
Validate the verification data computed earlier against the actual content of snapshot file registry.
VERIFY_ATOMICITY - Static variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyFactory
Disable atomicity check when caches are created lazily.
verifyMetadata(SnapshotMetadataV2) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotDigestRegistryCache
 
version() - Method in interface org.apache.ignite.cache.CacheEntry
Returns a comparable object representing the version of this cache entry.
version() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets node version.
version() - Method in interface org.apache.ignite.Ignite
Gets Ignite version.
version() - Method in class org.apache.ignite.IgniteSpringBean
Gets Ignite version.
version() - Method in class org.apache.ignite.ml.util.plugin.MLPluginProvider
version() - Method in interface org.apache.ignite.plugin.PluginProvider
 
version() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets node version.
version() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
version() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
version() - Method in interface org.gridgain.grid.product.ProductLicense
Gets license version.
versionRegexp() - Method in interface org.gridgain.grid.product.ProductLicense
Version regular expression.
VFS2SnapshotPath - Class in org.gridgain.grid.persistentstore.snapshot.file.remote
Commons-vfs2 file wrapper.
VFS2SnapshotPath(StandardFileSystemManager, FileObject) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.remote.VFS2SnapshotPath
Constructor.
viewColumn(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new view into matrix column .
viewColumn(int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new view into matrix column .
viewDiagonal() - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new view into matrix diagonal.
viewDiagonal() - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new view into matrix diagonal.
ViewMatrix - Class in org.apache.ignite.ml.math.primitives.matrix.impl
Implements the rectangular view into the parent Matrix.
ViewMatrix() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.ViewMatrix
Constructor for Externalizable interface.
ViewMatrix(Matrix, int, int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.ViewMatrix
 
ViewMatrix(MatrixStorage, int, int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.impl.ViewMatrix
 
ViewMatrixStorage - Class in org.apache.ignite.ml.math.primitives.matrix.storage
MatrixStorage implementation that delegates to parent matrix.
ViewMatrixStorage() - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
ViewMatrixStorage(MatrixStorage, int, int, int, int) - Constructor for class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
viewName() - Method in class org.apache.ignite.spi.systemview.view.SqlViewColumnView
 
viewPart(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
viewPart(int, int) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
viewPart(int, int) - Method in interface org.apache.ignite.ml.math.primitives.vector.Vector
 
viewRow(int) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
Creates new view into matrix row.
viewRow(int) - Method in interface org.apache.ignite.ml.math.primitives.matrix.Matrix
Creates new view into matrix row.
visitAll(SystemViewRowAttributeWalker.AttributeVisitor) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
Calls visitor for each row attribute.
visitAll(R, SystemViewRowAttributeWalker.AttributeWithValueVisitor) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
Calls visitor for each row attribute.
visitFile(Path, BasicFileAttributes) - Method in class org.gridgain.grid.persistentstore.snapshot.file.CopyFileVisitor
visitFile(Path, BasicFileAttributes) - Method in class org.gridgain.grid.persistentstore.snapshot.file.DeleteFileVisitor
visitXgHeader(XGBoostModelParser.XgHeaderContext) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
Visit a parse tree produced by XGBoostModelParser.xgHeader().
visitXgHeader(XGBoostModelParser.XgHeaderContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgHeader().
visitXgLeaf(XGBoostModelParser.XgLeafContext) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
Visit a parse tree produced by XGBoostModelParser.xgLeaf().
visitXgLeaf(XGBoostModelParser.XgLeafContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgLeaf().
visitXgModel(XGBoostModelParser.XgModelContext) - Method in class org.apache.ignite.ml.xgboost.parser.visitor.XGModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgModel().
visitXgModel(XGBoostModelParser.XgModelContext) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
Visit a parse tree produced by XGBoostModelParser.xgModel().
visitXgModel(XGBoostModelParser.XgModelContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgModel().
visitXgNode(XGBoostModelParser.XgNodeContext) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
Visit a parse tree produced by XGBoostModelParser.xgNode().
visitXgNode(XGBoostModelParser.XgNodeContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgNode().
visitXgTree(XGBoostModelParser.XgTreeContext) - Method in class org.apache.ignite.ml.xgboost.parser.visitor.XGTreeDictionaryVisitor
Visit a parse tree produced by XGBoostModelParser.xgTree().
visitXgTree(XGBoostModelParser.XgTreeContext) - Method in class org.apache.ignite.ml.xgboost.parser.visitor.XGTreeVisitor
Visit a parse tree produced by XGBoostModelParser.xgTree().
visitXgTree(XGBoostModelParser.XgTreeContext) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
Visit a parse tree produced by XGBoostModelParser.xgTree().
visitXgTree(XGBoostModelParser.XgTreeContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgTree().
visitXgValue(XGBoostModelParser.XgValueContext) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
Visit a parse tree produced by XGBoostModelParser.xgValue().
visitXgValue(XGBoostModelParser.XgValueContext) - Method in interface org.apache.ignite.ml.xgboost.parser.XGBoostModelVisitor
Visit a parse tree produced by XGBoostModelParser.xgValue().
VM_ID - Static variable in class org.apache.ignite.lang.IgniteUuid
VM ID.
VM_NAME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
vmId() - Static method in class org.apache.ignite.lang.IgniteUuid
Gets UUID associated with local VM.
VOCABULARY - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Vocabulary.
VOCABULARY - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Vocabulary.

W

WAIT_JOBS_THRESHOLD_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Threshold of maximum jobs on waiting queue.
waitForAttribute(K, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attribute to be set.
waitForAttribute(K, V, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attribute to be set or updated with given value.
waitForAttributes(Collection<?>, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attributes to be set.
waitForAttributes(Map<?, ?>, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attributes to be set or updated with given values.
waitForClientMessagePrecessed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST PURPOSE ONLY!
waitForLocal(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Waits for the specified events.
waitForLocalAsync(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Create future to wait for the specified events.
waitingJobs() - Method in interface org.apache.ignite.spi.collision.CollisionContext
Gets ordered collection of collision contexts for jobs that are currently waiting for execution.
walker() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
WALMode - Enum in org.apache.ignite.configuration
WAL Mode.
WalSegmentArchivedEvent - Class in org.apache.ignite.events
Event indicates the completion of WAL segment file transition to archive.
WalSegmentArchivedEvent(ClusterNode, long, File) - Constructor for class org.apache.ignite.events.WalSegmentArchivedEvent
Creates WAL segment event
WalSegmentArchivedEvent(ClusterNode, long, File, int) - Constructor for class org.apache.ignite.events.WalSegmentArchivedEvent
 
WalSegmentCompactedEvent - Class in org.apache.ignite.events
Event indicates the completion of WAL segment compaction.
WalSegmentCompactedEvent(ClusterNode, long, File) - Constructor for class org.apache.ignite.events.WalSegmentCompactedEvent
Creates WAL segment compaction event.
walSize() - Method in interface org.gridgain.grid.persistentstore.SnapshotInfo
Return size of occupied WAL in bytes for PITR.
WarmUpConfiguration - Interface in org.apache.ignite.configuration
Warm-up configuration marker interface.
WarmUpMXBean - Interface in org.apache.ignite.mxbean
Warm-up MXBean interface.
warning(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out warning message.
warning(String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs out warning message with optional exception.
warning(String, String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs out warning message with optional exception.
warning(String, Throwable) - Method in class org.apache.ignite.logger.EchoingLogger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
Logs out warning message with optional exception.
warning(String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out warning message with optional exception.
warning(String, String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.NullLogger
Logs out warning message with optional exception.
warning(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out warning message with optional exception.
warning(String, String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out warning message with optional exception.
WEB_SES_CACHE_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching cache name parameter name.
WEB_SES_KEEP_BINARY_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
 
WEB_SES_MAX_RETRIES_ON_FAIL_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching retry on fail parameter name (valid for ATOMIC cache only).
WEB_SES_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching grid name parameter name.
WEB_SES_RETRIES_TIMEOUT_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching retry on fail timeout parameter name.
WebSessionFilter - Class in org.apache.ignite.cache.websession
Filter for web sessions caching.
WebSessionFilter() - Constructor for class org.apache.ignite.cache.websession.WebSessionFilter
 
WebSphereLibertyTmFactory - Class in org.apache.ignite.cache.jta.websphere
Implementation of Transaction Manager factory that should used within WebSphere Liberty.
WebSphereLibertyTmFactory() - Constructor for class org.apache.ignite.cache.jta.websphere.WebSphereLibertyTmFactory
 
WebSphereTmFactory - Class in org.apache.ignite.cache.jta.websphere
Implementation of Transaction Manager factory that should used within WebSphere Application Server ("full profile" / "traditional" WS AS).
WebSphereTmFactory() - Constructor for class org.apache.ignite.cache.jta.websphere.WebSphereTmFactory
 
weight(int, int, int) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get the weight of neuron with given index in previous layer to neuron with given index in given layer.
weighted - Variable in class org.apache.ignite.ml.knn.ann.KNNModelFormat
Weighted or not.
weighted - Variable in class org.apache.ignite.ml.knn.KNNModel
Weighted or not.
weighted - Variable in class org.apache.ignite.ml.knn.KNNTrainer
Weighted or not.
weighted - Variable in class org.apache.ignite.ml.knn.NNClassificationModel
kNN strategy.
WeightedPredictionsAggregator - Class in org.apache.ignite.ml.composition.predictionsaggregator
Predictions aggregator returning weighted plus of predictions.
WeightedPredictionsAggregator(double[]) - Constructor for class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
Constructs WeightedPredictionsAggregator instance.
WeightedPredictionsAggregator(double[], double) - Constructor for class org.apache.ignite.ml.composition.predictionsaggregator.WeightedPredictionsAggregator
Constructs WeightedPredictionsAggregator instance.
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.
weights - Variable in class org.apache.ignite.ml.nn.MLPLayer
Weights matrix.
weights(int) - Method in class org.apache.ignite.ml.nn.MultilayerPerceptron
Get weights of layer with given index.
weights() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Gets the weights.
weights() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Gets the weights.
whenNull(IgniteLogger) - Static method in class org.apache.ignite.logger.NullLogger
 
WHOLE_SNAPSHOT - Static variable in class org.gridgain.grid.persistentstore.SnapshotIssue
Whole snapshot.
WHOLE_SNAPSHOT - Static variable in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
Whole snapshot.
withAddedLayer(int, boolean, IgniteDifferentiableDoubleToDoubleFunction) - Method in class org.apache.ignite.ml.nn.architecture.MLPArchitecture
Constructs new MLP architecture with new layer added on top of all this architecture layers.
withAggregatorInputMerger(IgniteBinaryOperator<I>) - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Specify binary operator used to merge submodels outputs to one.
withAggregatorInputMerger(IgniteBinaryOperator<IA>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Specify binary operator used to merge submodels outputs to one.
withAggregatorInputMerger(IgniteBinaryOperator<Vector>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Specify binary operator used to merge submodels outputs to one.
withAggregatorTrainer(DatasetTrainer<AM, L>) - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Specify aggregator trainer.
withAggregatorTrainer(DatasetTrainer<AM, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Specify aggregator trainer.
withAggregatorTrainer(DatasetTrainer<AM, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Specify aggregator trainer.
withAllowAtomicOpsInTx() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
withAllowAtomicOpsInTx() - Method in interface org.apache.ignite.IgniteCache
If you want to use atomic operations inside transactions you should allow it before transaction start.
withAmountOfClusters(int) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Set up the amount of clusters.
withAmountOfEliteChromosomes(int) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withAmountOfFolds(int) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withAmountOfGenerations(int) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withAmountOfIterations(int) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Set up the amount of outer iterations of SCDA algorithm.
withAmountOfLocIterations(int) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Set up the amount of local iterations of SCDA algorithm.
withAmountOfParts(int) - Method in class org.apache.ignite.ml.selection.cv.DebugCrossValidation
 
withAmountOfTrees(int) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
withArchSupplier(IgniteFunction<Dataset<EmptyContext, SimpleLabeledDatasetData>, MLPArchitecture>) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the multilayer perceptron architecture supplier that defines layers and activators.
withAsync() - Method in interface org.apache.ignite.IgniteCache
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteCompute
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteEvents
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteMessaging
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteServices
Deprecated.
withAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Deprecated.
since 2.0. Please use new specialized async method e.g.
     IgniteFuture f = cache.getAsync();
 
instead of old-style async API:
     IgniteCache asyncCache = cache.withAsync();
     asyncCache.get(key);
     IgniteFuture fut = asyncCache.future();
 
withBaseModelTrainerBuilder(IgniteSupplier<DatasetTrainer<? extends IgniteModel<Vector, Double>, Double>>) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets base model builder.
withBatchSize(int) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the batch size (per every partition).
withBatchSize(int) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up batch size parameter.
withBatchSize(int) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Set up the batchSize parameter.
withBatchSize(double) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Set up the batchSize parameter.
withCategoryFrequencies(Map<String, Integer>[]) - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderPartitionData
Sets the array of maps of frequencies by value in partition for each feature in the dataset.
withChainMode(SnapshotChainMode) - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams.Builder
 
withCheckConvergenceStgyFactory(ConvergenceCheckerFactory) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets CheckConvergenceStgyFactory.
withCheckConvergenceStgyFactory(ConvergenceCheckerFactory) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Sets CheckConvergenceStgyFactory.
withCntOfIterations(int) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets count of iterations.
withCompositionWeights(double[]) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets composition weights vector.
withConvertedLabels(IgniteFunction<L1, L>) - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Creates DatasetTrainer with same training logic, but able to accept labels of given new type of labels.
withConvertedLabels(IgniteFunction<L1, L>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Creates DatasetTrainer with same training logic, but able to accept labels of given new type of labels.
withConvertedLabels(IgniteFunction<L1, L>) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Creates DatasetTrainer with same training logic, but able to accept labels of given new type of labels.
withCounts(int[]) - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Sets the array of amounts of values in partition for each feature in the dataset.
withCrossingoverProbability(double) - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
withCrossingoverProbability(double) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withCrossoverStgy(CrossoverStrategy) - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
withCrossoverStgy(CrossoverStrategy) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withDatasetMapping(DatasetMapping<L, L>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Specify DatasetMapping which will be applied to dataset before fitting and updating.
withDataTtl(long) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Specify partition data time-to-live in seconds (-1 for an infinite lifetime).
withDataTtl(long) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify partition data time-to-live in seconds (-1 for an infinite lifetime).
withDataTtl(long) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Sets up dataTtl parameter.
withDefaultGradStepSize(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets default gradient step size.
withDeleteSources(Boolean) - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams.Builder
 
withDistance(DistanceMeasure) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Set up the distance.
withDistance(DistanceMeasure) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Set up the distance.
withDistanceMeasure(DistanceMeasure) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Sets up distanceMeasure parameter.
withDistanceMeasure(DistanceMeasure) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Set up parameter of the NN model.
withEnablingROCAUC(boolean) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
withEncodedFeature(int) - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderTrainer
Add the index of encoded feature.
withEncodedFeatures(Set<Integer>) - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderTrainer
Sets the indices of features which should be encoded.
withEncoderIndexingStrategy(EncoderSortingStrategy) - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderTrainer
Sets the encoder indexing strategy.
withEncoderType(EncoderType) - Method in class org.apache.ignite.ml.preprocessing.encoding.EncoderTrainer
Sets the encoder preprocessor type.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.bagging.BaggedTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.boosting.GDBBinaryClassifierTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets learning environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.boosting.GDBRegressionTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.boosting.GDBTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.trainers.DatasetTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.tree.DecisionTree
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.tree.DecisionTreeRegressionTrainer
Changes learning Environment.
withEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Changes learning Environment.
withEps(double) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets min divergence beween iterations.
withEpsilon(double) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Set up the epsilon.
withEpsilon(double) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Set up the epsilon.
withEquiprobableClasses() - Method in class org.apache.ignite.ml.naivebayes.discrete.DiscreteNaiveBayesTrainer
Sets equal probability for all classes.
withEquiprobableClasses() - Method in class org.apache.ignite.ml.naivebayes.gaussian.GaussianNaiveBayesTrainer
Sets equal probability for all classes.
withExecutor(String) - Method in interface org.apache.ignite.IgniteCompute
Gets instance of the compute API associated with custom executor.
withExpirePolicy(ExpiryPolicy) - Method in interface org.apache.ignite.client.ClientCache
withExpiryPolicy(ExpiryPolicy) - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
withExpiryPolicy(ExpiryPolicy) - Method in interface org.apache.ignite.client.ClientCache
Returns cache with the specified expiry policy set.
withExpiryPolicy(ExpiryPolicy) - Method in interface org.apache.ignite.IgniteCache
Returns cache with the specified expired policy set.
withExpiryPolicy(ExpiryPolicy) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheClientProxy
Returns cache with the specified expired policy set.
withExpiryPolicy(ExpiryPolicy) - Method in interface org.apache.ignite.springdata.proxy.IgniteCacheProxy
Returns cache with the specified expired policy set.
withExpiryPolicy(ExpiryPolicy) - Method in class org.apache.ignite.springdata.proxy.IgniteCacheProxyImpl
Returns cache with the specified expired policy set.
withExternalLabelToInternal(IgniteFunction<Double, Double>) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets external to internal label representation mapping.
withFeature(String, BinaryObjectVectorizer.Mapping) - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.BinaryObjectVectorizer
Sets values mapping for feature.
withFeaturesCountSelectionStrgy(Function<List<FeatureMeta>, Integer>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
withFilter(IgniteBiPredicate<K, V>) - Method in interface org.apache.ignite.ml.dataset.DatasetBuilder
Returns new instance of DatasetBuilder using conjunction of internal filter and filterToAdd.
withFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Returns new instance of DatasetBuilder using conjunction of internal filter and filterToAdd.
withFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder
Returns new instance of DatasetBuilder using conjunction of internal filter and filterToAdd.
withFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withFitnessFunction(Function<Chromosome, Double>) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
Sets the custom fitness function.
withIdxType(SpatialIndexType) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Sets up idxType parameter.
withIgnite(Ignite) - Method in class org.apache.ignite.ml.selection.cv.CrossValidation
 
withImputingStrategy(ImputingStrategy) - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerTrainer
Sets the imputing strategy.
withIncludedScopes(Set<Scope>) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
Builder method that allows to set included scopes.
withInitialCountOfComponents(int) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets numberOfComponents.
withInitialMeans(List<Vector>) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets initial means.
withInnerModel(M1) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetModel
Create new instance of this class with changed inner model.
withInput(String, TensorFlowBaseModelParser.InputTransformer<I>) - Method in class org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser
Setter that allows to specify additional input graph node and correspondent transformer that allows to transform input into tensor.
withIntercept(double) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Set up the intercept.
withIntercept(double) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Set up the intercept.
withInternalMdl(IgniteModel<Vector, Double>) - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
 
withK(int) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Set up the amount of clusters.
withK(int) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Sets up k parameter (number of neighbours).
withK(int) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Set up parameter of the NN model.
withK(int) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up k parameter (number of rows/cols in matrices after factorization).
withKeepBinary() - Method in interface org.apache.ignite.client.ClientCache
Returns cache that will operate with binary objects.
withKeepBinary() - Method in interface org.apache.ignite.IgniteCache
Returns cache that will operate with binary objects.
withKeepBinary() - Method in interface org.apache.ignite.IgniteQueue
Returns queue that will operate with binary objects.
withKeepBinary() - Method in interface org.apache.ignite.IgniteSet
Returns Ignite set that operates on binary objects without deserialization.
withKeepBinary(boolean) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Add keepBinary policy.
withLabel(String) - Method in interface org.apache.ignite.client.ClientTransactions
Returns instance of ClientTransactions to mark each new transaction with a specified label.
withLabel(String) - Method in interface org.apache.ignite.IgniteTransactions
Returns instance of Ignite Transactions to mark a transaction with a special label.
withLabel(String) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates.Builder
Builder method that allows to set optional label attribute.
withLambda(double) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Set up the regularization parameter.
withLearningEnvironmentBuilder(LearningEnvironmentBuilder) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up learning environment builder.
withLearningRate(double) - Method in class org.apache.ignite.ml.optimization.updatecalculators.SimpleGDUpdateCalculator
Create new instance of this class with same parameters as this one, but with new learning rate.
withLearningRate(double) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up learning rate parameter.
withLocIterations(int) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the maximal number of local iterations before synchronization.
withLocIterations(int) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Set up the amount of local iterations of SGD algorithm.
withLocIterations(double) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Set up the amount of local iterations of SGD algorithm.
withLoggingFactory(T) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify logging factory.
withLoggingFactoryDependency(IgniteFunction<Integer, MLLogger.Factory>) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Specify dependency (partition -> logging factory).
withLoggingFactoryDependency(IgniteFunction<Integer, MLLogger.Factory>) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify dependency (partition -> logging factory).
withLoss(IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction>) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the loss function to be minimized during the training.
withLossGradient(Loss) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Loss function.
withMapper(UniformMapper<K, V>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withMaxCountIterations(int) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets max count of iterations
withMaxCountOfClusters(int) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets maximum number of clusters in GMM.
withMaxCountOfInitTries(int) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets MaxCountOfInitTries parameter.
withMaxDeep(Double) - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Set up the max deep of decision tree.
withMaxDepth(int) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
withMaxIterations(int) - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansTrainer
Set up the max number of iterations before convergence.
withMaxIterations(int) - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer
Set up the max number of iterations before convergence.
withMaxIterations(int) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the maximal number of iterations before the training will be stopped.
withMaxIterations(int) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up max iterations parameter.
withMaxIterations(int) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Set up the max amount of iterations before convergence.
withMaxIterations(double) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Set up the max amount of iterations before convergence.
withMaxLikelihoodDivergence(double) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets maximum divergence between maximum of likelihood of vector in dataset and other for anomalies identification.
withMaxTries(int) - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
Set up the max number of tries to stop the hyperparameter search.
withMeanLabelValue(double) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets mean label value.
withMetric(Metric<L>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withMetric(Function<M, Double>) - Method in class org.apache.ignite.ml.selection.scoring.metric.AbstractMetrics
 
withMinClusterProbability(double) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets minimum requred probability for cluster.
withMinElementsForNewCluster(int) - Method in class org.apache.ignite.ml.clustering.gmm.GmmTrainer
Sets minimum required anomalies in terms of maxLikelihoodDivergence for creating new cluster.
withMinImpurityDecrease(Double) - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Set up the min impurity decrease of decision tree.
withMinImpurityDelta(double) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
withMinMdlImprovement(double) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up minModelImprovement parameter (minimal improvement of the model to continue training).
withMutationOperator(BiFunction<Integer, Double, Double>) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withMutationProbability(double) - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
withMutationProbability(double) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withName(String) - Method in interface org.apache.ignite.IgniteCompute
Sets task name for the next executed task in the current thread.
withNegativeClsLb(double) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
withNegativeClsLb(double) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Set the negative label.
withNodesToLearnSelectionStrgy(Function<Queue<TreeNode>, List<TreeNode>>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
Sets strategy for selection nodes from learning queue in each iteration.
withNoFailover() - Method in interface org.apache.ignite.client.ClientCompute
Sets no-failover flag for tasks executed by returned ClientCompute instance.
withNoFailover() - Method in interface org.apache.ignite.IgniteCompute
Sets no-failover flag for the next task executed in the current thread.
withNoResultCache() - Method in interface org.apache.ignite.client.ClientCompute
Disables result caching for tasks executed by returned ClientCompute instance.
withNoResultCache() - Method in interface org.apache.ignite.IgniteCompute
Disables caching for the next executed task in the current thread.
withNoRetries() - Method in class org.apache.ignite.cache.hibernate.HibernateCacheProxy
withNoRetries() - Method in interface org.apache.ignite.IgniteCache
 
withOriginalFeaturesDropped() - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Drop original features during training and inference.
withOriginalFeaturesDropped() - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Drop original features during training and inference.
withOriginalFeaturesDropped() - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Drop original features during training and inference.
withOriginalFeaturesKept(IgniteFunction<I, I>) - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Keep original features during training and propagate submodels input to aggregator during inference using given function.
withOriginalFeaturesKept() - Method in class org.apache.ignite.ml.composition.stacking.SimpleStackedDatasetTrainer
Keep original features using IgniteFunction.identity() as submodelInput2AggregatingInputConverter.
withOriginalFeaturesKept(IgniteFunction<IS, IA>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Keep original features during training and propagate submodels input to aggregator during inference using given function.
withOriginalFeaturesKept() - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Keep original features using IgniteFunction.identity() as submodelInput2AggregatingInputConverter.
withOriginalFeaturesKept(IgniteFunction<Vector, Vector>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Keep original features during training and propagate submodels input to aggregator during inference using given function.
withOutput(List<String>, TensorFlowBaseModelParser.OutputTransformer<O>) - Method in class org.apache.ignite.ml.inference.parser.TensorFlowBaseModelParser
Setter that allows to specify output graph nodes and correspondent transformer that allow to transform tensors into output.
withP(double) - Method in class org.apache.ignite.ml.preprocessing.normalization.NormalizationTrainer
Sets the p parameter value.
withParallelismStrategy(T) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specifies Parallelism Strategy for LearningEnvironment.
withParallelismStrategyDependency(IgniteFunction<Integer, ParallelismStrategy>) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Specifies dependency (partition -> Parallelism Strategy for LearningEnvironment).
withParallelismStrategyDependency(IgniteFunction<Integer, ParallelismStrategy>) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specifies dependency (partition -> Parallelism Strategy for LearningEnvironment).
withParallelismStrategyType(ParallelismStrategy.Type) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specifies Parallelism Strategy Type for LearningEnvironment.
withParallelismStrategyTypeDependency(IgniteFunction<Integer, ParallelismStrategy.Type>) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Specifies dependency (partition -> Parallelism Strategy Type for LearningEnvironment).
withParallelismStrategyTypeDependency(IgniteFunction<Integer, ParallelismStrategy.Type>) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specifies dependency (partition -> Parallelism Strategy Type for LearningEnvironment).
withParameterSearchStrategy(HyperParameterTuningStrategy) - Method in class org.apache.ignite.ml.selection.paramgrid.ParamGrid
Set up the hyperparameter searching strategy.
withParamGrid(ParamGrid) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withParralelismLevel(Integer) - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams.Builder
 
withPartitionRecover() - Method in interface org.apache.ignite.IgniteCache
Gets an instance of IgniteCache that will be allowed to execute cache read operations regardless of partition loss policy.
withPipeline(Pipeline<K, V, Integer, Double>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withPopulationSize(int) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withPositiveClsLb(double) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetrics
 
withPositiveClsLb(double) - Method in class org.apache.ignite.ml.selection.scoring.metric.classification.ROCAUC
Set the positive label.
withPreprocessor(Preprocessor<K, V>) - Method in class org.apache.ignite.ml.pipeline.PipelineMdl
 
withPreprocessor(Preprocessor<K, V>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withRandom(Random) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify random numbers generator for learning environment.
withRandomDependency(IgniteFunction<Integer, Random>) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Specify dependency (partition -> random numbers generator).
withRandomDependency(IgniteFunction<Integer, Random>) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify dependency (partition -> random numbers generator).
withRawLabels(boolean) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Set up the output label format.
withRawLabels(boolean) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Set up the output label format.
withRegularizer(double) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up regularization parameter.
withRetriesNumber(int) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Sets number of retries. 15 * 60 by default.
withRNGSeed(long) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify seed for random number generator.
withRNGSeedDependency(IgniteFunction<Integer, Long>) - Method in class org.apache.ignite.ml.environment.DefaultLearningEnvironmentBuilder
Specify dependency (partition -> seed for random number generator).
withRNGSeedDependency(IgniteFunction<Integer, Long>) - Method in interface org.apache.ignite.ml.environment.LearningEnvironmentBuilder
Specify dependency (partition -> seed for random number generator).
withSampleSize(long) - Method in class org.apache.ignite.ml.composition.boosting.GDBLearningStrategy
Sets sample size.
withSamplingRate(double) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
Builder method that allows to set sampling rate.
withSatisfactoryFitness(double) - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
Set up the satisfactory fitness to stop the hyperparameter search.
withSeed(long) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the multilayer perceptron model initializer.
withSeed(long) - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionSGDTrainer
Set up the random seed parameter.
withSeed(long) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Set up the random seed parameter.
withSeed(long) - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
Set up the seed number.
withSeed(long) - Method in class org.apache.ignite.ml.selection.paramgrid.RandomStrategy
Set up the seed number.
withSeed(long) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationTrainer
Set up the seed.
withSeed(long) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
withSelectionStgy(SelectionStrategy) - Method in class org.apache.ignite.ml.selection.paramgrid.EvolutionOptimizationStrategy
 
withSelectionStgy(SelectionStrategy) - Method in class org.apache.ignite.ml.util.genetic.GeneticAlgorithm
 
withSingleFileCopy(Boolean) - Method in class org.gridgain.grid.persistentstore.SnapshotUpdateOperationParams.Builder
 
withSkipStore() - Method in interface org.apache.ignite.IgniteCache
 
withSubmodelOutput2VectorConverter(IgniteFunction<IA, Vector>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Set function used for conversion of submodel output to Vector.
withSubmodelOutput2VectorConverter(IgniteFunction<Vector, Vector>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Set function used for conversion of submodel output to Vector.
withSubSampleSize(double) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestTrainer
 
withSums(double[]) - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Sets the array of sums of values in partition for each feature in the dataset.
withThreshold(double) - Method in class org.apache.ignite.ml.preprocessing.binarization.BinarizationTrainer
Set the threshold parameter value.
withThreshold(double) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Set up the threshold.
withThreshold(double) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Set up the threshold.
withTimeout(long) - Method in interface org.apache.ignite.client.ClientCompute
Sets timeout for tasks executed by returned ClientCompute instance.
withTimeout(long) - Method in interface org.apache.ignite.IgniteCompute
Sets task timeout for the next executed task in the current thread.
withTracing() - Method in interface org.apache.ignite.IgniteTransactions
Returns an instance of IgniteTransactions tran will trace every transaction.
withTrainer(DatasetTrainer<M, L>) - Method in class org.apache.ignite.ml.selection.cv.AbstractCrossValidation
 
withTrainerEnvironment(LearningEnvironment) - Method in class org.apache.ignite.ml.recommendation.RecommendationTrainer
Set up trainer learning environment.
withUpdatesStgy(UpdatesStrategy<? super MultilayerPerceptron, P>) - Method in class org.apache.ignite.ml.nn.MLPTrainer
Set up the update strategy that defines how to update model parameters during the training.
withUpdatesStgy(UpdatesStrategy) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionSGDTrainer
Set up the regularization parameter.
withUpstreamCache(IgniteCache<K, V>) - Method in class org.apache.ignite.ml.selection.cv.CrossValidation
 
withUpstreamMap(Map<K, V>) - Method in class org.apache.ignite.ml.selection.cv.DebugCrossValidation
 
withUpstreamTransformer(UpstreamTransformerBuilder) - Method in interface org.apache.ignite.ml.dataset.DatasetBuilder
Returns new instance of DatasetBuilder with new UpstreamTransformerBuilder added to chain of upstream transformer builders.
withUpstreamTransformer(UpstreamTransformerBuilder) - Method in class org.apache.ignite.ml.dataset.impl.cache.CacheBasedDatasetBuilder
Returns new instance of DatasetBuilder with new UpstreamTransformerBuilder added to chain of upstream transformer builders.
withUpstreamTransformer(UpstreamTransformerBuilder) - Method in class org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder
Returns new instance of DatasetBuilder with new UpstreamTransformerBuilder added to chain of upstream transformer builders.
withUpstreamTransformerBuilder(UpstreamTransformerBuilder) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Specify which UpstreamTransformerBuilder will be used.
withUseIndex(boolean) - Method in class org.apache.ignite.ml.tree.DecisionTreeClassificationTrainer
Sets useIndex parameter and returns trainer instance.
withUsingIdx(boolean) - Method in class org.apache.ignite.ml.tree.boosting.GDBBinaryClassifierOnTreesTrainer
Set useIndex parameter and returns trainer instance.
withUsingIdx(boolean) - Method in class org.apache.ignite.ml.tree.boosting.GDBRegressionOnTreesTrainer
Set useIndex parameter and returns trainer instance.
withUsingIdx(boolean) - Method in class org.apache.ignite.ml.tree.DecisionTreeRegressionTrainer
Sets usingIdx parameter and returns trainer instance.
withValuesByFrequency(Map<Double, Integer>[]) - Method in class org.apache.ignite.ml.preprocessing.imputing.ImputerPartitionData
Sets the array of maps of frequencies by value in partition for each feature in the dataset.
withVector2SubmodelInputConverter(IgniteFunction<Vector, IS>) - Method in class org.apache.ignite.ml.composition.stacking.StackedDatasetTrainer
Set function used for conversion of Vector to submodel input.
withVector2SubmodelInputConverter(IgniteFunction<Vector, Vector>) - Method in class org.apache.ignite.ml.composition.stacking.StackedVectorDatasetTrainer
Set function used for conversion of Vector to submodel input.
withWeighted(boolean) - Method in class org.apache.ignite.ml.knn.KNNTrainer
Sets up weighted parameter.
withWeighted(boolean) - Method in class org.apache.ignite.ml.knn.NNClassificationModel
Sets up weighted parameter.
withWeights(Vector) - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel
Set up the weights.
withWeights(Vector) - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel
Set up the weights.
worker() - Method in interface org.apache.ignite.spi.discovery.IgniteDiscoveryThread
 
WORKER_JOB_NAME - Static variable in class org.apache.ignite.tensorflow.cluster.util.TensorFlowClusterResolver
TensorFlow worker job name.
WorkersControlMXBean - Interface in org.apache.ignite.mxbean
MBean that provides ability to terminate worker that registered in the workers registry.
wrap(IgniteFunction<Dataset<C, D>, I>) - Method in interface org.apache.ignite.ml.dataset.Dataset
Wraps this dataset into the specified wrapper to introduce new functionality based on compute and computeWithCtx methods.
WrappedPreparedStatement - Class in org.apache.ignite.cache.store.cassandra.session
Simple wrapper providing access to Cassandra prepared statement and generation of Cassandra session which was used to create this statement
WrappedSession - Class in org.apache.ignite.cache.store.cassandra.session
Simple container for Cassandra session and its generation number.
write(Cache.Entry<? extends K, ? extends V>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
write(Cache.Entry<? extends K, ? extends V>) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
write(Cache.Entry<? extends K, ? extends V>) - Method in class org.apache.ignite.cache.store.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(Cache.Entry<? extends K, ? extends IgniteBiTuple<V, ?>>) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
write(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.SnapshotEncryptionOutputStream
Writes the given page.
writeAffinityTopologyVersion(String, AffinityTopologyVersion) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes AffinityTopologyVersion.
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
writeAll(Collection<Cache.Entry<? extends K, ? extends IgniteBiTuple<V, ?>>>) - Method in class org.gridgain.grid.cache.store.local.CacheFileLocalStore
writeBehindBatchSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindCoalescing() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindFlushFrequency() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindFlushSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindFlushThreadCount() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBinary(BinaryWriter) - Method in interface org.apache.ignite.binary.Binarylizable
Writes fields to provided writer.
writeBinary(Object, BinaryWriter) - Method in class org.apache.ignite.binary.BinaryReflectiveSerializer
Writes fields to provided writer.
writeBinary(Object, BinaryWriter) - Method in interface org.apache.ignite.binary.BinarySerializer
Writes fields to provided writer.
writeBinary(BinaryWriter) - Method in class org.apache.ignite.lang.IgniteUuid
Writes fields to provided writer.
writeBitSet(String, BitSet) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes BitSet.
writeBoolean(boolean) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeBoolean(String, boolean) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeBoolean(String, boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes boolean value.
writeBooleanArray(boolean[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeBooleanArray(String, boolean[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeBooleanArray(String, boolean[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes boolean array.
writeByte(byte) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeByte(String, byte) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeByte(String, byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte value.
writeByteArray(byte[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeByteArray(String, byte[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeByteArray(String, byte[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte array.
writeByteArray(String, byte[], long, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte array.
writeChar(char) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeChar(String, char) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeChar(String, char) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes char value.
writeCharArray(char[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeCharArray(String, char[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeCharArray(String, char[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes char array.
writeCollection(Collection<T>) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeCollection(String, Collection<T>) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeCollection(String, Collection<T>, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes collection.
writeDate(Date) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDate(String, Date) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDateArray(Date[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDateArray(String, Date[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDecimal(BigDecimal) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDecimal(String, BigDecimal) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDecimalArray(BigDecimal[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDecimalArray(String, BigDecimal[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDouble(double) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDouble(String, double) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDouble(String, double) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes double value.
writeDoubleArray(double[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDoubleArray(String, double[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDoubleArray(String, double[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes double array.
writeEnum(T) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeEnum(String, T) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeEnumArray(T[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeEnumArray(String, T[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.affinity.AffinityKey
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.store.cassandra.datasource.DataSource
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.ml.dataset.impl.bootstrapping.BootstrappedVector
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.distances.EuclideanDistance
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.distances.HammingDistance
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.matrix.AbstractMatrix
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.DenseMatrixStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.SparseMatrixStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.AbstractVector
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingNamedVector
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.DelegatingVector
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.impl.VectorizedViewMatrix
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.DenseVectorStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.SparseVectorStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorizedViewMatrixStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.math.primitives.vector.storage.VectorViewStorage
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.structures.Dataset
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.structures.DatasetRow
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.structures.FeatureMetadata
writeExternal(ObjectOutput) - Method in class org.apache.ignite.ml.structures.LabeledVector
writeExternal(ObjectOutput) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
writeExternal(ObjectOutput) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
writeExternal(ObjectOutput) - Method in class org.gridgain.grid.cache.dr.CacheDrStateTransfer
writeExternal(ObjectOutput) - Method in class org.gridgain.grid.cache.dr.CacheDrStatus
writeExternalData(ObjectOutput) - Method in class org.gridgain.grid.persistentstore.SnapshotOperationIssue
Save object's specific data content.
writeFloat(float) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeFloat(String, float) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeFloat(String, float) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes float value.
writeFloatArray(float[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeFloatArray(String, float[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeFloatArray(String, float[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes float array.
writeHeader(short, byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes message header.
writeIgniteUuid(String, IgniteUuid) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes IgniteUuid.
writeInt(int) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeInt(String, int) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeInt(String, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes int value.
writeIntArray(int[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeIntArray(String, int[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeIntArray(String, int[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes int array.
writeLong(long) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeLong(String, long) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeLong(String, long) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long value.
writeLongArray(long[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeLongArray(String, long[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeLongArray(String, long[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long array.
writeLongArray(String, long[], int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long array.
writeMap(Map<K, V>) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeMap(String, Map<K, V>) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeMap(String, Map<K, V>, MessageCollectionItemType, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes map.
writeMessage(String, Message) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes nested message.
writeMessageType(ByteBuffer, short) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Write message type to byte buffer.
writeMetadata(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
WriteMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Mutation which writes(inserts) object into Cassandra.
WriteMutation(Cache.Entry, String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.WriteMutation
Creates instance of delete mutation operation.
writeObject(Object) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeObject(String, Object) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeObjectArray(Object[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeObjectArray(String, Object[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeObjectArray(String, T[], MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes array of objects.
writer(UUID) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFormatter
Creates new message writer instance.
writeRegistry(ByteBuffer) - Method in class org.gridgain.grid.persistentstore.snapshot.file.FileSnapshotSession
writeReplace() - Method in class org.apache.ignite.configuration.CacheConfiguration
Creates a copy of current configuration and removes all cache entry listeners.
writeShort(short) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeShort(String, short) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeShort(String, short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes short value.
writeShortArray(short[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeShortArray(String, short[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeShortArray(String, short[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes short array.
writeString(String) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeString(String, String) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeString(String, String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes String.
writeStringArray(String[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeStringArray(String, String[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeSynchronizationMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeThrottlingThreshold() - Method in class org.gridgain.grid.persistentstore.SnapshotCreateParams
Write throttling threshold.
writeTime(Time) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTime(String, Time) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTimeArray(Time[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTimeArray(String, Time[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTimestamp(Timestamp) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTimestamp(String, Timestamp) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTimestampArray(Timestamp[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTimestampArray(String, Timestamp[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTo(ByteBuffer, MessageWriter) - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Writes this message to provided byte buffer.
writeToSocket(Socket, TcpDiscoveryAbstractMessage, byte[], long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes message to the socket.
writeToSocket(Socket, TcpDiscoveryAbstractMessage, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes message to the socket.
writeToSocket(ClusterNode, Socket, OutputStream, TcpDiscoveryAbstractMessage, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
writeToSocket(Socket, OutputStream, TcpDiscoveryAbstractMessage, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes message to the socket.
writeToSocket(TcpDiscoveryAbstractMessage, Socket, int, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes response to the socket.
writeUuid(UUID) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeUuid(String, UUID) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeUuid(String, UUID) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes UUID.
writeUuidArray(UUID[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeUuidArray(String, UUID[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
WS - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
WS - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 

X

XGBoostModelBaseVisitor<T> - Class in org.apache.ignite.ml.xgboost.parser
This class provides an empty implementation of XGBoostModelVisitor, which can be extended to create a visitor which only needs to handle a subset of the available methods.
XGBoostModelBaseVisitor() - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelBaseVisitor
 
XGBoostModelLexer - Class in org.apache.ignite.ml.xgboost.parser
XGBoost model lexer generated by ANTLR.
XGBoostModelLexer(CharStream) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Constructs a new instance of XGBoost model lexer.
XGBoostModelListener - Interface in org.apache.ignite.ml.xgboost.parser
This interface defines a complete listener for a parse tree produced by XGBoostModelParser.
XGBoostModelParser - Class in org.apache.ignite.ml.xgboost.parser
XGBoost model parser generated by ANTLR.
XGBoostModelParser(TokenStream) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Constructs a new instance of XGBoost model parser.
XGBoostModelParser.XgHeaderContext - Class in org.apache.ignite.ml.xgboost.parser
XG header context.
XGBoostModelParser.XgLeafContext - Class in org.apache.ignite.ml.xgboost.parser
XG leaf context.
XGBoostModelParser.XgModelContext - Class in org.apache.ignite.ml.xgboost.parser
XG model context.
XGBoostModelParser.XgNodeContext - Class in org.apache.ignite.ml.xgboost.parser
XG node conext.
XGBoostModelParser.XgTreeContext - Class in org.apache.ignite.ml.xgboost.parser
XG tree context.
XGBoostModelParser.XgValueContext - Class in org.apache.ignite.ml.xgboost.parser
XG value context.
XGBoostModelVisitor<T> - Interface in org.apache.ignite.ml.xgboost.parser
This interface defines a complete generic visitor for a parse tree produced by XGBoostModelParser.
xgHeader() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Returns XG header.
xgHeader() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
XgHeaderContext(ParserRuleContext, int) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgHeaderContext
Constructs a new instance of XG header context.
xgLeaf() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Returns XG leaf.
xgLeaf() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
xgLeaf(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
XgLeafContext(ParserRuleContext, int) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
Constructs a new instance of XG leaf conext.
xgModel() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
XGModelComposition - Class in org.apache.ignite.ml.xgboost
XGBoost model composition.
XGModelComposition(Map<String, Integer>, List<DecisionTreeNode>) - Constructor for class org.apache.ignite.ml.xgboost.XGModelComposition
Constructs a new instance of composition of models.
XgModelContext(ParserRuleContext, int) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
Constructs a new instance of XG model context.
XGModelParser - Class in org.apache.ignite.ml.xgboost.parser
XGBoost model parser.
XGModelParser() - Constructor for class org.apache.ignite.ml.xgboost.parser.XGModelParser
 
XGModelVisitor - Class in org.apache.ignite.ml.xgboost.parser.visitor
XGBoost model visitor that parses model.
XGModelVisitor() - Constructor for class org.apache.ignite.ml.xgboost.parser.visitor.XGModelVisitor
 
xgNode() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Returns XG node.
xgNode() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
xgNode(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
 
XgNodeContext(ParserRuleContext, int) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
Constructs a new instance of XG node context.
xgTree() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
 
xgTree(int) - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgModelContext
 
xgTree() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 
XgTreeContext(ParserRuleContext, int) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgTreeContext
Constructs a new instance of XG tree context.
XGTreeDictionaryVisitor - Class in org.apache.ignite.ml.xgboost.parser.visitor
Tree dictionary visitor that collects all feature names.
XGTreeDictionaryVisitor() - Constructor for class org.apache.ignite.ml.xgboost.parser.visitor.XGTreeDictionaryVisitor
 
XGTreeVisitor - Class in org.apache.ignite.ml.xgboost.parser.visitor
XGBoost tree visitor that parses tree.
XGTreeVisitor(Map<String, Integer>) - Constructor for class org.apache.ignite.ml.xgboost.parser.visitor.XGTreeVisitor
Constructs a new instance of tree visitor.
xgValue() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgLeafContext
 
xgValue() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
xgValue() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Returns XG value.
XgValueContext(ParserRuleContext, int) - Constructor for class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgValueContext
Constructs a new instance of XG value context.
xid() - Method in class org.apache.ignite.events.CacheEvent
ID of surrounding cache transaction or null if there is no surrounding transaction.
xid() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
xid() - Method in interface org.apache.ignite.transactions.Transaction
Gets unique identifier for this transaction.
XML_DESCRIPTOR_PATH - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default task description file path and name (value is META-INF/ignite.xml).

Y

YARN_LOG_OUT - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
 
yarnQueue(String) - Method in class org.apache.ignite.yarn.ClusterProperties
Sets Yarn Queue
yarnQueue() - Method in class org.apache.ignite.yarn.ClusterProperties
 
YES - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
 
YES() - Method in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser.XgNodeContext
 
YES - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
 

Z

zero() - Method in class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.DefaultLabelVectorizer
Returns default label value for unlabeled data.
zero() - Method in class org.apache.ignite.ml.dataset.feature.extractor.impl.LabeledDummyVectorizer
Returns default label value for unlabeled data.
zero() - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer.VectorizerAdapter
Returns default label value for unlabeled data.
zero() - Method in class org.apache.ignite.ml.dataset.feature.extractor.Vectorizer
Returns default label value for unlabeled data.
zero(int) - Static method in class org.apache.ignite.ml.util.generators.primitives.vector.VectorGeneratorPrimitives
 
zeroes(int) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Create new
zeroesLike(Vector) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Create new vector like given vector initialized by zeroes.
ZipCompressionTask - Class in org.gridgain.grid.persistentstore.snapshot.file
Deprecated.
This class was not intended to be public API and is planned to be deleted. To manage snapshot compression via java API: via snapshot-utility.sh|bat:
  • specify parameter -archive
ZipCompressionTask(FsSnapshotPath, int, SnapshotOperationContext, SnapshotMetricsMXBeanImpl, IgniteLogger) - Constructor for class org.gridgain.grid.persistentstore.snapshot.file.ZipCompressionTask
Deprecated.
File to compress.
zipFoldByColumns(Matrix, Matrix, IgniteBiFunction<Vector, Vector, Double>) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Zips two matrices by column-by-column with specified function.
zipFoldByRows(Matrix, Matrix, IgniteBiFunction<Vector, Vector, Double>) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Zips two matrices by row-by-row with specified function.
zipWith(Vector, Vector, IgniteBiFunction<Double, Double, Double>) - Static method in class org.apache.ignite.ml.math.primitives.vector.VectorUtils
Zip two vectors with given binary function (i.e. apply binary function to both vector elementwise and construct vector from results).
zipWith(Vector, Vector, IgniteTriFunction<Double, Double, Integer, Double>) - Static method in class org.apache.ignite.ml.math.util.MatrixUtil
Zip two vectors with given tri-function taking as third argument position in vector (i.e. apply binary function to both vector elementwise and construct vector from results).
ZookeeperDiscoverySpi - Class in org.apache.ignite.spi.discovery.zk
Zookeeper Discovery Spi.
ZookeeperDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
ZookeeperDiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery.zk
Management bean for ZookeeperDiscoverySpi.
ZstdDictionaryCompressionConfiguration - Class in org.gridgain.grid.cache.compress
Enables Zstandard-based compression with dictionary training and rotation.
ZstdDictionaryCompressionConfiguration() - Constructor for class org.gridgain.grid.cache.compress.ZstdDictionaryCompressionConfiguration
 

_

_ATN - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
ATN.
_ATN - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
ATN.
_decisionToDFA - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Decision to DFA.
_decisionToDFA - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
DFA.
_serializedATN - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Serialized ATN.
_serializedATN - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Serialized ATN.
_sharedContextCache - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelLexer
Shared context cache.
_sharedContextCache - Static variable in class org.apache.ignite.ml.xgboost.parser.XGBoostModelParser
Shared context cache.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

2024 Copyright © GridGain Systems
Follow us:   Follow GridGain on Twitter Follow GridGain on Vimeo
GridGain In-Memory Computing Platform :   ver. 8.9.3
Release Date :   March 13 2024