You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by pravingadakh <gi...@git.apache.org> on 2015/11/06 07:49:23 UTC

[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

GitHub user pravingadakh opened a pull request:

    https://github.com/apache/spark/pull/9516

    [SPARK-11550][Docs] Replace example code in mllib-optimization.md using include_example

    

You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/pravingadakh/spark SPARK-11550

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/spark/pull/9516.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #9516
    
----
commit 82e517bf6be5dcfcdbf4d8f7df9b878ac4248297
Author: Pravin Gadakh <pr...@gmail.com>
Date:   2015-11-06T06:48:15Z

    Replace example code in mllib-optimization.md using include_example

----


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44366366
  
    --- Diff: examples/src/main/java/org/apache/spark/examples/mllib/JavaLBFGSExample.java ---
    @@ -0,0 +1,104 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.examples.mllib;
    +
    +// $example on$
    +import java.util.Arrays;
    +
    +import scala.Tuple2;
    +
    +import org.apache.spark.api.java.*;
    +import org.apache.spark.api.java.function.Function;
    +import org.apache.spark.mllib.classification.LogisticRegressionModel;
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics;
    +import org.apache.spark.mllib.linalg.Vector;
    +import org.apache.spark.mllib.linalg.Vectors;
    +import org.apache.spark.mllib.optimization.*;
    +import org.apache.spark.mllib.regression.LabeledPoint;
    +import org.apache.spark.mllib.util.MLUtils;
    +import org.apache.spark.SparkConf;
    +import org.apache.spark.SparkContext;
    +
    +public class JavaLBFGSExample {
    +  public static void main(String[] args) {
    +    SparkConf conf = new SparkConf().setAppName("L-BFGS Example");
    +    SparkContext sc = new SparkContext(conf);
    +    String path = "data/mllib/sample_libsvm_data.txt";
    +    JavaRDD<LabeledPoint> data = MLUtils.loadLibSVMFile(sc, path).toJavaRDD();
    +    int numFeatures = data.take(1).get(0).features().size();
    +
    +    // Split initial RDD into two... [60% training data, 40% testing data].
    +    JavaRDD<LabeledPoint> trainingInit = data.sample(false, 0.6, 11L);
    +    JavaRDD<LabeledPoint> test = data.subtract(trainingInit);
    +
    +    // Append 1 into the training data as intercept.
    +    JavaRDD<Tuple2<Object, Vector>> training = data.map(
    +      new Function<LabeledPoint, Tuple2<Object, Vector>>() {
    +        public Tuple2<Object, Vector> call(LabeledPoint p) {
    +          return new Tuple2<Object, Vector>(p.label(), MLUtils.appendBias(p.features()));
    +        }
    +      });
    +    training.cache();
    +
    +    // Run training algorithm to build the model.
    +    int numCorrections = 10;
    +    double convergenceTol = 1e-4;
    +    int maxNumIterations = 20;
    +    double regParam = 0.1;
    +    Vector initialWeightsWithIntercept = Vectors.dense(new double[numFeatures + 1]);
    +
    +    Tuple2<Vector, double[]> result = LBFGS.runLBFGS(
    +      training.rdd(),
    +      new LogisticGradient(),
    +      new SquaredL2Updater(),
    +      numCorrections,
    +      convergenceTol,
    +      maxNumIterations,
    +      regParam,
    +      initialWeightsWithIntercept);
    +    Vector weightsWithIntercept = result._1();
    +    double[] loss = result._2();
    +
    +    final LogisticRegressionModel model = new LogisticRegressionModel(
    +      Vectors.dense(Arrays.copyOf(weightsWithIntercept.toArray(), weightsWithIntercept.size() - 1)),
    +      (weightsWithIntercept.toArray())[weightsWithIntercept.size() - 1]);
    +
    +    // Clear the default threshold.
    +    model.clearThreshold();
    +
    +    // Compute raw scores on the test set.
    +    JavaRDD<Tuple2<Object, Object>> scoreAndLabels = test.map(
    +      new Function<LabeledPoint, Tuple2<Object, Object>>() {
    +        public Tuple2<Object, Object> call(LabeledPoint p) {
    +          Double score = model.predict(p.features());
    +          return new Tuple2<Object, Object>(score, p.label());
    +        }
    +      });
    +
    +    // Get evaluation metrics.
    +    BinaryClassificationMetrics metrics =
    +      new BinaryClassificationMetrics(scoreAndLabels.rdd());
    +    double auROC = metrics.areaUnderROC();
    +
    +    System.out.println("Loss of each step in training process");
    +    for (double l : loss)
    +      System.out.println(l);
    +    System.out.println("Area under ROC = " + auROC);
    --- End diff --
    
    `$example off$` here


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155531043
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by asfgit <gi...@git.apache.org>.
Github user asfgit closed the pull request at:

    https://github.com/apache/spark/pull/9516


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155271814
  
    @pravingadakh Everything looks good except for the positions of comments.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44366190
  
    --- Diff: examples/src/main/java/org/apache/spark/examples/mllib/JavaLBFGSExample.java ---
    @@ -0,0 +1,104 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.examples.mllib;
    +
    +// $example on$
    +import java.util.Arrays;
    +
    +import scala.Tuple2;
    +
    +import org.apache.spark.api.java.*;
    +import org.apache.spark.api.java.function.Function;
    +import org.apache.spark.mllib.classification.LogisticRegressionModel;
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics;
    +import org.apache.spark.mllib.linalg.Vector;
    +import org.apache.spark.mllib.linalg.Vectors;
    +import org.apache.spark.mllib.optimization.*;
    +import org.apache.spark.mllib.regression.LabeledPoint;
    +import org.apache.spark.mllib.util.MLUtils;
    +import org.apache.spark.SparkConf;
    +import org.apache.spark.SparkContext;
    +
    +public class JavaLBFGSExample {
    +  public static void main(String[] args) {
    +    SparkConf conf = new SparkConf().setAppName("L-BFGS Example");
    +    SparkContext sc = new SparkContext(conf);
    +    String path = "data/mllib/sample_libsvm_data.txt";
    +    JavaRDD<LabeledPoint> data = MLUtils.loadLibSVMFile(sc, path).toJavaRDD();
    +    int numFeatures = data.take(1).get(0).features().size();
    +
    +    // Split initial RDD into two... [60% training data, 40% testing data].
    +    JavaRDD<LabeledPoint> trainingInit = data.sample(false, 0.6, 11L);
    +    JavaRDD<LabeledPoint> test = data.subtract(trainingInit);
    +
    +    // Append 1 into the training data as intercept.
    +    JavaRDD<Tuple2<Object, Vector>> training = data.map(
    +      new Function<LabeledPoint, Tuple2<Object, Vector>>() {
    +        public Tuple2<Object, Vector> call(LabeledPoint p) {
    +          return new Tuple2<Object, Vector>(p.label(), MLUtils.appendBias(p.features()));
    +        }
    +      });
    +    training.cache();
    +
    +    // Run training algorithm to build the model.
    +    int numCorrections = 10;
    +    double convergenceTol = 1e-4;
    +    int maxNumIterations = 20;
    +    double regParam = 0.1;
    +    Vector initialWeightsWithIntercept = Vectors.dense(new double[numFeatures + 1]);
    +
    +    Tuple2<Vector, double[]> result = LBFGS.runLBFGS(
    +      training.rdd(),
    +      new LogisticGradient(),
    +      new SquaredL2Updater(),
    +      numCorrections,
    +      convergenceTol,
    +      maxNumIterations,
    +      regParam,
    +      initialWeightsWithIntercept);
    +    Vector weightsWithIntercept = result._1();
    +    double[] loss = result._2();
    +
    +    final LogisticRegressionModel model = new LogisticRegressionModel(
    +      Vectors.dense(Arrays.copyOf(weightsWithIntercept.toArray(), weightsWithIntercept.size() - 1)),
    +      (weightsWithIntercept.toArray())[weightsWithIntercept.size() - 1]);
    +
    +    // Clear the default threshold.
    +    model.clearThreshold();
    +
    +    // Compute raw scores on the test set.
    +    JavaRDD<Tuple2<Object, Object>> scoreAndLabels = test.map(
    +      new Function<LabeledPoint, Tuple2<Object, Object>>() {
    +        public Tuple2<Object, Object> call(LabeledPoint p) {
    +          Double score = model.predict(p.features());
    +          return new Tuple2<Object, Object>(score, p.label());
    +        }
    +      });
    +
    +    // Get evaluation metrics.
    +    BinaryClassificationMetrics metrics =
    +      new BinaryClassificationMetrics(scoreAndLabels.rdd());
    +    double auROC = metrics.areaUnderROC();
    +
    +    System.out.println("Loss of each step in training process");
    +    for (double l : loss)
    +      System.out.println(l);
    +    System.out.println("Area under ROC = " + auROC);
    +  }
    +}
    +// $example off$
    --- End diff --
    
    remove this line.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44265630
  
    --- Diff: examples/src/main/scala/org/apache/spark/examples/mllib/LBFGSExample.scala ---
    @@ -0,0 +1,91 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +// scalastyle:off println
    +package org.apache.spark.examples.mllib
    +
    +// $example on$
    +import org.apache.spark.mllib.classification.LogisticRegressionModel
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics
    +import org.apache.spark.mllib.linalg.Vectors
    +import org.apache.spark.mllib.optimization.{LBFGS, LogisticGradient, SquaredL2Updater}
    +import org.apache.spark.mllib.util.MLUtils
    +// $example off$
    +
    +import org.apache.spark.{SparkConf, SparkContext}
    +
    +object LBFGSExample {
    +
    +  def main(args: Array[String]) {
    +
    +    val conf = new SparkConf().setAppName("SimpleFPGrowth")
    +    val sc = new SparkContext(conf)
    +
    +    // $example on$
    +    val data = MLUtils.loadLibSVMFile(sc, "data/mllib/sample_libsvm_data.txt")
    +    val numFeatures = data.take(1)(0).features.size
    +
    +    // Split data into training (60%) and test (40%).
    +    val splits = data.randomSplit(Array(0.6, 0.4), seed = 11L)
    +
    +    // Append 1 into the training data as intercept.
    +    val training = splits(0).map(x => (x.label, MLUtils.appendBias(x.features))).cache()
    +
    +    val test = splits(1)
    +
    +    // Run training algorithm to build the model
    +    val numCorrections = 10
    +    val convergenceTol = 1e-4
    +    val maxNumIterations = 20
    +    val regParam = 0.1
    +    val initialWeightsWithIntercept = Vectors.dense(new Array[Double](numFeatures + 1))
    +
    +    val (weightsWithIntercept, loss) = LBFGS.runLBFGS(
    +      training,
    +      new LogisticGradient(),
    +      new SquaredL2Updater(),
    +      numCorrections,
    +      convergenceTol,
    +      maxNumIterations,
    +      regParam,
    +      initialWeightsWithIntercept)
    +
    +    val model = new LogisticRegressionModel(
    +      Vectors.dense(weightsWithIntercept.toArray.slice(0, weightsWithIntercept.size - 1)),
    +      weightsWithIntercept(weightsWithIntercept.size - 1))
    +
    +    // Clear the default threshold.
    +    model.clearThreshold()
    +
    +    // Compute raw scores on the test set.
    +    val scoreAndLabels = test.map { point =>
    +      val score = model.predict(point.features)
    +      (score, point.label)
    +    }
    +
    +    // Get evaluation metrics.
    +    val metrics = new BinaryClassificationMetrics(scoreAndLabels)
    +    val auROC = metrics.areaUnderROC()
    +
    +    println("Loss of each step in training process")
    +    loss.foreach(println)
    +    println("Area under ROC = " + auROC)
    +    // $example off$
    +  }
    +
    --- End diff --
    
    remove the blank line


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44366208
  
    --- Diff: examples/src/main/java/org/apache/spark/examples/mllib/JavaLBFGSExample.java ---
    @@ -0,0 +1,104 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.examples.mllib;
    +
    +// $example on$
    +import java.util.Arrays;
    +
    +import scala.Tuple2;
    +
    +import org.apache.spark.api.java.*;
    +import org.apache.spark.api.java.function.Function;
    +import org.apache.spark.mllib.classification.LogisticRegressionModel;
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics;
    +import org.apache.spark.mllib.linalg.Vector;
    +import org.apache.spark.mllib.linalg.Vectors;
    +import org.apache.spark.mllib.optimization.*;
    +import org.apache.spark.mllib.regression.LabeledPoint;
    +import org.apache.spark.mllib.util.MLUtils;
    +import org.apache.spark.SparkConf;
    +import org.apache.spark.SparkContext;
    +
    +public class JavaLBFGSExample {
    +  public static void main(String[] args) {
    +    SparkConf conf = new SparkConf().setAppName("L-BFGS Example");
    +    SparkContext sc = new SparkContext(conf);
    +    String path = "data/mllib/sample_libsvm_data.txt";
    +    JavaRDD<LabeledPoint> data = MLUtils.loadLibSVMFile(sc, path).toJavaRDD();
    +    int numFeatures = data.take(1).get(0).features().size();
    +
    +    // Split initial RDD into two... [60% training data, 40% testing data].
    +    JavaRDD<LabeledPoint> trainingInit = data.sample(false, 0.6, 11L);
    +    JavaRDD<LabeledPoint> test = data.subtract(trainingInit);
    +
    +    // Append 1 into the training data as intercept.
    +    JavaRDD<Tuple2<Object, Vector>> training = data.map(
    +      new Function<LabeledPoint, Tuple2<Object, Vector>>() {
    +        public Tuple2<Object, Vector> call(LabeledPoint p) {
    +          return new Tuple2<Object, Vector>(p.label(), MLUtils.appendBias(p.features()));
    +        }
    +      });
    +    training.cache();
    +
    +    // Run training algorithm to build the model.
    +    int numCorrections = 10;
    +    double convergenceTol = 1e-4;
    +    int maxNumIterations = 20;
    +    double regParam = 0.1;
    +    Vector initialWeightsWithIntercept = Vectors.dense(new double[numFeatures + 1]);
    +
    +    Tuple2<Vector, double[]> result = LBFGS.runLBFGS(
    +      training.rdd(),
    +      new LogisticGradient(),
    +      new SquaredL2Updater(),
    +      numCorrections,
    +      convergenceTol,
    +      maxNumIterations,
    +      regParam,
    +      initialWeightsWithIntercept);
    +    Vector weightsWithIntercept = result._1();
    +    double[] loss = result._2();
    +
    +    final LogisticRegressionModel model = new LogisticRegressionModel(
    +      Vectors.dense(Arrays.copyOf(weightsWithIntercept.toArray(), weightsWithIntercept.size() - 1)),
    +      (weightsWithIntercept.toArray())[weightsWithIntercept.size() - 1]);
    +
    +    // Clear the default threshold.
    +    model.clearThreshold();
    +
    +    // Compute raw scores on the test set.
    +    JavaRDD<Tuple2<Object, Object>> scoreAndLabels = test.map(
    +      new Function<LabeledPoint, Tuple2<Object, Object>>() {
    +        public Tuple2<Object, Object> call(LabeledPoint p) {
    +          Double score = model.predict(p.features());
    +          return new Tuple2<Object, Object>(score, p.label());
    +        }
    +      });
    +
    +    // Get evaluation metrics.
    +    BinaryClassificationMetrics metrics =
    +      new BinaryClassificationMetrics(scoreAndLabels.rdd());
    +    double auROC = metrics.areaUnderROC();
    +
    +    System.out.println("Loss of each step in training process");
    +    for (double l : loss)
    +      System.out.println(l);
    +    System.out.println("Area under ROC = " + auROC);
    --- End diff --
    
    `$example off$` here


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155582001
  
    Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44366029
  
    --- Diff: examples/src/main/java/org/apache/spark/examples/mllib/JavaLBFGSExample.java ---
    @@ -0,0 +1,104 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.examples.mllib;
    +
    +// $example on$
    +import java.util.Arrays;
    +
    +import scala.Tuple2;
    +
    +import org.apache.spark.api.java.*;
    +import org.apache.spark.api.java.function.Function;
    +import org.apache.spark.mllib.classification.LogisticRegressionModel;
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics;
    +import org.apache.spark.mllib.linalg.Vector;
    +import org.apache.spark.mllib.linalg.Vectors;
    +import org.apache.spark.mllib.optimization.*;
    +import org.apache.spark.mllib.regression.LabeledPoint;
    +import org.apache.spark.mllib.util.MLUtils;
    +import org.apache.spark.SparkConf;
    +import org.apache.spark.SparkContext;
    +
    --- End diff --
    
    Here should have a `$example off$`.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by mengxr <gi...@git.apache.org>.
Github user mengxr commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155592532
  
    Merged into master and branch-1.6. Thanks!


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44366165
  
    --- Diff: examples/src/main/java/org/apache/spark/examples/mllib/JavaLBFGSExample.java ---
    @@ -0,0 +1,104 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.examples.mllib;
    +
    +// $example on$
    +import java.util.Arrays;
    +
    +import scala.Tuple2;
    +
    +import org.apache.spark.api.java.*;
    +import org.apache.spark.api.java.function.Function;
    +import org.apache.spark.mllib.classification.LogisticRegressionModel;
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics;
    +import org.apache.spark.mllib.linalg.Vector;
    +import org.apache.spark.mllib.linalg.Vectors;
    +import org.apache.spark.mllib.optimization.*;
    +import org.apache.spark.mllib.regression.LabeledPoint;
    +import org.apache.spark.mllib.util.MLUtils;
    +import org.apache.spark.SparkConf;
    +import org.apache.spark.SparkContext;
    +
    +public class JavaLBFGSExample {
    +  public static void main(String[] args) {
    +    SparkConf conf = new SparkConf().setAppName("L-BFGS Example");
    +    SparkContext sc = new SparkContext(conf);
    --- End diff --
    
    Here should have a `$example on$`


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155531063
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44265565
  
    --- Diff: examples/src/main/scala/org/apache/spark/examples/mllib/LBFGSExample.scala ---
    @@ -0,0 +1,91 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +// scalastyle:off println
    +package org.apache.spark.examples.mllib
    +
    +// $example on$
    +import org.apache.spark.mllib.classification.LogisticRegressionModel
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics
    +import org.apache.spark.mllib.linalg.Vectors
    +import org.apache.spark.mllib.optimization.{LBFGS, LogisticGradient, SquaredL2Updater}
    +import org.apache.spark.mllib.util.MLUtils
    +// $example off$
    +
    +import org.apache.spark.{SparkConf, SparkContext}
    +
    +object LBFGSExample {
    +
    +  def main(args: Array[String]) {
    --- End diff --
    
    add `:Unit = ` as the return value


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by mengxr <gi...@git.apache.org>.
Github user mengxr commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155530826
  
    ok to test


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155581702
  
    **[Test build #45538 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/45538/consoleFull)** for PR 9516 at commit [`8f71ac6`](https://github.com/apache/spark/commit/8f71ac6793406113984cf5eff41b12d4142be5a7).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:\n  * `public class JavaLBFGSExample `\n


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/9516#discussion_r44265520
  
    --- Diff: examples/src/main/scala/org/apache/spark/examples/mllib/LBFGSExample.scala ---
    @@ -0,0 +1,91 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +// scalastyle:off println
    +package org.apache.spark.examples.mllib
    +
    +// $example on$
    +import org.apache.spark.mllib.classification.LogisticRegressionModel
    +import org.apache.spark.mllib.evaluation.BinaryClassificationMetrics
    +import org.apache.spark.mllib.linalg.Vectors
    +import org.apache.spark.mllib.optimization.{LBFGS, LogisticGradient, SquaredL2Updater}
    +import org.apache.spark.mllib.util.MLUtils
    +// $example off$
    +
    +import org.apache.spark.{SparkConf, SparkContext}
    +
    +object LBFGSExample {
    +
    +  def main(args: Array[String]) {
    +
    +    val conf = new SparkConf().setAppName("SimpleFPGrowth")
    --- End diff --
    
    rename the appname


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155534095
  
    **[Test build #45538 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/45538/consoleFull)** for PR 9516 at commit [`8f71ac6`](https://github.com/apache/spark/commit/8f71ac6793406113984cf5eff41b12d4142be5a7).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by yinxusen <gi...@git.apache.org>.
Github user yinxusen commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155307263
  
    @mengxr LGTM


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by pravingadakh <gi...@git.apache.org>.
Github user pravingadakh commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155299748
  
    @yinxusen I have added example on off labels at places you mentioned.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-154329143
  
    Can one of the admins verify this patch?


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request: [SPARK-11550][Docs] Replace example code in ml...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/9516#issuecomment-155582003
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/45538/
    Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org