You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ch...@apache.org on 2019/04/18 11:55:48 UTC

[ignite] branch master updated: IGNITE-11772: [ML] Broken javadoc

This is an automated email from the ASF dual-hosted git repository.

chief pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/ignite.git


The following commit(s) were added to refs/heads/master by this push:
     new ad08be5  IGNITE-11772: [ML] Broken javadoc
ad08be5 is described below

commit ad08be5eb8fdb2969501ffb64edb45a6d4724ab6
Author: Yury Babak <yb...@gridgain.com>
AuthorDate: Thu Apr 18 14:54:59 2019 +0300

    IGNITE-11772: [ML] Broken javadoc
    
    This closes #6475
---
 .../ml/clustering/gmm/MeanWithClusterProbAggregator.java | 11 +++++------
 .../convergence/simple/ConvergenceCheckerStub.java       |  3 ++-
 .../ignite/ml/composition/stacking/StackedModel.java     |  2 +-
 .../java/org/apache/ignite/ml/genetic/CrossOverJob.java  |  2 +-
 .../java/org/apache/ignite/ml/genetic/CrossOverTask.java | 16 ++++++++--------
 .../java/org/apache/ignite/ml/genetic/FitnessJob.java    |  2 +-
 .../java/org/apache/ignite/ml/genetic/FitnessTask.java   |  6 +++---
 .../java/org/apache/ignite/ml/genetic/MutateJob.java     |  2 +-
 .../java/org/apache/ignite/ml/genetic/MutateTask.java    |  7 ++++---
 .../apache/ignite/ml/genetic/TruncateSelectionJob.java   |  2 +-
 .../apache/ignite/ml/genetic/TruncateSelectionTask.java  |  6 +++---
 .../storage/descriptor/ModelDescriptorStorage.java       |  2 +-
 .../src/main/java/org/apache/ignite/ml/math/Tracer.java  | 10 +++++-----
 .../apache/ignite/ml/math/primitives/matrix/Matrix.java  |  2 +-
 .../java/org/apache/ignite/ml/structures/DatasetRow.java |  1 -
 .../apache/ignite/ml/tree/impurity/ImpurityMeasure.java  |  2 +-
 16 files changed, 38 insertions(+), 38 deletions(-)

diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/clustering/gmm/MeanWithClusterProbAggregator.java b/modules/ml/src/main/java/org/apache/ignite/ml/clustering/gmm/MeanWithClusterProbAggregator.java
index 59e8e2b..56b5dd2 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/clustering/gmm/MeanWithClusterProbAggregator.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/clustering/gmm/MeanWithClusterProbAggregator.java
@@ -17,17 +17,16 @@
 
 package org.apache.ignite.ml.clustering.gmm;
 
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.stream.Collectors;
 import org.apache.ignite.internal.util.typedef.internal.A;
 import org.apache.ignite.ml.dataset.Dataset;
 import org.apache.ignite.ml.dataset.primitive.context.EmptyContext;
 import org.apache.ignite.ml.math.primitives.vector.Vector;
 import org.apache.ignite.ml.math.primitives.vector.VectorUtils;
 
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.stream.Collectors;
-
 /**
  * Statistics aggregator for mean values and cluster probabilities computing.
  */
@@ -82,7 +81,7 @@ class MeanWithClusterProbAggregator implements Serializable {
      * Aggregates statistics for means and cluster probabilities computing given dataset.
      *
      * @param dataset Dataset.
-     * @param countOfComponents
+     * @param countOfComponents Count of componets.
      */
     public static AggregatedStats aggreateStats(Dataset<EmptyContext, GmmPartitionData> dataset, int countOfComponents) {
         return new AggregatedStats(dataset.compute(
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/composition/boosting/convergence/simple/ConvergenceCheckerStub.java b/modules/ml/src/main/java/org/apache/ignite/ml/composition/boosting/convergence/simple/ConvergenceCheckerStub.java
index 0ced3f2..65ade75 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/composition/boosting/convergence/simple/ConvergenceCheckerStub.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/composition/boosting/convergence/simple/ConvergenceCheckerStub.java
@@ -46,7 +46,8 @@ public class ConvergenceCheckerStub<K, V> extends ConvergenceChecker<K, V> {
      * @param externalLbToInternalMapping External label to internal mapping.
      * @param loss Loss function.
      * @param datasetBuilder Dataset builder.
-     * @param vectorizer Upstream vectorizer.
+     * @param preprocessor Preprocessor.
+     * @param precision Precision.
      */
     public ConvergenceCheckerStub(long sampleSize, IgniteFunction externalLbToInternalMapping, Loss loss,
         DatasetBuilder datasetBuilder, Preprocessor<K, V> preprocessor, double precision) {
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/composition/stacking/StackedModel.java b/modules/ml/src/main/java/org/apache/ignite/ml/composition/stacking/StackedModel.java
index 34e1a97..5793c2e 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/composition/stacking/StackedModel.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/composition/stacking/StackedModel.java
@@ -44,7 +44,7 @@ public class StackedModel<IS, IA, O, AM extends IgniteModel<IA, O>> implements I
 
     /**
      * Construct instance of this class from {@link IgniteModel}.
-     * @param mdl
+     * @param mdl Model.
      */
     StackedModel(IgniteModel<IS, O> mdl) {
         this.mdl = mdl;
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java
index 2f213b5..0b8d17c 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java
@@ -96,7 +96,7 @@ public class CrossOverJob extends ComputeJobAdapter {
     /**
      * Perform crossover operation
      */
-    public Object execute() throws IgniteException {
+    @Override public Object execute() throws IgniteException {
 
         if (this.crossOverRate > Math.random()) {
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java
index 9daa57a..e6acada 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java
@@ -65,7 +65,7 @@ public class CrossOverTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param chromosomeKeys Primary keys for respective chromosomes
      * @return A map of nodes to jobs.
      */
-    public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
+    @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
 
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
 
@@ -86,7 +86,7 @@ public class CrossOverTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param list ComputeJobResult
      * @return Boolean value; if operationa was successful return true, otherwise Exception
      */
-    public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
+    @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
         // TODO Auto-generated method stub
         return Boolean.TRUE;
     }
@@ -96,7 +96,7 @@ public class CrossOverTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param rcvd List of ComputeJobResult
      * @return ComputeJobResultPolicy
      */
-    public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
+    @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
         if (err != null)
@@ -108,12 +108,12 @@ public class CrossOverTask extends ComputeTaskAdapter<List<Long>, Boolean> {
     }
 
     /**
-     * Helper method to help assign ComputeJobs to respective ClusterNodes
+     * Helper method to help assign ComputeJobs to respective ClusterNodes.
      *
-     * @param clusterNode
-     * @param keys Primary keys of Chromosomes
-     * @param map Nodes where jobs will be sent
-     * @return A map of ComputeJob/ClusterNode's
+     * @param clusterNode Cluster node.
+     * @param keys Primary keys of Chromosomes.
+     * @param map Nodes where jobs will be sent.
+     * @return A map of ComputeJob/ClusterNode's.
      */
     private Map<ComputeJob, ClusterNode> setupCrossOver(ClusterNode clusterNode, List<Long> keys,
         Map<ComputeJob, ClusterNode> map) {
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java
index 0bde403..5bf7f83 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java
@@ -65,7 +65,7 @@ public class FitnessJob extends ComputeJobAdapter {
      *
      * @return Fitness score
      */
-    public Double execute() throws IgniteException {
+    @Override public Double execute() throws IgniteException {
 
         IgniteCache<Long, Chromosome> populationCache = ignite.cache(GAGridConstants.POPULATION_CACHE);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java
index 66fd795..5a02bed 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java
@@ -55,7 +55,7 @@ public class FitnessTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param chromosomeKeys List of chromosome keys
      * @return Map of jobs to nodes
      */
-    public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
+    @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
 
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
 
@@ -76,7 +76,7 @@ public class FitnessTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param list List of ComputeJobResult
      * @return Boolean value
      */
-    public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
+    @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
 
         return Boolean.TRUE;
     }
@@ -86,7 +86,7 @@ public class FitnessTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param rcvd List of ComputeJobResult
      * @return ComputeJobResultPolicy
      */
-    public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
+    @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
         if (err != null)
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java
index d69911a..5e102a5 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java
@@ -59,7 +59,7 @@ public class MutateJob extends ComputeJobAdapter {
      *
      * @return Boolean value
      */
-    public Boolean execute() throws IgniteException {
+    @Override public Boolean execute() throws IgniteException {
 
         IgniteCache<Long, Chromosome> populationCache = ignite.cache(GAGridConstants.POPULATION_CACHE);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java
index 9fd9147..51c602a 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java
@@ -77,8 +77,9 @@ public class MutateTask extends ComputeTaskAdapter<List<Long>, Boolean> {
     /**
      * @param nodes List of ClusterNode
      * @param chromosomeKeys Primary keys for respective chromosomes
+     * @return Mapping compute jobs to nodes.
      */
-    public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
+    @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
 
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
         Affinity affinity = ignite.affinity(GAGridConstants.POPULATION_CACHE);
@@ -97,7 +98,7 @@ public class MutateTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param list List of ComputeJobResult
      * @return Boolean value
      */
-    public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
+    @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
         return Boolean.TRUE;
     }
 
@@ -106,7 +107,7 @@ public class MutateTask extends ComputeTaskAdapter<List<Long>, Boolean> {
      * @param rcvd List of ComputeJobResult
      * @return ComputeJobResultPolicy
      */
-    public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
+    @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
         if (err != null)
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java
index 19f22c6..4586ff6 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java
@@ -54,7 +54,7 @@ public class TruncateSelectionJob extends ComputeJobAdapter {
      *
      * @return Boolean value
      */
-    public Boolean execute() throws IgniteException {
+    @Override public Boolean execute() throws IgniteException {
 
         IgniteCache<Long, Chromosome> populationCache = ignite.cache(GAGridConstants.POPULATION_CACHE);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java
index 00d00c1..81da7fb 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java
@@ -112,7 +112,7 @@ public class TruncateSelectionTask extends ComputeTaskAdapter<List<Long>, Boolea
      * @param chromosomeKeys Primary keys for respective chromosomes.
      * @return Map of nodes to jobs.
      */
-    public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
+    @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
         Affinity affinity = ignite.affinity(GAGridConstants.POPULATION_CACHE);
 
@@ -135,7 +135,7 @@ public class TruncateSelectionTask extends ComputeTaskAdapter<List<Long>, Boolea
      * @param list List of ComputeJobResult.
      * @return Boolean value.
      */
-    public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
+    @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
         return Boolean.TRUE;
     }
 
@@ -144,7 +144,7 @@ public class TruncateSelectionTask extends ComputeTaskAdapter<List<Long>, Boolea
      * @param rcvd List of ComputeJobResult.
      * @return ComputeJobResultPolicy.
      */
-    public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
+    @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
         if (err != null)
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/inference/storage/descriptor/ModelDescriptorStorage.java b/modules/ml/src/main/java/org/apache/ignite/ml/inference/storage/descriptor/ModelDescriptorStorage.java
index 92b351e..93420d1 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/inference/storage/descriptor/ModelDescriptorStorage.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/inference/storage/descriptor/ModelDescriptorStorage.java
@@ -63,5 +63,5 @@ public interface ModelDescriptorStorage extends Iterable<IgniteBiTuple<String, M
      *
      * @return Iterator of pairs of model identifier and model descriptor.
      */
-    public Iterator<IgniteBiTuple<String, ModelDescriptor>> iterator();
+    @Override public Iterator<IgniteBiTuple<String, ModelDescriptor>> iterator();
 }
\ No newline at end of file
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/Tracer.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/Tracer.java
index da5e53c..be70b7c 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/Tracer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/Tracer.java
@@ -340,7 +340,7 @@ public class Tracer {
      * @param generator Datastream generator.
      * @param limit Count of points that should be taken from dataset.
      * @param xIdx Index of dimension for abscissa representation.
-     * @throws IOException
+     * @throws IOException IOException.
      */
     public static void showRegressionDatasetInHtml(String name, DataStreamGenerator generator, int limit,
         int xIdx) throws IOException {
@@ -356,7 +356,7 @@ public class Tracer {
      * @param generator Datastream generator.
      * @param limit Count of points that should be taken from dataset.
      * @param xIdx Index of dimension for abscissa representation.
-     * @throws IOException
+     * @throws IOException IOException.
      */
     public static void showRegressionDatasetInHtml(DataStreamGenerator generator, int limit,
         int xIdx) throws IOException {
@@ -372,7 +372,7 @@ public class Tracer {
      * @param xIdx Index of dimension for abscissa representation.
      * @param yIdx Index of dimension for ordinate representation.
      * @param isLabeled if isLabeled == true then colors will be used for separate different classes on plane.
-     * @throws IOException
+     * @throws IOException IOException.
      */
     public static void showClassificationDatasetHtml(DataStreamGenerator generator, int limit,
         int xIdx, int yIdx, boolean isLabeled) throws IOException {
@@ -389,7 +389,7 @@ public class Tracer {
      * @param xIdx Index of dimension for abscissa representation.
      * @param yIdx Index of dimension for ordinate representation.
      * @param isLabeled if isLabeled == true then colors will be used for separate different classes on plane.
-     * @throws IOException
+     * @throws IOException IOException.
      */
     public static void showClassificationDatasetHtml(String name, DataStreamGenerator generator, int limit,
         int xIdx, int yIdx, boolean isLabeled) throws IOException {
@@ -415,7 +415,7 @@ public class Tracer {
      * @param xIndex Index of abscissa in vector.
      * @param yGetter Getter of ordinate value from vector.
      * @param colorGetter Getter of collor for showing.
-     * @throws IOException
+     * @throws IOException IOException.
      */
     private static void showVectorsHtml(String name, List<LabeledVector<Double>> values,
         int xIndex, Function<LabeledVector<Double>, Double> yGetter,
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java
index 134c29b..c952347 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java
@@ -508,7 +508,7 @@ public interface Matrix extends MetaAttributes, Externalizable, StorageOpsMetric
     /**
      * Destroys matrix if managed outside of JVM. It's a no-op in all other cases.
      */
-    public default void destroy() {
+    @Override public default void destroy() {
         // No-op.
     }
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/structures/DatasetRow.java b/modules/ml/src/main/java/org/apache/ignite/ml/structures/DatasetRow.java
index fae78b9..a243fd8 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/structures/DatasetRow.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/structures/DatasetRow.java
@@ -113,7 +113,6 @@ public class DatasetRow<V extends Vector> implements Serializable, Externalizabl
      *
      * @param idx Dataset row index to set value at.
      * @param val Value to set.
-     * @return This dataset row.
      * @throws IndexException Throw if index is out of bounds.
      */
     public void set(int idx, double val) {
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/tree/impurity/ImpurityMeasure.java b/modules/ml/src/main/java/org/apache/ignite/ml/tree/impurity/ImpurityMeasure.java
index 85f59e6..5f88a3b 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/tree/impurity/ImpurityMeasure.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/tree/impurity/ImpurityMeasure.java
@@ -49,7 +49,7 @@ public interface ImpurityMeasure<T extends ImpurityMeasure<T>> extends Comparabl
     public T subtract(T measure);
 
     /** {@inheritDoc} */
-    public default int compareTo(T o) {
+    @Override public default int compareTo(T o) {
         return Double.compare(impurity(), o.impurity());
     }
 }