org.apache.spark.api.java.StorageLevels.create(boolean, boolean, boolean, int) |
org.apache.spark.api.java.JavaSparkContext.defaultMinSplits()
|
org.apache.spark.streaming.api.java.JavaDStreamLike.foreach(Function)
As of release 0.9.0, replaced by foreachRDD
|
org.apache.spark.streaming.api.java.JavaDStreamLike.foreach(Function2)
As of release 0.9.0, replaced by foreachRDD
|
org.apache.spark.mllib.util.MLUtils.loadLabeledData(SparkContext, String)
|
org.apache.spark.streaming.api.java.JavaDStreamLike.reduceByWindow(Function2, Duration, Duration)
As this API is not Java compatible.
|
org.apache.spark.mllib.util.MLUtils.saveLabeledData(RDD, String)
|
org.apache.spark.mllib.optimization.LBFGS.setMaxNumIterations(int)
|
org.apache.spark.api.java.JavaRDDLike.toArray()
|
org.apache.spark.mllib.rdd.RDDFunctions.treeAggregate(U, Function2, Function2, int, ClassTag)
|
org.apache.spark.mllib.rdd.RDDFunctions.treeReduce(Function2, int)
|