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).
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,Double>,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
 
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.
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 extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Accuracy metric class.
Accuracy() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.Accuracy
Creates an instance of Accuracy metric.
ackMessage() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
Called when custom message has been handled by all nodes.
acquire() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
acquire(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, blocking until all are available, or the thread is interrupted.
acquireAndExecute(IgniteCallable<T>, int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given semaphore, executes the given callable and schedules the release of permits asynchronously
acquireUninterruptibly() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, blocking until one is available.
acquireUninterruptibly(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, blocking until all are available.
actionsForMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
All MaintenanceActions provided by a component for MaintenanceTask with a given name.
activate() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Activates the job.
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() - Method in enum org.apache.ignite.cluster.ClusterState
 
active() - Method in interface org.apache.ignite.Ignite
Deprecated.
active(boolean) - Method in interface org.apache.ignite.Ignite
Deprecated.
active() - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
active(boolean) - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
active() - Method in class org.apache.ignite.IgniteSpringBean
Checks Ignite grid is active or not active.
active(boolean) - Method in class org.apache.ignite.IgniteSpringBean
Changes Ignite grid state to active or inactive.
active(boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
active() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.active" instead.
ACTIVE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ACTIVE_JOBS_THRESHOLD_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Threshold of maximum jobs executing concurrently.
activeJobs() - Method in interface org.apache.ignite.spi.collision.CollisionContext
Gets ordered collection of collision contexts for jobs that are currently executing.
activeMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Returns active MaintenanceTask by its name.
activeTaskFutures() - Method in interface org.apache.ignite.IgniteCompute
Gets tasks future for active tasks started on local node.
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 multidimensional 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.
addAttributeListener(ComputeTaskSessionAttributeListener, boolean) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Add listener for the session attributes.
addCacheConfiguration(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Adds cache configuration template.
addCacheConfiguration(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Adds cache configuration template.
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
addConsoleAppender(boolean) - Method in class org.apache.ignite.logger.java.JavaLogger
Adds console appender to the logger.
addConsoleAppender(boolean) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Adds console appender to the logger.
addData(K, V) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Map.Entry<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Collection<? extends Map.Entry<K, V>>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Map<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
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, IgniteDoubleConsumer, 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
 
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.
addresses() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets collection of addresses this node is known by.
addresses() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
addresses() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collection of addresses this node is known by.
addresses() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
AddressResolver - Interface in org.apache.ignite.configuration
Provides resolution between external and internal addresses.
addSendMessageListener(IgniteInClosure<TcpDiscoveryAbstractMessage>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
addSystemViewCreationListener(Consumer<SystemView<?>>) - Method in interface org.apache.ignite.spi.systemview.ReadOnlySystemViewRegistry
Adds listener of view creation events.
addTag(String, String) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Adds tag to span with String value.
addTag(String, String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Adds tag to span with String value.
addTag(String, String) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Adds tag to span with String value.
addTimeoutObject(IgniteSpiTimeoutObject) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
addTimeoutObject(IgniteSpiTimeoutObject) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
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(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.sql.SqlTableColumnView
 
AffinityFunction - Interface in org.apache.ignite.cache.affinity
Cache key affinity which maps keys to nodes.
AffinityFunctionContext - Interface in org.apache.ignite.cache.affinity
Affinity function context.
affinityKey(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Maps passed in key to a key which will be used for node affinity.
AffinityKey<K> - Class in org.apache.ignite.cache.affinity
Optional wrapper for cache keys to provide support for custom affinity mapping.
AffinityKey() - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Empty constructor.
AffinityKey(K) - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Initializes key wrapper for a given key.
AffinityKey(K, Object) - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Initializes key together with its affinity key counter-part.
affinityKey() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Gets affinity key to use for affinity mapping.
affinityKey(Object) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Sets affinity key to use for affinity mapping.
affinityKey(Object) - Method in interface org.apache.ignite.cache.affinity.AffinityKeyMapper
Deprecated.
Maps passed in key to an alternate key which will be used for node affinity.
affinityKey() - Method in interface org.apache.ignite.services.ServiceContext
Gets affinity key used for key-to-node affinity calculation.
affinityKey() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets affinity key used for key-to-node affinity calculation.
affinityKey() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
affinityKeyColumn() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns name of affinity key column.
affinityKeyFieldName() - Method in interface org.apache.ignite.binary.BinaryType
Binary objects can optionally specify custom key-affinity mapping in the configuration.
AffinityKeyMapped - Annotation Type in org.apache.ignite.cache.affinity
Optional annotation to specify custom key-to-node affinity.
AffinityKeyMapper - Interface in org.apache.ignite.cache.affinity
affinityMapper() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
affinityPartitionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
affinityPartitionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
affinityRun(String, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRun(Collection<String>, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRun(Collection<String>, int, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where partition is located (the partition is primary on the node) It's guaranteed that the data of all the partitions of all participating caches, the affinity key belongs to, will present on the destination node throughout the job execution.
affinityRun(IgniteRunnable) - Method in interface org.apache.ignite.IgniteQueue
Executes given job on collocated queue on the node where the queue is located (a.k.a. affinity co-location).
affinityRun(IgniteRunnable) - Method in interface org.apache.ignite.IgniteSet
Executes given job on collocated set on the node where the set is located (a.k.a. affinity co-location).
affinityRunAsync(String, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRunAsync(Collection<String>, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRunAsync(Collection<String>, int, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where partition is located (the partition is primary on the node) The data of the partition will not be migrated from the target node while the job is executed.
AffinityUuid - Class in org.apache.ignite.cache.affinity
Guaranteed unique affinity-based key.
AffinityUuid() - Constructor for class org.apache.ignite.cache.affinity.AffinityUuid
Empty constructor.
AffinityUuid(Object) - Constructor for class org.apache.ignite.cache.affinity.AffinityUuid
Constructs unique affinity UUID based on affinity key.
affKey - Variable in class org.apache.ignite.services.ServiceConfiguration
Affinity key.
affKeyFieldName() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
afterExecute(Runnable, Throwable) - Method in class org.apache.ignite.thread.IgniteThreadPoolExecutor
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.
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.
aggregate(IgniteModel<Vector, L>, LabeledVector<L>) - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.BinaryClassificationPointwiseMetricStatsAggregator
Aggregates statistics for metric computation given model and vector with answer.
aggregate(IgniteModel<Vector, L>, LabeledVector<L>) - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.ClassificationMetricsAggregator
Aggregates statistics for metric computation given model and vector with answer.
aggregate(IgniteModel<Vector, L>, LabeledVector<L>) - Method in interface org.apache.ignite.ml.selection.scoring.evaluator.aggregator.MetricStatsAggregator
Aggregates statistics for metric computation given model and vector with answer.
aggregate(IgniteModel<Vector, Double>, LabeledVector<Double>) - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.RegressionMetricStatsAggregator
Aggregates statistics for metric computation given model and vector with answer.
aggregate(LabeledVector<L>) - Method in class org.apache.ignite.ml.selection.scoring.evaluator.context.BinaryClassificationEvaluationContext
Aggregates statistic from vector of sample.
aggregate(LabeledVector<L>) - Method in class org.apache.ignite.ml.selection.scoring.evaluator.context.EmptyContext
Aggregates statistic from vector of sample.
aggregate(LabeledVector<L>) - Method in interface org.apache.ignite.ml.selection.scoring.evaluator.context.EvaluationContext
Aggregates statistic from vector of sample.
aggregateImpurityStatistics(ArrayList<RandomForestTreeModel>, 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.
alive() - Method in interface org.apache.ignite.cdc.CdcConsumer
Checks that consumer still alive.
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.
ALL_PERMISSIONS - Static variable in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
allActions() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Supplies list of MaintenanceActions that user can call to fix maintenance situation for the component or get information about ongoing actions.
allCoords(K, V) - Method in class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.ArrayLikeObjectLabelVectorizer
Returns list of all coordinate with feature values.
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) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
allocateMemory(long) - Method in interface org.apache.ignite.mem.MemoryAllocator
 
allowOverwrite() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag enabling overwriting existing values in cache.
allowOverwrite(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag enabling overwriting existing values in cache.
allPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which given cluster node has any ownership (either primary or backup).
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.
amountOfClusters() - Method in interface org.apache.ignite.ml.clustering.kmeans.ClusterizationModel
Gets the clusters count.
amountOfClusters() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Gets the clusters count.
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 this 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.
ANNClassificationModel.ANNJSONExportModel - Class in org.apache.ignite.ml.knn.ann
 
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.
ANNJSONExportModel(Long, String, String) - Constructor for class org.apache.ignite.ml.knn.ann.ANNClassificationModel.ANNJSONExportModel
 
ANNJSONExportModel() - Constructor for class org.apache.ignite.ml.knn.ann.ANNClassificationModel.ANNJSONExportModel
 
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.
ANONYMOUS_LOGGER_NAME - Static variable in class org.apache.ignite.logger.java.JavaLoggerFormatter
Name for anonymous loggers.
appendCachePermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form cache with name.
appendServicePermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form service with name.
appendSystemPermissions(SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append system permission set.
appendTaskPermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form task with name.
apply(ClusterNode, List<ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
Defines a predicate which returns true if a node is acceptable for a backup or false otherwise.
apply(ClusterNode, List<ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeColocatedBackupFilter
Defines a predicate which returns true if a node is acceptable for a backup or false otherwise.
apply(ClusterNode) - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
Predicate body.
apply(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on a node within the underlying cluster group.
apply(IgniteClosure<T, R>, Collection<? extends T>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within the underlying cluster group.
apply(IgniteClosure<T, R1>, Collection<? extends T>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within the underlying cluster group.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiClosure
Closure body.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiInClosure
Closure body.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiPredicate
Predicate body.
apply(E) - Method in interface org.apache.ignite.lang.IgniteClosure
Closure body.
apply(E) - Method in interface org.apache.ignite.lang.IgniteInClosure
Closure body.
apply() - Method in interface org.apache.ignite.lang.IgniteOutClosure
Closure body.
apply(E) - Method in interface org.apache.ignite.lang.IgnitePredicate
Predicate body.
apply(UUID, T) - Method in class org.apache.ignite.messaging.MessagingListenActor
Predicate body.
apply(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.frequency.FrequencyEncoderPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.encoding.label.LabelEncoderPreprocessor
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.encoding.target.TargetEncoderPreprocessor
Applies this preprocessor.
apply(K, V) - Method in class org.apache.ignite.ml.preprocessing.finalization.VectorFinalizationPreprocessor
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.
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() - 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.
arguments() - Method in class org.apache.ignite.events.SqlQueryExecutionEvent
Gets query arguments.
ArrayLikeObjectLabelVectorizer(Integer...) - Constructor for class org.apache.ignite.ml.dataset.feature.extractor.ExtractionUtils.ArrayLikeObjectLabelVectorizer
Creates an instance of Vectorizer.
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
Convert 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.
AsyncModelBuilder - Interface in org.apache.ignite.ml.inference.builder
Builder of asynchronous inference model.
AtomicConfiguration - Class in org.apache.ignite.configuration
Configuration for atomic data structures.
AtomicConfiguration() - Constructor for class org.apache.ignite.configuration.AtomicConfiguration
 
atomicityMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
atomicityMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
atomicLong(String, long, boolean) - Method in interface org.apache.ignite.client.IgniteClient
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, ClientAtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.client.IgniteClient
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, AtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, ClientAtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, AtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
AtomicLongView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicLong representation for a SystemView.
AtomicLongView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicLongView
 
atomicReference(String, T, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, AtomicConfiguration, T, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, T, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, AtomicConfiguration, T, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
AtomicReferenceView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicReference representation for a SystemView.
AtomicReferenceView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicReferenceView
 
atomicSequence(String, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, AtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, AtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
AtomicSequenceView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicSequence representation for a SystemView.
AtomicSequenceView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
atomicStamped(String, T, S, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, AtomicConfiguration, T, S, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, T, S, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, AtomicConfiguration, T, S, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
AtomicStampedView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicStamped representation for a SystemView.
AtomicStampedView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
attach(Object) - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Attaches the given object to this session.
attachment() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Retrieves the current attachment or null if there is no attachment.
ATTR_ADDRS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node IP addresses (value is comm.tcp.addrs).
ATTR_CONN_PROP - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Connection attribute property name.
ATTR_EXT_ADDRS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node's external addresses (value is comm.tcp.ext-addrs).
ATTR_EXT_ADDRS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Node attribute that is mapped to node's external addresses (value is disc.tcp.ext-addrs).
ATTR_FORCE_CLIENT_SERVER_CONNECTIONS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
ATTR_HOST_NAMES - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node host names (value is comm.tcp.host.names).
ATTR_PAIRED_CONN - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Attr paired connection.
ATTR_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node port number (value is comm.tcp.port).
ATTR_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
This constant is not used and will be removed in future releases.
attribute(String) - Method in interface org.apache.ignite.cluster.BaselineNode
Gets a node attribute.
attribute(String) - Method in interface org.apache.ignite.cluster.ClusterNode
Gets a node attribute.
attribute(String) - Method in interface org.apache.ignite.services.ServiceCallContext
Get the string attribute.
attribute(String) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets a node attribute.
attributeNames() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
 
AttributeNames - Class in org.apache.ignite.spi.communication.tcp
Deprecated.
fix it in the ticket https://ggsystems.atlassian.net/browse/GG-29546
AttributeNames(String, String, String, String, String, String) - Constructor for class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
attributes() - Method in interface org.apache.ignite.cluster.BaselineNode
Gets all node attributes.
attributes() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets all node attributes.
attributes() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets all node attributes.
attributeValues(String) - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
 
authenticatedSubject(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets security subject based on subject ID.
authenticatedSubjects() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets collection of authenticated subjects together with their permissions.
authenticateNode(ClusterNode, SecurityCredentials) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
Security credentials.
AuthenticationContext - Class in org.apache.ignite.plugin.security
Authentication context.
AuthenticationContext() - Constructor for class org.apache.ignite.plugin.security.AuthenticationContext
 
authenticationFailedError(TcpDiscoveryAuthFailedMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
autoAdjustTimeout() - Method in class org.apache.ignite.events.BaselineConfigurationChangedEvent
 
autoDelete() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets autoDelete flag.
autoDelete() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
autoFlushFrequency() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets automatic flush frequency.
autoFlushFrequency(long) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets automatic flush frequency.
autoIncrement() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
automaticAction() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Component can provide optional MaintenanceAction that will be executed automatically by MaintenanceRegistry when node enters maintenance mode.
autoUnsubscribe() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
AVAILABLE_PROC_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
availablePermits() - Method in interface org.apache.ignite.IgniteSemaphore
Returns the current number of permits available in this semaphore.
availablePermits() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
averageExecutionTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average execution time in milliseconds since future was created.
averageIdleTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average idle time for this scheduled task.
averageTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets average execution time of query.
averageTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets average execution time of query.
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.
avgActiveJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgCanceledJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgCpuLoad() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgJobsExecuteTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgJobsWaitTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgRejectedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgWaitingJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
await() - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted.
await(long, TimeUnit) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
await() - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless current thread is interrupted.
await(long) - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
await(long, TimeUnit) - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
awaitNanos(long) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
awaitTermination(long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
awaitUninterruptibly() - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled.
awaitUntil(Date) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified deadline elapses.
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.
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<L extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
BalancedAccuracy metric class.
BalancedAccuracy() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.BalancedAccuracy
Creates an instance of BalancedAccuracy.
BalancedAccuracy(L, L) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.BalancedAccuracy
Creates an instance of BalancedAccuracy class.
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.
BaselineNodeAttributeView - Class in org.apache.ignite.spi.systemview.view
Baseline node attribute representation for a SystemView.
BaselineNodeAttributeView(Object, String, Object) - Constructor for class org.apache.ignite.spi.systemview.view.BaselineNodeAttributeView
 
baselineNodes() - Method in class org.apache.ignite.events.BaselineChangedEvent
 
baselineNodes() - Method in class org.apache.ignite.events.ClusterActivationEvent
Deprecated.
Gets baseline nodes.
baselineNodes() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
Gets baseline nodes.
baselineNodes() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
BaselineNodeView - Class in org.apache.ignite.spi.systemview.view
Baseline topology node representation for a SystemView.
BaselineNodeView(Object, boolean) - Constructor for class org.apache.ignite.spi.systemview.view.BaselineNodeView
 
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
 
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
 
BayesModel<MODEL extends BayesModel,FEATURES,OUTPUT> - Interface in org.apache.ignite.ml.naivebayes
Interface for Bayes Models.
beforeExecute(Thread, Runnable) - Method in class org.apache.ignite.thread.IgniteThreadPoolExecutor
beforeInnerMessageRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback called before inner message is read.
beforeInnerMessageWrite() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called before inner message is written.
beforeMessageRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback that must be invoked by a message implementation before message body started decoding.
beforeTrainedModel(IgniteFunction<I1, I>) - Method in class org.apache.ignite.ml.trainers.AdaptableDatasetTrainer
Let this trainer produce model mdl.
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.IgniteClientSpringBean
binary() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteBinary interface.
binaryAttribute(String) - Method in interface org.apache.ignite.services.ServiceCallContext
Get the binary attribute.
BinaryBasicIdMapper - Class in org.apache.ignite.binary
Base binary ID mapper implementation.
BinaryBasicIdMapper() - Constructor for class org.apache.ignite.binary.BinaryBasicIdMapper
Default constructor.
BinaryBasicIdMapper(boolean) - Constructor for class org.apache.ignite.binary.BinaryBasicIdMapper
 
BinaryBasicNameMapper - Class in org.apache.ignite.binary
Base binary name mapper implementation.
BinaryBasicNameMapper() - Constructor for class org.apache.ignite.binary.BinaryBasicNameMapper
Default constructor.
BinaryBasicNameMapper(boolean) - Constructor for class org.apache.ignite.binary.BinaryBasicNameMapper
 
BinaryClassificationEvaluationContext<L extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.evaluator.context
This context tries to define positive and negative labels for estimation of binary classifier.
BinaryClassificationEvaluationContext() - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.context.BinaryClassificationEvaluationContext
Creates an instance of BinaryClassificationEvaluationContext.
BinaryClassificationEvaluationContext(L, L) - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.context.BinaryClassificationEvaluationContext
Creates an instance of BinaryClassificationEvaluationContext.
BinaryClassificationMetric<L extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.metric.classification
Common abstract class for all binary classification metrics.
BinaryClassificationMetric(L, L) - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetric
Creates an instance of BinaryClassificationMetric.
BinaryClassificationMetric() - Constructor for class org.apache.ignite.ml.selection.scoring.metric.classification.BinaryClassificationMetric
Creates an instance of BinaryClassificationMetric.
BinaryClassificationPointwiseMetricStatsAggregator<L extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.evaluator.aggregator
This class represents statistics for pointwise metrics evaluation for binary classification like TruePositive, FalsePositive, TrueNegative and FalseNegative.
BinaryClassificationPointwiseMetricStatsAggregator() - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.BinaryClassificationPointwiseMetricStatsAggregator
Creates an instance of BinaryClassificationPointwiseMetricStatsAggregator.
BinaryClassificationPointwiseMetricStatsAggregator(L, L, int, int, int, int) - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.BinaryClassificationPointwiseMetricStatsAggregator
Creates an instance of BinaryClassificationPointwiseMetricStatsAggregator.
BinaryClassificationPointwiseMetricStatsAggregator.WithCustomLabelsAggregator<L extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.evaluator.aggregator
Class represents already initialized aggregator.
BinaryCollectionFactory<K> - Interface in org.apache.ignite.binary
Collection factory.
BinaryConfiguration - Class in org.apache.ignite.configuration
Configuration object for Ignite Binary Objects.
BinaryConfiguration() - Constructor for class org.apache.ignite.configuration.BinaryConfiguration
 
BinaryField - Interface in org.apache.ignite.binary
Binary object field.
BinaryIdMapper - Interface in org.apache.ignite.binary
Type and field ID mapper for binary objects.
BinaryInvalidTypeException - Exception in org.apache.ignite.binary
Exception indicating that class needed for deserialization of binary object does not exist.
BinaryInvalidTypeException(String) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with error message.
BinaryInvalidTypeException(Throwable) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with Throwable as a cause.
BinaryInvalidTypeException(String, Throwable) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with error message and Throwable as a cause.
Binarylizable - Interface in org.apache.ignite.binary
Interface that allows to implement custom serialization logic for binary objects.
BinaryMapFactory<K,V> - Interface in org.apache.ignite.binary
Map factory.
BinaryMetadataView - Class in org.apache.ignite.spi.systemview.view
BinaryMetadata representation for the SystemView.
BinaryMetadataView(BinaryMetadata) - Constructor for class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
BinaryNameMapper - Interface in org.apache.ignite.binary
Maps type and field names to different names.
BinaryObject - Interface in org.apache.ignite.binary
Wrapper for binary object in binary format.
BinaryObjectBuilder - Interface in org.apache.ignite.binary
Binary object builder.
BinaryObjectException - Exception in org.apache.ignite.binary
Exception indicating binary object serialization error.
BinaryObjectException(String) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with error message.
BinaryObjectException(Throwable) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with Throwable as a cause.
BinaryObjectException(String, Throwable) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with error message and Throwable as a cause.
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!
BrayCurtisDistance - Class in org.apache.ignite.ml.math.distances
Calculates the Bray Curtis distance between two points.
BrayCurtisDistance() - Constructor for class org.apache.ignite.ml.math.distances.BrayCurtisDistance
 
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
 
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
 
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.
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<RandomForestTreeModel>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestClassifierTrainer
Returns composition of built trees.
buildComposition(List<RandomForestTreeModel>) - Method in class org.apache.ignite.ml.tree.randomforest.RandomForestRegressionTrainer
Returns composition of built trees.
buildComposition(List<RandomForestTreeModel>) - 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.
buildDecisionTreeModel(Map<Integer, NodeData>) - Static method in class org.apache.ignite.ml.tree.NodeData
Builds the DT model by the given sorted map of nodes.
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
 
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.
buildTree(Map<Integer, NodeData>, NodeData) - Static method in class org.apache.ignite.ml.tree.NodeData
Build tree or sub-tree based on indices and nodes sorted map as a dictionary.
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.
busyTimePercentage() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 

C

cache() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
cache(String) - Method in interface org.apache.ignite.client.IgniteClient
Get existing cache.
cache(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCache API for the given name if one is configured or null otherwise.
cache(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Get existing cache.
cache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCache API for the given name if one is configured or null otherwise.
CacheAbstractJdbcStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Implementation of CacheStore backed by JDBC.
CacheAbstractJdbcStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
CacheAbstractJdbcStore.EntryMapping - Class in org.apache.ignite.cache.store.jdbc
Entry mapping description.
CacheAbstractJdbcStore.TypeKind - Enum in org.apache.ignite.cache.store.jdbc
Type kind.
cacheAffinity(String) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
CacheAtomicityMode - Enum in org.apache.ignite.cache
Cache atomicity mode controls whether cache should maintain fully transactional semantics or more light-weight atomic behavior.
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.
CacheConsistencyViolationEvent - Class in org.apache.ignite.events
This is an experimental API.
CacheConsistencyViolationEvent(String, ClusterNode, String, Map<Object, CacheConsistencyViolationEvent.EntriesInfo>, Map<Object, Object>, ReadRepairStrategy) - Constructor for class org.apache.ignite.events.CacheConsistencyViolationEvent
Creates a new instance of CacheConsistencyViolationEvent.
CacheConsistencyViolationEvent.EntriesInfo - Interface in org.apache.ignite.events
Inconsistent entries mapping.
CacheConsistencyViolationEvent.EntryInfo - Interface in org.apache.ignite.events
Inconsistent entry info.
cacheCount() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cachedPagesCount() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
CacheEntry<K,V> - Interface in org.apache.ignite.cache
Cache entry that extends Cache.Entry by providing additional entry related information.
CacheEntryEventSerializableFilter<K,V> - Interface in org.apache.ignite.cache
This filter adds Serializable interface to CacheEntryEventFilter object.
CacheEntryProcessor<K,V,T> - Interface in org.apache.ignite.cache
This processor adds Serializable interface to EntryProcessor object.
CacheEntryVersion - Interface in org.apache.ignite.cache
Entry event order.
CacheEvent - Class in org.apache.ignite.events
In-memory database (cache) event.
CacheEvent(String, ClusterNode, ClusterNode, String, int, int, boolean, Object, IgniteUuid, String, Object, Object, boolean, Object, boolean, UUID, String, String) - Constructor for class org.apache.ignite.events.CacheEvent
Constructs cache event.
CacheExistsException - Exception in org.apache.ignite.cache
Exception thrown when cache must be created but it already exists.
CacheExistsException(String) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheExistsException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheExistsException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CachePagesListView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.PartitionStateView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns cache group ID.
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns cache group ID.
CacheGroupIoView - Class in org.apache.ignite.spi.systemview.view
Cache group IO statistics representation for a SystemView.
CacheGroupIoView(CacheGroupContext, MetricRegistry) - Constructor for class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns Cache group name.
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns Cache group name.
cacheGroups() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
CacheGroupView - Class in org.apache.ignite.spi.systemview.view
Cache group representation for the SystemView.
CacheGroupView(CacheGroupDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheId() - Method in interface org.apache.ignite.cdc.CdcCacheEvent
 
cacheId() - Method in interface org.apache.ignite.cdc.CdcEvent
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns cache ID.
cacheId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns cache ID.
cacheIds() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
CacheInterceptor<K,V> - Interface in org.apache.ignite.cache
Cache interceptor.
CacheInterceptorAdapter<K,V> - Class in org.apache.ignite.cache
Cache interceptor convenience adapter.
CacheInterceptorAdapter() - Constructor for class org.apache.ignite.cache.CacheInterceptorAdapter
 
CacheInterceptorEntry<K,V> - Class in org.apache.ignite.cache
A cache interceptor map entry.
CacheInterceptorEntry() - Constructor for class org.apache.ignite.cache.CacheInterceptorEntry
 
CacheJdbcBlobStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
CacheStore implementation backed by JDBC.
CacheJdbcBlobStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
 
CacheJdbcBlobStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
Factory implementation for CacheJdbcBlobStore.
CacheJdbcBlobStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
 
CacheJdbcPojoStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Implementation of CacheStore backed by JDBC and POJO via reflection.
CacheJdbcPojoStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
 
CacheJdbcPojoStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
Factory implementation for CacheJdbcPojoStore.
CacheJdbcPojoStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
 
CacheJdbcStoreSessionListener - Class in org.apache.ignite.cache.store.jdbc
Cache store session listener based on JDBC connection.
CacheJdbcStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
 
CacheJndiTmFactory - Class in org.apache.ignite.cache.jta.jndi
Implementation of Factory<TransactionManager> interface that is using JNDI names to find TM.
CacheJndiTmFactory() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Creates uninitialized jndi TM lookup.
CacheJndiTmFactory(String...) - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Creates generic TM lookup with given jndi names.
CacheJndiTmLookup - Class in org.apache.ignite.cache.jta.jndi
Implementation of CacheTmLookup interface that is using list of JNDI names to find TM.
CacheJndiTmLookup() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
 
CacheKeyConfiguration - Class in org.apache.ignite.cache
Configuration defining various aspects of cache keys without explicit usage of annotations on user classes.
CacheKeyConfiguration() - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
Creates an empty cache key configuration that should be populated via setters.
CacheKeyConfiguration(Class) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
 
CacheKeyConfiguration(String, String) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
Creates cache key configuration with given type name and affinity field name.
cacheLoaderFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheLoadOnlyStoreAdapter<K,V,I> - Class in org.apache.ignite.cache.store
This adapter designed to support stores with bulk loading from stream-like source.
CacheLoadOnlyStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
 
CacheManager - Class in org.apache.ignite.cache
Implementation of JSR-107 CacheManager.
CacheManager(URI, CachingProvider, ClassLoader, Properties) - Constructor for class org.apache.ignite.cache.CacheManager
 
cacheMappings - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Cache with entry mapping description.
CacheMetrics - Interface in org.apache.ignite.cache
Cache metrics used to obtain statistics on cache itself.
cacheMetrics() - Method in interface org.apache.ignite.spi.discovery.DiscoveryMetricsProvider
Returns metrics data about all caches on local node.
cacheMetrics() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collections of cache metrics for this node.
CacheMode - Enum in org.apache.ignite.cache
Enumeration of all supported caching modes.
cacheMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheName() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Cache name for the current store operation.
cacheName() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in class org.apache.ignite.events.CacheEvent
Gets cache name.
cacheName() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets cache name on which query was executed.
cacheName() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets cache name on which query was executed.
cacheName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets cache name.
cacheName() - Method in interface org.apache.ignite.IgniteDataStreamer
Name of cache to stream data to.
cacheName - Variable in class org.apache.ignite.services.ServiceConfiguration
Cache name.
cacheName() - Method in interface org.apache.ignite.services.ServiceContext
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns cache name.
cacheName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns cache name.
CacheNameResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of grid cache name.
cacheNames() - Method in interface org.apache.ignite.client.IgniteClient
Gets the names of all available caches.
cacheNames() - Method in interface org.apache.ignite.Ignite
Gets the collection of names of currently available caches.
cacheNames() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the names of all available caches.
cacheNames() - Method in class org.apache.ignite.IgniteSpringBean
Gets the collection of names of currently available caches.
cacheNamesAsync() - Method in interface org.apache.ignite.client.IgniteClient
Gets the names of all available caches.
cacheNamesAsync() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the names of all available caches.
CacheObjectTransformedEvent - Class in org.apache.ignite.events
 
CacheObjectTransformedEvent(ClusterNode, String, int, byte[], byte[], boolean) - Constructor for class org.apache.ignite.events.CacheObjectTransformedEvent
 
CachePagesListView - Class in org.apache.ignite.spi.systemview.view
Pages-list representation for a SystemView.
CachePagesListView(PagesList, int, int) - Constructor for class org.apache.ignite.spi.systemview.view.CachePagesListView
 
CachePartialUpdateException - Exception in org.apache.ignite.cache
Exception thrown from non-transactional cache in case when update succeeded only partially.
CachePartialUpdateException(CachePartialUpdateCheckedException) - Constructor for exception org.apache.ignite.cache.CachePartialUpdateException
 
cachePartitionOwners(String) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
CachePeekMode - Enum in org.apache.ignite.cache
Enumeration of all supported cache peek modes.
cachePermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of cache names to cache permissions.
cachePermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of cache names to cache permissions.
CachePluginConfiguration<K,V> - Interface in org.apache.ignite.plugin
Cache plugin configuration.
CachePluginContext<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
Cache plugin context.
CachePluginProvider<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
Cache plugin provider is a point for processing of properties which provide specific CachePluginConfiguration.
cachePoolThread() - Method in class org.apache.ignite.thread.IgniteThread
 
CacheQueryEntryEvent<K,V> - Class in org.apache.ignite.cache.query
A Cache continuous query entry event.
CacheQueryEntryEvent(Cache, EventType) - Constructor for class org.apache.ignite.cache.query.CacheQueryEntryEvent
Constructs a cache entry event from a given cache as source.
CacheQueryExecutedEvent<K,V> - Class in org.apache.ignite.events
Cache query execution event.
CacheQueryExecutedEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String) - Constructor for class org.apache.ignite.events.CacheQueryExecutedEvent
 
CacheQueryReadEvent<K,V> - Class in org.apache.ignite.events
Cache query read event.
CacheQueryReadEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String, K, V, V, Object) - Constructor for class org.apache.ignite.events.CacheQueryReadEvent
 
CacheRebalanceMode - Enum in org.apache.ignite.cache
Cache rebalance mode.
CacheRebalancingEvent - Class in org.apache.ignite.events
In-memory database (cache) rebalancing event.
CacheRebalancingEvent(String, ClusterNode, String, int, int, ClusterNode, int, long) - Constructor for class org.apache.ignite.events.CacheRebalancingEvent
Constructs cache event.
CacheReflectionTmLookup - Class in org.apache.ignite.cache.jta.reflect
Implementation of CacheTmLookup interface that attempts to obtain JTA manager by calling static method on the class.
CacheReflectionTmLookup() - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Creates uninitialized reflection TM lookup.
CacheReflectionTmLookup(String, String) - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Creates generic TM lookup with given class and method name.
CacheServerNotFoundException - Exception in org.apache.ignite.cache
Exception thrown when all data nodes left the grid.
CacheServerNotFoundException(String) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheServerNotFoundException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheServerNotFoundException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheStore<K,V> - Interface in org.apache.ignite.cache.store
API for cache persistent storage for read-through and write-through behavior.
CacheStoreAdapter<K,V> - Class in org.apache.ignite.cache.store
Cache storage convenience adapter.
CacheStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheStoreAdapter
 
cacheStoreFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheStoreSession - Interface in org.apache.ignite.cache.store
Session for the cache store operations.
CacheStoreSessionListener - Interface in org.apache.ignite.cache.store
Cache store session listener that allows to implement callbacks for session lifecycle.
CacheStoreSessionResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of current CacheStoreSession instance.
CacheTmLookup - Interface in org.apache.ignite.cache.jta
Allows grid to use different transactional systems.
CacheTopologyValidatorProvider - Interface in org.apache.ignite.plugin
The CacheTopologyValidatorProvider is used to pass an implementation of TopologyValidators for a specific cache through Ignite plugin extensions mechanism.
cacheType() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheView - Class in org.apache.ignite.spi.systemview.view
Cache representation for a SystemView.
CacheView(DynamicCacheDescriptor, GridKernalContext) - Constructor for class org.apache.ignite.spi.systemview.view.CacheView
 
cacheWriterFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheWriteSynchronizationMode - Enum in org.apache.ignite.cache
Mode indicating how Ignite should wait for write replies from other nodes.
CachingProvider - Class in org.apache.ignite.cache
Implementation of JSR-107 CachingProvider.
CachingProvider() - Constructor for class org.apache.ignite.cache.CachingProvider
 
CalciteQueryEngineConfiguration - Class in org.apache.ignite.calcite
Query engine configuration for Calcite-based query engine.
CalciteQueryEngineConfiguration() - Constructor for class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
 
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 fitness 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.
call() - Method in class org.apache.ignite.cache.store.cassandra.session.LoadCacheCustomQueryWorker
call() - Method in class org.apache.ignite.compute.ComputeJobAdapter
call(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job on a node within the underlying cluster group.
call(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within the underlying cluster group.
call(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within the underlying cluster group.
callAsync(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job asynchronously on a node within the underlying cluster group.
callAsync(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on nodes within the underlying cluster group.
callAsync(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on nodes within the underlying cluster group.
callcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callLocal(Callable<R>) - Method in interface org.apache.ignite.IgniteScheduler
Executes given callable on internal system thread pool asynchronously.
CanberraDistance - Class in org.apache.ignite.ml.math.distances
Calculates the Canberra distance between two points.
CanberraDistance() - Constructor for class org.apache.ignite.ml.math.distances.CanberraDistance
 
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(String) - Method in interface org.apache.ignite.mxbean.ComputeMXBean
Kills compute task by the session idenitifier.
cancel() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Cancel defragmentation.
cancel(String) - Method in interface org.apache.ignite.mxbean.ServiceMXBean
 
cancel(String) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Kills transactions by the xid.
cancel() - Method in interface org.apache.ignite.services.Service
Cancels this service.
cancel(ServiceContext) - Method in interface org.apache.ignite.services.Service
Deprecated.
Use Service.cancel() instead.
cancel() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Cancels the job.
cancelAll(Collection<String>) - Method in interface org.apache.ignite.IgniteServices
Cancels services with specified names.
cancelAll() - Method in interface org.apache.ignite.IgniteServices
Cancels all deployed services.
cancelAllAsync(Collection<String>) - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels services with specified names.
cancelAllAsync() - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels all deployed services.
cancelAsync(String) - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels service deployment.
cancelContinuous(String, String) - Method in interface org.apache.ignite.mxbean.QueryMXBean
Kills continuous query by the identifier.
canceled() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cancelScan(String, String, Long) - Method in interface org.apache.ignite.mxbean.QueryMXBean
Kills scan query by the identifiers.
cancelSnapshot(String) - Method in interface org.apache.ignite.IgniteSnapshot
Cancel running snapshot operation.
cancelSnapshot(String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
cancelSnapshotOperation(String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Cancel previously started snapshot operation.
cancelSnapshotRestore(String) - Method in interface org.apache.ignite.IgniteSnapshot
Cancel snapshot restore operation.
cancelSnapshotRestore(String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
cancelSQL(String) - Method in interface org.apache.ignite.mxbean.QueryMXBean
Kills SQL query by the identifier.
candidateFeatures - Variable in class org.apache.ignite.ml.knn.ann.ANNClassificationModel.ANNJSONExportModel
Centers of clusters.
candidateLabels - Variable in class org.apache.ignite.ml.knn.ann.ANNClassificationModel.ANNJSONExportModel
 
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.math
Indicates a cardinality mismatch in matrix or vector operations.
CardinalityException(int, int) - Constructor for exception org.apache.ignite.ml.math.exceptions.math.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.
CatboostClassificationModel - Class in org.apache.ignite.ml.catboost
CatboostClassificationModel imported and wrapped to be compatible with Apache Ignite infrastructure.
CatboostClassificationModel(CatBoostModel) - Constructor for class org.apache.ignite.ml.catboost.CatboostClassificationModel
Constructs a new instance of Catboost model wrapper.
CatboostClassificationModelParser - Class in org.apache.ignite.ml.catboost
Catboost Classification model parser.
CatboostClassificationModelParser() - Constructor for class org.apache.ignite.ml.catboost.CatboostClassificationModelParser
 
CatboostRegressionModel - Class in org.apache.ignite.ml.catboost
CatboostRegressionModel imported and wrapped to be compatible with Apache Ignite infrastructure.
CatboostRegressionModel(CatBoostModel) - Constructor for class org.apache.ignite.ml.catboost.CatboostRegressionModel
Constructs a new instance of Catboost model wrapper.
CatboostRegressionModelParser - Class in org.apache.ignite.ml.catboost
Catboost Regression model parser.
CatboostRegressionModelParser() - Constructor for class org.apache.ignite.ml.catboost.CatboostRegressionModelParser
 
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.
CdcCacheEvent - Interface in org.apache.ignite.cdc
Notification of CdcConsumer about cache creation/change events.
CdcCommandLineStartup - Class in org.apache.ignite.startup.cmdline
This class defines command-line Ignite Capture Data Change startup.
CdcCommandLineStartup() - Constructor for class org.apache.ignite.startup.cmdline.CdcCommandLineStartup
 
CdcConfiguration - Class in org.apache.ignite.cdc
This class defines CdcMain runtime configuration.
CdcConfiguration() - Constructor for class org.apache.ignite.cdc.CdcConfiguration
 
CdcConsumer - Interface in org.apache.ignite.cdc
Consumer of WAL data change events.
CdcEvent - Interface in org.apache.ignite.cdc
Event of single entry change.
CdcLoader - Class in org.apache.ignite.cdc
Utility class to load CdcMain from Spring XML configuration.
CdcLoader() - Constructor for class org.apache.ignite.cdc.CdcLoader
 
centers() - Method in interface org.apache.ignite.ml.clustering.kmeans.ClusterizationModel
Get cluster centers.
centers() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel
Get cluster centers.
centerShow(String, String, String, LocalDate, 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
 
centroidStat - Variable in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer.CentroidStat
Count of points closest to the center with a given index.
centroindsStat - Variable in class org.apache.ignite.ml.knn.ann.ANNClassificationModel.ANNJSONExportModel
Centroid statistics.
certificates() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
 
certificates(Certificate[]) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Set client SSL certificates.
certificates() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject client certificates, or null if SSL were not used or client certificate checking not enabled.
CFG_URL_PREFIX - Static variable in class org.apache.ignite.IgniteJdbcDriver
Config URL prefix.
cfgNodeId - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
chain(IgniteClosure<? super IgniteFuture<V>, T>) - Method in interface org.apache.ignite.lang.IgniteFuture
Make a chained future to convert result of this future (when complete) into a new format.
chainAsync(IgniteClosure<? super IgniteFuture<V>, T>, Executor) - Method in interface org.apache.ignite.lang.IgniteFuture
Make a chained future to convert result of this future (when complete) into a new format.
changeCacheGroupKey(Collection<String>) - Method in interface org.apache.ignite.IgniteEncryption
Starts cache group encryption key change process.
changeCacheGroupKey(String) - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
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.
ChebyshevDistance - Class in org.apache.ignite.ml.math.distances
Calculates the max(x_i - y_i) (Chebyshev) distance between two points.
ChebyshevDistance() - Constructor for class org.apache.ignite.ml.math.distances.ChebyshevDistance
 
checkAndReturnSplitValue(int, 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 a timeout.
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.
checkNullParameter(Object, String) - Method in class org.apache.ignite.ssl.SslContextFactory
 
checkParameters() - Method in class org.apache.ignite.ssl.SslContextFactory
Checks that all required parameters are set.
CHECKPOINT_PARALLEL_SORT_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Starting from this number of dirty pages in checkpoint, array will be sorted with Arrays.parallelSort(Comparable[]) in case of CheckpointWriteOrder.SEQUENTIAL.
CHECKPOINT_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CheckpointEvent - Class in org.apache.ignite.events
Grid checkpoint event.
CheckpointEvent() - Constructor for class org.apache.ignite.events.CheckpointEvent
No-arg constructor.
CheckpointEvent(ClusterNode, String, int, String) - Constructor for class org.apache.ignite.events.CheckpointEvent
Creates new checkpoint event with given parameters.
CheckpointListener - Interface in org.apache.ignite.spi.checkpoint
Listener for notifications of checkpoints removed by CheckpointSpi.
CheckpointSpi - Interface in org.apache.ignite.spi.checkpoint
Checkpoint SPI provides an ability to save an intermediate job state.
CheckpointWriteOrder - Enum in org.apache.ignite.configuration
This enum defines order of writing pages to disk storage during checkpoint.
checkRingLatency(int) - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Diagnosis method for determining ring message latency.
checkTimeout(long) - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Check if total timeout will be reached in now() + timeInFut.
checkTimeout(long) - Method in interface org.apache.ignite.spi.TimeoutStrategy
Check if total timeout will be reached in now() + timeInFut.
checkTimeout() - Method in interface org.apache.ignite.spi.TimeoutStrategy
Check if total timeout will be reached by now.
Chromosome - Class in org.apache.ignite.ml.util.genetic
Represents 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
 
CIPHER_ALGO - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Algorithm supported by implementation.
cipherSuites - Variable in class org.apache.ignite.ssl.SslContextFactory
Enabled cipher suites.
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.
ClassificationMetricsAggregator<L extends Serializable> - Class in org.apache.ignite.ml.selection.scoring.evaluator.aggregator
Class represents aggregations for classification metric (including multi-classification case).
ClassificationMetricsAggregator() - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.ClassificationMetricsAggregator
Creates an instance of ClassificationMetricsAggregator.
ClassificationMetricsAggregator(long, long) - Constructor for class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.ClassificationMetricsAggregator
Creates an instance of ClassificationMetricsAggregator.
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.
className() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets queried class name.
className() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets queried class name.
classNameFilter() - Method in interface org.apache.ignite.marshaller.MarshallerContext
Returns class name filter.
classNameFilter(ClassLoader) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns class name filter for marshaller.
clause() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query clause.
clause() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query clause.
cleanup() - Method in class org.apache.ignite.spi.IgniteSpiThread
Should be overridden by child classes if cleanup logic is required.
clear() - Method in interface org.apache.ignite.client.ClientCache
Clears the contents of the cache.
clear(K) - Method in interface org.apache.ignite.client.ClientCache
Clears entry with specified key from the cache.
clear() - Method in interface org.apache.ignite.client.ClientIgniteSet
clear() - Method in interface org.apache.ignite.IgniteCache
clear(K) - Method in interface org.apache.ignite.IgniteCache
Clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
clear() - Method in interface org.apache.ignite.IgniteQueue
clear(int) - Method in interface org.apache.ignite.IgniteQueue
Removes all of the elements from this queue.
clear() - Method in interface org.apache.ignite.IgniteSet
clear() - Method in class org.apache.ignite.lang.IgniteBiTuple
clearAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Clears entries with specified keys from the cache.
clearAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
clearAll() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Removes all events from the event queue.
clearAll() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Removes all events from the event queue.
clearAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Clears entries with specified keys from the cache asynchronously.
clearAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
clearAsync() - Method in interface org.apache.ignite.client.ClientCache
Clears the contents of the cache asynchronously.
clearAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Clears entry with specified key from the cache asynchronously.
clearAsync() - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears the contents of the cache, without notifying listeners or CacheWriters.
clearAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
clearCache() - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Intended for test purposes only.
clearNodeLocalMap() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Clears node local map.
clearQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Clear query entities.
clearStatistics() - Method in interface org.apache.ignite.IgniteCache
Clear cluster statistics for this cache.
clearStatistics(Collection<String>) - Method in interface org.apache.ignite.IgniteCluster
Clear statistics for caches cluster wide.
CLIENT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Time interval that indicates that client reconnect throttle must be reset to zero. 2 minutes by default.
ClientAddressFinder - Interface in org.apache.ignite.client
This interface provides a list of addresses of Ignite server nodes within a cluster.
ClientAtomicConfiguration - Class in org.apache.ignite.client
Configuration for atomic data structures.
ClientAtomicConfiguration() - Constructor for class org.apache.ignite.client.ClientAtomicConfiguration
 
ClientAtomicLong - Interface in org.apache.ignite.client
Distributed atomic long API.
ClientAuthenticationException - Exception in org.apache.ignite.client
Indicates user name or password is invalid.
ClientAuthenticationException(String) - Constructor for exception org.apache.ignite.client.ClientAuthenticationException
Default constructor.
ClientAuthenticationException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthenticationException
Constructs a new exception with the specified detail message and cause.
ClientAuthorizationException - Exception in org.apache.ignite.client
Indicates user has no permission to perform operation.
ClientAuthorizationException() - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Default constructor.
ClientAuthorizationException(Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified cause and a detail message of (cause==null ?
ClientAuthorizationException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified detail message and cause.
ClientAutoCloseableIterator<T> - Interface in org.apache.ignite.client
Auto closeable iterator.
ClientCache<K,V> - Interface in org.apache.ignite.client
Thin client cache.
ClientCacheConfiguration - Class in org.apache.ignite.client
Cache configuration.
ClientCacheConfiguration() - Constructor for class org.apache.ignite.client.ClientCacheConfiguration
Default constructor.
ClientCacheConfiguration(ClientCacheConfiguration) - Constructor for class org.apache.ignite.client.ClientCacheConfiguration
Creates client cache configuration by coping all configuration properties from the given one.
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
 
ClientConnectionException - Exception in org.apache.ignite.client
Indicates all the Ignite servers specified in the client configuration are no longer available.
ClientConnectionException(String) - Constructor for exception org.apache.ignite.client.ClientConnectionException
Constructs a new exception with the specified detail message.
ClientConnectionException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientConnectionException
Constructs a new exception with the specified cause and detail message.
ClientConnectionView - Class in org.apache.ignite.spi.systemview.view
Client connection system view row.
ClientConnectionView(GridNioSession) - Constructor for class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
ClientConnectorConfiguration - Class in org.apache.ignite.configuration
Client connector configuration.
ClientConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ClientConnectorConfiguration
Creates SQL connector configuration with all default values.
ClientConnectorConfiguration(ClientConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ClientConnectorConfiguration
Creates SQL connector configuration by copying all properties from given configuration.
ClientDisconnectListener - Interface in org.apache.ignite.client
Client disconnected event listener.
ClientException - Exception in org.apache.ignite.client
Common thin client unchecked exception.
ClientException() - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with null as its detail message.
ClientException(String) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message.
ClientException(Throwable) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified cause and a detail message of (cause==null ?
ClientException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message and cause.
ClientException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message, cause, suppression enabled or disabled, and writable stack trace enabled or disabled.
ClientExceptionsUtils - Class in org.apache.ignite.spi.communication.tcp
Utils to analyze client-related exceptions.
ClientExceptionsUtils() - Constructor for class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
 
clientFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns client failure detection timeout set to use for network related operations.
ClientFeatureNotSupportedByServerException - Exception in org.apache.ignite.client
Feature not supported by server exception.
ClientFeatureNotSupportedByServerException(String) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
Constructs a new exception with the specified detail message.
ClientFeatureNotSupportedByServerException(ProtocolBitmaskFeature) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
 
ClientFeatureNotSupportedByServerException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
Constructs a new exception with the specified cause and detail message.
ClientIgniteSet<T> - Interface in org.apache.ignite.client
Distributed Set.
ClientOperationType - Enum in org.apache.ignite.client
Client operation type.
clientParams() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Returns the bulk load parameters to send to the client.
ClientPartitionAwarenessMapper - Interface in org.apache.ignite.client
This function calculates the cache key to a partition mapping for each cache key.
ClientPartitionAwarenessMapperFactory - Interface in org.apache.ignite.client
This factory is used on the client side and only when the partition awareness thin client feature is enabled.
ClientProcessorMXBean - Interface in org.apache.ignite.mxbean
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 class org.apache.ignite.IgniteClientSpringBean
Closes this client's open connections and relinquishes all underlying resources.
close() - Method in interface org.apache.ignite.IgniteCountDownLatch
Removes this count down latch.
close(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Streams any remaining data and closes this streamer.
close() - Method in interface org.apache.ignite.IgniteDataStreamer
Closes data streamer.
close() - Method in interface org.apache.ignite.IgniteLock
Removes reentrant lock.
close() - Method in interface org.apache.ignite.IgniteQueue
Removes this queue.
close() - Method in interface org.apache.ignite.IgniteSemaphore
Removes this semaphore.
close() - Method in interface org.apache.ignite.IgniteSet
Removes this set.
close() - Method in class org.apache.ignite.IgniteSpringBean
Closes this instance of grid.
close() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
close() - Method in class org.apache.ignite.ml.catboost.CatboostClassificationModel
close() - Method in class org.apache.ignite.ml.catboost.CatboostRegressionModel
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 class org.apache.ignite.ml.h2o.H2OMojoModel
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.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.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.IgniteSpiCloseableIterator
Closes the iterator and frees all the resources held by the iterator.
close() - Method in interface org.apache.ignite.transactions.Transaction
Ends the transaction.
closeConnection(Connection) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes connection.
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.
clsLbls - Variable in class org.apache.ignite.ml.knn.ann.ProbableLabel
Key is label, value is probability to be this class
clsLblsSet - Variable in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer.CentroidStat
Set of unique labels.
cluster() - Method in interface org.apache.ignite.client.IgniteClient
Gets client cluster facade.
cluster() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCluster interface.
cluster() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets client cluster facade.
cluster() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCluster interface.
cluster(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.
ClusterizationModel<P,V> - Interface in org.apache.ignite.ml.clustering.kmeans
Base interface for all clusterization models.
ClusterMetrics - Interface in org.apache.ignite.cluster
This class represents runtime information on a cluster.
ClusterMetricsMXBean - Interface in org.apache.ignite.mxbean
Cluster metrics MBean.
ClusterNode - Interface in org.apache.ignite.cluster
Interface representing a single cluster node.
ClusterNodeAttributeAffinityBackupFilter - Class in org.apache.ignite.cache.affinity.rendezvous
Attribute-based affinity backup filter that forces each partition's primary and backup nodes to different hardware which is not expected to fail simultaneously, e.g., in AWS, to different "availability zones".
ClusterNodeAttributeAffinityBackupFilter(String...) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
 
ClusterNodeAttributeColocatedBackupFilter - Class in org.apache.ignite.cache.affinity.rendezvous
This class can be used as a RendezvousAffinityFunction.affinityBackupFilter to create cache templates in Spring that force each partition's primary and backup to be co-located on nodes with the same attribute value.
ClusterNodeAttributeColocatedBackupFilter(String) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeColocatedBackupFilter
 
ClusterNodeView - Class in org.apache.ignite.spi.systemview.view
Cluster node representation for a SystemView.
ClusterNodeView(ClusterNode) - Constructor for class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
ClusterStartNodeResult - Interface in org.apache.ignite.cluster
Cluster start node result information.
ClusterState - Enum in org.apache.ignite.cluster
Cluster states.
clusterState() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.clusterState" instead.
clusterState(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
clusterState(String, boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Changes current cluster state.
ClusterStateChangeEvent - Class in org.apache.ignite.events
Cluster state change event.
ClusterStateChangeEvent(ClusterState, ClusterState, Collection<? extends BaselineNode>, ClusterNode, String) - Constructor for class org.apache.ignite.events.ClusterStateChangeEvent
 
ClusterStateChangeStartedEvent - Class in org.apache.ignite.events
Cluster state change started event.
ClusterStateChangeStartedEvent(ClusterState, ClusterState, ClusterNode, String) - 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.
code() - Method in enum org.apache.ignite.cache.CacheMode
 
collect(E) - Method in interface org.apache.ignite.lang.IgniteReducer
Collects given value.
collect(DiscoveryDataBag) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
Collects data from all components.
CollectionConfiguration - Class in org.apache.ignite.configuration
Configuration for Ignite collections.
CollectionConfiguration() - Constructor for class org.apache.ignite.configuration.CollectionConfiguration
 
collectionOf(Collection<DataRegionMetrics>) - Static method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Converts collection of DataRegionMetrics into collection of legacy MemoryMetrics.
collectMessagesCountByNodeId(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collect messages count by nodeId
collectMessagesCountByType(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collect messages count by type
COLLISION_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CollisionContext - Interface in org.apache.ignite.spi.collision
Context for resolving collisions.
CollisionExternalListener - Interface in org.apache.ignite.spi.collision
Listener to be set on CollisionSpi for notification of external collision events (e.g. job stealing).
CollisionJobContext - Interface in org.apache.ignite.spi.collision
This interface defines set of operations that collision SPI implementation can perform on jobs that are either waiting or executing.
CollisionSpi - Interface in org.apache.ignite.spi.collision
Collision SPI allows to regulate how grid jobs get executed when they arrive on a destination node for execution.
collocated() - Method in interface org.apache.ignite.IgniteQueue
Returns true if this queue can be kept on the one node only.
collocated() - Method in interface org.apache.ignite.IgniteSet
Returns true if this set can be kept on the one node only.
collocated() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
collocated() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
colocated() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether all items of this set are stored on a single node.
colocated() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
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.math
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.math.ColumnIndexException
 
columnName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
columnName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
columnOffset() - Method in class org.apache.ignite.ml.math.primitives.matrix.storage.ViewMatrixStorage
 
columns() - Method in class org.apache.ignite.spi.systemview.view.sql.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 ?
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
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.
CompoundNaiveBayesModel - Class in org.apache.ignite.ml.naivebayes.compound
A compound Naive Bayes model which uses a composition ofGaussianNaiveBayesModel and DiscreteNaiveBayesModel.
CompoundNaiveBayesModel() - Constructor for class org.apache.ignite.ml.naivebayes.compound.CompoundNaiveBayesModel
 
CompoundNaiveBayesTrainer - Class in org.apache.ignite.ml.naivebayes.compound
Trainer for the compound Naive Bayes classifier model.
CompoundNaiveBayesTrainer() - Constructor for class org.apache.ignite.ml.naivebayes.compound.CompoundNaiveBayesTrainer
 
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.
compute() - Method in interface org.apache.ignite.client.IgniteClient
Gets compute facade over all cluster nodes started in server mode.
compute(ClientClusterGroup) - Method in interface org.apache.ignite.client.IgniteClient
Gets compute facade over the specified cluster group.
compute() - Method in interface org.apache.ignite.Ignite
Gets compute facade over all cluster nodes started in server mode.
compute(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets compute facade over the specified cluster group.
compute() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets compute facade over all cluster nodes started in server mode.
compute(ClientClusterGroup) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets compute facade over the specified cluster group.
compute() - Method in class org.apache.ignite.IgniteSpringBean
Gets compute facade over all cluster nodes started in server mode.
compute(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets compute facade over the specified cluster group.
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 class org.apache.ignite.ml.math.distances.BrayCurtisDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.CanberraDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.ChebyshevDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.CosineSimilarity
Compute the distance between two n-dimensional vectors.
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, Vector) - Method in class org.apache.ignite.ml.math.distances.JaccardIndex
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.JensenShannonDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.ManhattanDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.MinkowskiDistance
Compute the distance between two n-dimensional vectors.
compute(Vector, Vector) - Method in class org.apache.ignite.ml.math.distances.WeightedMinkowskiDistance
Compute the distance between two n-dimensional vectors.
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.
ComputeMXBean - Interface in org.apache.ignite.mxbean
Compute MXBean interface.
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.
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.
configInfo(String, Object) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformed string for configuration parameter.
configuration() - Method in interface org.apache.ignite.cdc.CdcCacheEvent
Note, CacheConfiguration.getQueryEntities() value not changed on table schema change.
configuration() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the client configuration.
configuration() - Method in interface org.apache.ignite.Ignite
Gets the configuration of this Ignite instance.
configuration() - Method in class org.apache.ignite.IgniteSpringBean
Gets the configuration of this Ignite instance.
ConfigurationView - Class in org.apache.ignite.spi.systemview.view
Configuration value representation for a SystemView.
ConfigurationView(String, String) - Constructor for class org.apache.ignite.spi.systemview.view.ConfigurationView
 
configureConsoleAppender(boolean) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates console appender with some reasonable default logging settings.
configureHistogramMetric(String, long[]) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
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.
conflictResolver() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CONN_IDX_META - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Connection index meta for session.
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcThinDriver
connectCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
connection() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
connectionAvailable(ClusterNode, ClusterNode) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
ConnectionClosedEvent - Class in org.apache.ignite.client.events
 
ConnectionClosedEvent(ConnectionDescription, Throwable) - Constructor for class org.apache.ignite.client.events.ConnectionClosedEvent
 
ConnectionDescription - Class in org.apache.ignite.client.events
 
ConnectionDescription(InetSocketAddress, InetSocketAddress, String, UUID) - Constructor for class org.apache.ignite.client.events.ConnectionDescription
 
connectionDescription() - Method in class org.apache.ignite.client.events.ConnectionEvent
 
connectionDescription() - Method in class org.apache.ignite.client.events.RequestEvent
 
ConnectionEvent - Class in org.apache.ignite.client.events
 
ConnectionEvent(ConnectionDescription) - Constructor for class org.apache.ignite.client.events.ConnectionEvent
 
ConnectionEventListener - Interface in org.apache.ignite.client.events
 
connectionId() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
ConnectorConfiguration - Class in org.apache.ignite.configuration
REST access configuration.
ConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
Creates client connection configuration with all default values.
ConnectorConfiguration(ConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
Creates client connection configuration by copying all properties from given configuration.
ConnectorMessageInterceptor - Interface in org.apache.ignite.configuration
Interface for user-defined object interceptors.
connRecoveryTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default connection recovery timeout in ms.
CONSISTENT_ID_META - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node consistent id meta for session.
CONSISTENT_ID_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite node consistent id.
consistentId() - Method in interface org.apache.ignite.cluster.BaselineNode
Gets consistent globally unique node ID.
consistentId() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets consistent globally unique node ID.
consistentId() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets consistent globally unique node ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.systemview.view.BaselineNodeView
 
consistentId() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
consistentId() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
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 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(K) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains an entry for the specified key.
containsKey(K) - Method in interface org.apache.ignite.IgniteCache
containsKey(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
containsKey(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns true if this cache contains a mapping for the specified key.
containsKeyAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains an entry for the specified key asynchronously.
containsKeyAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains an entry for the specified key.
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains entries for the specified keys.
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Determines if the Cache contains entries for the specified keys.
containsKeysAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains entries for the specified keys asynchronously.
containsKeysAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains entries for the specified keys.
containsValue(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
contextDestroyed(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
contextInitialized(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
ContinuousQuery<K,V> - Class in org.apache.ignite.cache.query
API for configuring continuous cache queries.
ContinuousQuery() - Constructor for class org.apache.ignite.cache.query.ContinuousQuery
Creates new continuous query.
continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets continuous query filter.
continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets continuous query filter.
ContinuousQueryView - Class in org.apache.ignite.spi.systemview.view
Continuous query representation for a SystemView.
ContinuousQueryView(UUID, GridContinuousProcessor.RoutineInfo) - Constructor for class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
ContinuousQueryWithTransformer<K,V,T> - Class in org.apache.ignite.cache.query
API for configuring continuous cache queries with transformer.
ContinuousQueryWithTransformer() - Constructor for class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Creates new continuous query with transformer.
ContinuousQueryWithTransformer.EventListener<T> - Interface in org.apache.ignite.cache.query
Interface for local listener of ContinuousQueryWithTransformer to implement.
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.
convert(PrintStream, IgniteWalConverterArguments) - Static method in class org.apache.ignite.development.utils.IgniteWalConverter
Write to out WAL log data in human-readable form.
convert() - Method in class org.apache.ignite.ml.clustering.kmeans.KMeansModel.KMeansJSONExportModel
Convert JSON string to IgniteModel object.
convert() - Method in class org.apache.ignite.ml.inference.json.JSONModel
Convert JSON string to IgniteModel object.
convert() - Method in class org.apache.ignite.ml.knn.ann.ANNClassificationModel.ANNJSONExportModel
Convert JSON string to IgniteModel object.
convert() - Method in class org.apache.ignite.ml.regressions.linear.LinearRegressionModel.LinearRegressionModelJSONExportModel
Convert JSON string to IgniteModel object.
convert() - Method in class org.apache.ignite.ml.regressions.logistic.LogisticRegressionModel.LogisticRegressionJSONExportModel
Convert JSON string to IgniteModel object.
convert() - Method in class org.apache.ignite.ml.svm.SVMLinearClassificationModel.SVMLinearClassificationJSONExportModel
Convert JSON string to IgniteModel object.
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.
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
 
corr() - Method in class org.apache.ignite.ml.dataset.primitive.SimpleDataset
Calculates correlation matrix by all columns.
CosineSimilarity - Class in org.apache.ignite.ml.math.distances
Calculates the A * B / (|A| * |B|) (Cosine similarity) distance between two points.
CosineSimilarity() - Constructor for class org.apache.ignite.ml.math.distances.CosineSimilarity
 
count() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets current count value of the latch.
count() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets total count of executions this task has already completed.
count() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
count() - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
 
countDown() - Method in interface org.apache.ignite.IgniteCountDownLatch
Decrements the count of the latch, releasing all waiting threads on all nodes if the count reaches zero.
countDown(int) - Method in interface org.apache.ignite.IgniteCountDownLatch
Decreases the count of the latch using passed in value, releasing all waiting threads on all nodes if the count reaches zero.
countDownAll() - Method in interface org.apache.ignite.IgniteCountDownLatch
Counts down this latch to zero, releasing all waiting threads on all nodes.
countDownLatch(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates count down latch.
countDownLatch(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates count down latch.
CountDownLatchView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteCountDownLatch representation for a SystemView.
CountDownLatchView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
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 histogram 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 - Variable in class org.apache.ignite.ml.knn.ann.ANNClassificationTrainer.CentroidStat
Count of points closest to the center with a given index.
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).
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.jdbc.CacheJdbcBlobStoreFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
create(String, int) - Method in interface org.apache.ignite.client.ClientPartitionAwarenessMapperFactory
 
create() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
create(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 enum org.apache.ignite.ml.selection.scoring.metric.MetricName
Creates an instance of metric class by name.
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
createCache(String, C) - Method in class org.apache.ignite.cache.CacheManager
createCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with a default configuration.
createCache(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with the specified configuration.
createCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache using template configuration.
createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with a default configuration.
createCache(ClientCacheConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with the specified configuration.
createCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache with the given cache configuration.
createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache using template configuration.
createCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with a default configuration.
createCacheAsync(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with the specified configuration.
createCacheAsync(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with a default configuration.
createCacheAsync(ClientCacheConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with the specified configuration.
createCacheProvider(CachePluginContext) - Method in 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.
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.
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.
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.
createIncrementalSnapshot(String) - Method in interface org.apache.ignite.IgniteSnapshot
Create an incremental snapshot for an existing snapshot.
createIncrementalSnapshot(String, String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Create the cluster-wide incremental snapshot for the given full snapshot.
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.
createInitializedContext() - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.BinaryClassificationPointwiseMetricStatsAggregator
Returns initialized context.
createInitializedContext() - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.BinaryClassificationPointwiseMetricStatsAggregator.WithCustomLabelsAggregator
Returns initialized context.
createInitializedContext() - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.ClassificationMetricsAggregator
Returns initialized context.
createInitializedContext() - Method in interface org.apache.ignite.ml.selection.scoring.evaluator.aggregator.MetricStatsAggregator
Returns initialized context.
createInitializedContext() - Method in class org.apache.ignite.ml.selection.scoring.evaluator.aggregator.RegressionMetricStatsAggregator
Returns initialized context.
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.
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.
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(String) - Method in interface org.apache.ignite.IgniteSnapshot
Create a consistent copy of all persistence cache groups from the whole cluster.
createSnapshot(String, String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Create the cluster-wide snapshot with given name asynchronously.
createSpiAttributeName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Creates new name for the given attribute.
createTcpClient(ClusterNode, int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Establish TCP connection to remote node and returns client.
createTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets time in milliseconds at which this future was created.
createTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
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.
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.
CrossoverStrategy - Enum in org.apache.ignite.ml.util.genetic
Represents the crossover strategy depending of locus point amount.
CrossValidation<M extends IgniteModel<Vector,Double>,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
 
curActiveJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curCanceledJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curCpuLoad() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curDaemonThreadCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curGcCpuLoad() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curIdleTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curJobsExecuteTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curJobsWaitTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curRejectedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
current() - Static method in class org.apache.ignite.thread.IgniteThread
 
currentBaselineTopology() - Method in interface org.apache.ignite.IgniteCluster
Gets current baseline topology.
currentCallContext() - Method in interface org.apache.ignite.services.ServiceContext
Gets context of the current service call.
currentThreadCanRequestBinaryMetadata() - Static method in class org.apache.ignite.thread.IgniteThread
 
currentTopologySnapshot() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets current topology snapshot.
currentTopologyVersion() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets current topology version number.
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)).
curThreadCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curWaitingJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
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
 
DataPageEvictionMode - Enum in org.apache.ignite.configuration
Defines memory page eviction algorithm.
DataRegionConfiguration - Class in org.apache.ignite.configuration
This class allows defining custom data regions' configurations with various parameters for Apache Ignite page memory (see DataStorageConfiguration.
DataRegionConfiguration() - Constructor for class org.apache.ignite.configuration.DataRegionConfiguration
 
DataRegionMetrics - Interface in org.apache.ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
dataRegionMetrics() - Method in interface org.apache.ignite.Ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
dataRegionMetrics(String) - Method in interface org.apache.ignite.Ignite
Returns the latest DataRegionMetrics snapshot for the memory region of the given name.
dataRegionMetrics() - Method in class org.apache.ignite.IgniteSpringBean
Returns a collection of DataRegionMetrics that reflects page memory usage on this Apache Ignite node instance.
dataRegionMetrics(String) - Method in class org.apache.ignite.IgniteSpringBean
Returns the latest DataRegionMetrics snapshot for the memory region of the given name.
DataRegionMetricsAdapter - Class in org.apache.ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
DataRegionMetricsProvider - Interface in org.apache.ignite
This interface provides calculated metrics for data region.
dataRegionName() - Method in class org.apache.ignite.events.PageReplacementStartedEvent
Gets data region name for which page replacement started.
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.PagesTimestampHistogramView
 
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[]) - 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.
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.
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
 
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.java.JavaLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out debug message.
debug(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out debug message.
debug(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out debug message.
DebugCrossValidation<M extends IgniteModel<Vector,Double>,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
 
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.
DecisionTreeConditionalNode() - Constructor for class org.apache.ignite.ml.tree.DecisionTreeConditionalNode
For jackson serialization needs.
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.
DecisionTreeLeafNode() - Constructor for class org.apache.ignite.ml.tree.DecisionTreeLeafNode
For jackson serialization needs.
DecisionTreeModel - Class in org.apache.ignite.ml.tree
Base class for decision tree models.
DecisionTreeModel(DecisionTreeNode) - Constructor for class org.apache.ignite.ml.tree.DecisionTreeModel
Creates the model.
DecisionTreeNode - Class in org.apache.ignite.ml.tree
Base interface for decision tree nodes.
DecisionTreeNode() - Constructor for class org.apache.ignite.ml.tree.DecisionTreeNode
Empty constructor for serialization needs.
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.
DecisionTreeTrainer<T extends ImpurityMeasure<T>> - Class in org.apache.ignite.ml.tree
Distributed decision tree trainer that allows to fit trees using row-partitioned dataset.
decrementAndGet() - Method in interface org.apache.ignite.client.ClientAtomicLong
Decrements and gets current value of atomic long.
decrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Decrements and gets current value of atomic long.
decrypt(byte[], Serializable) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
decrypt(byte[], Serializable) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
decrypt(byte[], Serializable) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
decryptKey(byte[]) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptKey(byte[]) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptKey(byte[]) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
DEFAULT - Static variable in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Default instance.
DEFAULT() - Constructor for class org.apache.ignite.resources.SpringResource.DEFAULT
 
DEFAULT_COMMUNICATION_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default communication configuration.
DEFAULT_DISCOVERY_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default discovery configuration.
DEFAULT_EXCHANGE_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default exchange configuration.
DEFAULT_KEY_SIZE - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Default encryption key size;
DEFAULT_MASTER_KEY_NAME - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Default key store entry name to store Encryption master key.
DEFAULT_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_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.
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.sql.SqlTableColumnView
 
defaultValue() - Method in class org.apache.ignite.spi.systemview.view.sql.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
 
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.jdbc.CacheAbstractJdbcStore
delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.cassandra.CassandraCacheStore
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
deleteDirectory(Path) - Static method in class org.apache.ignite.ml.inference.util.DirectorySerializer
Removes the specified directory.
DeleteMutation - Class in org.apache.ignite.cache.store.cassandra.session.transaction
Mutation which deletes object from Cassandra.
DeleteMutation(Object, String, PersistenceController) - Constructor for class org.apache.ignite.cache.store.cassandra.session.transaction.DeleteMutation
Creates instance of delete mutation operation.
DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Delimiter to use between address and port tokens in file names.
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(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
 
description() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
description() - Method in interface org.apache.ignite.spi.metric.Metric
 
description() - Method in class org.apache.ignite.spi.systemview.view.MetricsView
 
description() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewView
 
description() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
description() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
deserialize() - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
deserialize(ClassLoader) - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
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.
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
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.IgniteClientSpringBean
Destroys the cache with the given name.
destroyCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Destroys a cache with the given name and cleans data that was written to the cache.
destroyCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Destroys the cache with the given name.
destroyCacheAsync(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Destroys the cache with the given name.
destroyCaches(Collection<String>) - Method in interface org.apache.ignite.Ignite
Destroys caches with the given names and cleans data that was written to the caches.
destroyCaches(Collection<String>) - Method in class org.apache.ignite.IgniteSpringBean
Destroys caches with the given names and cleans data that was written to the caches.
destroySession(String) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
detectPojoFields(NodeList) - Method in class org.apache.ignite.cache.store.cassandra.persistence.PersistenceSettings
Extracts POJO fields from a list of corresponding XML field nodes.
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.