You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by we...@apache.org on 2019/05/08 02:17:09 UTC

[spark-website] branch asf-site updated: website update for 2.4.3 (#200)

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

wenchen pushed a commit to branch asf-site
in repository https://gitbox.apache.org/repos/asf/spark-website.git


The following commit(s) were added to refs/heads/asf-site by this push:
     new f4abd91  website update for 2.4.3 (#200)
f4abd91 is described below

commit f4abd91f0c674ccb32e8043a77d4dac3457e6fe4
Author: Xiao Li <ga...@gmail.com>
AuthorDate: Tue May 7 19:17:04 2019 -0700

    website update for 2.4.3 (#200)
---
 site/docs/2.4.3/README.md                          |    87 +
 site/docs/2.4.3/api.html                           |   181 +
 site/docs/2.4.3/api/DESCRIPTION                    |    63 +
 site/docs/2.4.3/api/R/00Index.html                 |    23 +
 site/docs/2.4.3/api/R/00frame_toc.html             |    93 +
 site/docs/2.4.3/api/R/R.css                        |    55 +
 site/docs/2.4.3/api/R/index.html                   |     9 +
 site/docs/2.4.3/api/java/allclasses-frame.html     |  1322 +
 site/docs/2.4.3/api/java/allclasses-noframe.html   |  1322 +
 site/docs/2.4.3/api/java/constant-values.html      |   284 +
 site/docs/2.4.3/api/java/deprecated-list.html      |   858 +
 site/docs/2.4.3/api/java/help-doc.html             |   223 +
 site/docs/2.4.3/api/java/index-all.html            | 52796 +++++++++++++++++++
 site/docs/2.4.3/api/java/index.html                |    75 +
 site/docs/2.4.3/api/java/lib/api-javadocs.js       |    60 +
 site/docs/2.4.3/api/java/lib/jquery.js             |     2 +
 .../api/java/org/apache/spark/Accumulable.html     |   494 +
 .../java/org/apache/spark/AccumulableParam.html    |   319 +
 .../api/java/org/apache/spark/Accumulator.html     |   470 +
 .../AccumulatorParam.DoubleAccumulatorParam$.html  |   379 +
 .../AccumulatorParam.FloatAccumulatorParam$.html   |   379 +
 .../AccumulatorParam.IntAccumulatorParam$.html     |   379 +
 .../AccumulatorParam.LongAccumulatorParam$.html    |   379 +
 .../AccumulatorParam.StringAccumulatorParam$.html  |   398 +
 .../java/org/apache/spark/AccumulatorParam.html    |   322 +
 .../api/java/org/apache/spark/Aggregator.html      |   436 +
 .../java/org/apache/spark/BarrierTaskContext.html  |   670 +
 .../api/java/org/apache/spark/BarrierTaskInfo.html |   239 +
 .../api/java/org/apache/spark/CleanAccum.html      |   370 +
 .../api/java/org/apache/spark/CleanBroadcast.html  |   370 +
 .../api/java/org/apache/spark/CleanCheckpoint.html |   370 +
 .../2.4.3/api/java/org/apache/spark/CleanRDD.html  |   370 +
 .../api/java/org/apache/spark/CleanShuffle.html    |   370 +
 .../api/java/org/apache/spark/CleanupTask.html     |   170 +
 .../org/apache/spark/CleanupTaskWeakReference.html |   294 +
 .../java/org/apache/spark/ComplexFutureAction.html |   557 +
 .../java/org/apache/spark/ContextBarrierId.html    |   405 +
 .../api/java/org/apache/spark/Dependency.html      |   284 +
 .../java/org/apache/spark/ExceptionFailure.html    |   502 +
 .../java/org/apache/spark/ExecutorLostFailure.html |   451 +
 .../api/java/org/apache/spark/ExecutorPlugin.html  |   259 +
 .../java/org/apache/spark/ExecutorRegistered.html  |   370 +
 .../api/java/org/apache/spark/ExecutorRemoved.html |   370 +
 .../api/java/org/apache/spark/ExpireDeadHosts.html |   334 +
 .../api/java/org/apache/spark/FetchFailed.html     |   483 +
 .../api/java/org/apache/spark/FutureAction.html    |   487 +
 .../api/java/org/apache/spark/HashPartitioner.html |   350 +
 .../java/org/apache/spark/InternalAccumulator.html |   510 +
 .../apache/spark/InternalAccumulator.input$.html   |   325 +
 .../apache/spark/InternalAccumulator.output$.html  |   325 +
 .../spark/InternalAccumulator.shuffleRead$.html    |   390 +
 .../spark/InternalAccumulator.shuffleWrite$.html   |   338 +
 .../org/apache/spark/InterruptibleIterator.html    |   362 +
 .../java/org/apache/spark/JobExecutionStatus.html  |   376 +
 .../api/java/org/apache/spark/JobSubmitter.html    |   244 +
 .../java/org/apache/spark/NarrowDependency.html    |   315 +
 .../java/org/apache/spark/OneToOneDependency.html  |   308 +
 .../2.4.3/api/java/org/apache/spark/Partition.html |   266 +
 .../api/java/org/apache/spark/Partitioner.html     |   341 +
 .../api/java/org/apache/spark/RangeDependency.html |   318 +
 .../java/org/apache/spark/RangePartitioner.html    |   457 +
 .../api/java/org/apache/spark/Resubmitted.html     |   364 +
 .../org/apache/spark/SerializableWritable.html     |   310 +
 .../java/org/apache/spark/ShuffleDependency.html   |   405 +
 .../api/java/org/apache/spark/ShuffleStatus.html   |   527 +
 .../java/org/apache/spark/SimpleFutureAction.html  |   517 +
 .../2.4.3/api/java/org/apache/spark/SparkConf.html |  1339 +
 .../api/java/org/apache/spark/SparkContext.html    |  3102 ++
 .../2.4.3/api/java/org/apache/spark/SparkEnv.html  |   504 +
 .../api/java/org/apache/spark/SparkException.html  |   278 +
 .../java/org/apache/spark/SparkExecutorInfo.html   |   323 +
 .../org/apache/spark/SparkExecutorInfoImpl.html    |   415 +
 .../api/java/org/apache/spark/SparkFiles.html      |   299 +
 .../org/apache/spark/SparkFirehoseListener.html    |   601 +
 .../api/java/org/apache/spark/SparkJobInfo.html    |   258 +
 .../java/org/apache/spark/SparkJobInfoImpl.html    |   320 +
 .../java/org/apache/spark/SparkMasterRegex.html    |   309 +
 .../api/java/org/apache/spark/SparkStageInfo.html  |   323 +
 .../java/org/apache/spark/SparkStageInfoImpl.html  |   415 +
 .../java/org/apache/spark/SparkStatusTracker.html  |   373 +
 .../api/java/org/apache/spark/SpillListener.html   |   326 +
 .../org/apache/spark/StopMapOutputTracker.html     |   334 +
 .../2.4.3/api/java/org/apache/spark/Success.html   |   336 +
 .../java/org/apache/spark/TaskCommitDenied.html    |   448 +
 .../api/java/org/apache/spark/TaskContext.html     |   648 +
 .../api/java/org/apache/spark/TaskEndReason.html   |   177 +
 .../java/org/apache/spark/TaskFailedReason.html    |   257 +
 .../api/java/org/apache/spark/TaskKilled.html      |   437 +
 .../java/org/apache/spark/TaskKilledException.html |   313 +
 .../api/java/org/apache/spark/TaskResultLost.html  |   363 +
 .../java/org/apache/spark/TaskSchedulerIsSet.html  |   336 +
 .../2.4.3/api/java/org/apache/spark/TaskState.html |   425 +
 .../2.4.3/api/java/org/apache/spark/TestUtils.html |   572 +
 .../api/java/org/apache/spark/UnknownReason.html   |   363 +
 .../org/apache/spark/api/java/JavaDoubleRDD.html   |  2216 +
 .../apache/spark/api/java/JavaFutureAction.html    |   237 +
 .../org/apache/spark/api/java/JavaHadoopRDD.html   |   339 +
 .../apache/spark/api/java/JavaNewHadoopRDD.html    |   339 +
 .../org/apache/spark/api/java/JavaPairRDD.html     |  4020 ++
 .../java/org/apache/spark/api/java/JavaRDD.html    |  1957 +
 .../org/apache/spark/api/java/JavaRDDLike.html     |  2086 +
 .../apache/spark/api/java/JavaSparkContext.html    |  2398 +
 .../spark/api/java/JavaSparkStatusTracker.html     |   354 +
 .../api/java/JavaUtils.SerializableMapWrapper.html |   386 +
 .../java/org/apache/spark/api/java/JavaUtils.html  |   301 +
 .../java/org/apache/spark/api/java/Optional.html   |   514 +
 .../org/apache/spark/api/java/StorageLevels.html   |   468 +
 .../spark/api/java/function/CoGroupFunction.html   |   242 +
 .../api/java/function/DoubleFlatMapFunction.html   |   237 +
 .../spark/api/java/function/DoubleFunction.html    |   237 +
 .../spark/api/java/function/FilterFunction.html    |   239 +
 .../spark/api/java/function/FlatMapFunction.html   |   237 +
 .../spark/api/java/function/FlatMapFunction2.html  |   239 +
 .../api/java/function/FlatMapGroupsFunction.html   |   239 +
 .../function/FlatMapGroupsWithStateFunction.html   |   245 +
 .../spark/api/java/function/ForeachFunction.html   |   239 +
 .../java/function/ForeachPartitionFunction.html    |   235 +
 .../apache/spark/api/java/function/Function.html   |   239 +
 .../apache/spark/api/java/function/Function0.html  |   235 +
 .../apache/spark/api/java/function/Function2.html  |   239 +
 .../apache/spark/api/java/function/Function3.html  |   241 +
 .../apache/spark/api/java/function/Function4.html  |   243 +
 .../spark/api/java/function/MapFunction.html       |   237 +
 .../spark/api/java/function/MapGroupsFunction.html |   239 +
 .../java/function/MapGroupsWithStateFunction.html  |   244 +
 .../api/java/function/MapPartitionsFunction.html   |   235 +
 .../api/java/function/PairFlatMapFunction.html     |   238 +
 .../spark/api/java/function/PairFunction.html      |   238 +
 .../spark/api/java/function/ReduceFunction.html    |   239 +
 .../spark/api/java/function/VoidFunction.html      |   237 +
 .../spark/api/java/function/VoidFunction2.html     |   239 +
 .../spark/api/java/function/package-frame.html     |    43 +
 .../spark/api/java/function/package-summary.html   |   300 +
 .../spark/api/java/function/package-tree.html      |   158 +
 .../org/apache/spark/api/java/package-frame.html   |    35 +
 .../org/apache/spark/api/java/package-summary.html |   221 +
 .../org/apache/spark/api/java/package-tree.html    |   169 +
 .../api/java/org/apache/spark/api/r/BaseRRDD.html  |   359 +
 .../java/org/apache/spark/api/r/PairwiseRRDD.html  |   322 +
 .../apache/spark/api/r/RBackendAuthHandler.html    |   346 +
 .../api/java/org/apache/spark/api/r/RRDD.html      |  2216 +
 .../java/org/apache/spark/api/r/RRunnerModes.html  |   295 +
 .../api/java/org/apache/spark/api/r/RUtils.html    |   367 +
 .../api/java/org/apache/spark/api/r/SerDe.html     |   773 +
 .../apache/spark/api/r/SerializationFormats.html   |   295 +
 .../org/apache/spark/api/r/SparkRDefaults.html     |   295 +
 .../org/apache/spark/api/r/SpecialLengths.html     |   269 +
 .../java/org/apache/spark/api/r/StringRRDD.html    |   319 +
 .../java/org/apache/spark/api/r/package-frame.html |    30 +
 .../org/apache/spark/api/r/package-summary.html    |   190 +
 .../java/org/apache/spark/api/r/package-tree.html  |   164 +
 .../java/org/apache/spark/broadcast/Broadcast.html |   406 +
 .../org/apache/spark/broadcast/package-frame.html  |    20 +
 .../apache/spark/broadcast/package-summary.html    |   151 +
 .../org/apache/spark/broadcast/package-tree.html   |   135 +
 .../api/java/org/apache/spark/graphx/Edge.html     |   466 +
 .../java/org/apache/spark/graphx/EdgeContext.html  |   423 +
 .../org/apache/spark/graphx/EdgeDirection.html     |   368 +
 .../api/java/org/apache/spark/graphx/EdgeRDD.html  |  2222 +
 .../java/org/apache/spark/graphx/EdgeTriplet.html  |   413 +
 .../api/java/org/apache/spark/graphx/Graph.html    |  1207 +
 .../java/org/apache/spark/graphx/GraphLoader.html  |   314 +
 .../api/java/org/apache/spark/graphx/GraphOps.html |   978 +
 .../java/org/apache/spark/graphx/GraphXUtils.html  |   276 +
 ...artitionStrategy.CanonicalRandomVertexCut$.html |   365 +
 .../graphx/PartitionStrategy.EdgePartition1D$.html |   364 +
 .../graphx/PartitionStrategy.EdgePartition2D$.html |   401 +
 .../graphx/PartitionStrategy.RandomVertexCut$.html |   364 +
 .../org/apache/spark/graphx/PartitionStrategy.html |   281 +
 .../api/java/org/apache/spark/graphx/Pregel.html   |   379 +
 .../org/apache/spark/graphx/TripletFields.html     |   416 +
 .../java/org/apache/spark/graphx/VertexRDD.html    |  2680 +
 .../spark/graphx/impl/AggregatingEdgeContext.html  |   490 +
 .../apache/spark/graphx/impl/EdgeActiveness.html   |   391 +
 .../org/apache/spark/graphx/impl/EdgeRDDImpl.html  |  2240 +
 .../org/apache/spark/graphx/impl/GraphImpl.html    |  1205 +
 .../apache/spark/graphx/impl/VertexRDDImpl.html    |  2570 +
 .../apache/spark/graphx/impl/package-frame.html    |    27 +
 .../apache/spark/graphx/impl/package-summary.html  |   171 +
 .../org/apache/spark/graphx/impl/package-tree.html |   170 +
 .../spark/graphx/lib/ConnectedComponents.html      |   324 +
 .../apache/spark/graphx/lib/LabelPropagation.html  |   296 +
 .../java/org/apache/spark/graphx/lib/PageRank.html |   505 +
 .../apache/spark/graphx/lib/SVDPlusPlus.Conf.html  |   388 +
 .../org/apache/spark/graphx/lib/SVDPlusPlus.html   |   315 +
 .../org/apache/spark/graphx/lib/ShortestPaths.html |   290 +
 .../graphx/lib/StronglyConnectedComponents.html    |   292 +
 .../org/apache/spark/graphx/lib/TriangleCount.html |   316 +
 .../org/apache/spark/graphx/lib/package-frame.html |    27 +
 .../apache/spark/graphx/lib/package-summary.html   |   194 +
 .../org/apache/spark/graphx/lib/package-tree.html  |   142 +
 .../org/apache/spark/graphx/package-frame.html     |    39 +
 .../org/apache/spark/graphx/package-summary.html   |   269 +
 .../java/org/apache/spark/graphx/package-tree.html |   169 +
 .../apache/spark/graphx/util/BytecodeUtils.html    |   286 +
 .../apache/spark/graphx/util/GraphGenerators.html  |   469 +
 .../apache/spark/graphx/util/package-frame.html    |    21 +
 .../apache/spark/graphx/util/package-summary.html  |   158 +
 .../org/apache/spark/graphx/util/package-tree.html |   136 +
 .../org/apache/spark/input/PortableDataStream.html |   340 +
 .../java/org/apache/spark/input/package-frame.html |    20 +
 .../org/apache/spark/input/package-summary.html    |   143 +
 .../java/org/apache/spark/input/package-tree.html  |   135 +
 .../java/org/apache/spark/internal/Logging.html    |   448 +
 .../internal/config/ConfigEntryWithDefault.html    |   443 +
 .../config/ConfigEntryWithDefaultFunction.html     |   441 +
 .../config/ConfigEntryWithDefaultString.html       |   441 +
 .../spark/internal/config/ConfigHelpers.html       |   395 +
 .../spark/internal/config/package-frame.html       |    23 +
 .../spark/internal/config/package-summary.html     |   152 +
 .../apache/spark/internal/config/package-tree.html |   138 +
 ...FileCommitProtocol.EmptyTaskCommitMessage$.html |   298 +
 .../io/FileCommitProtocol.TaskCommitMessage.html   |   286 +
 .../spark/internal/io/FileCommitProtocol.html      |   593 +
 .../internal/io/HadoopMapRedCommitProtocol.html    |   329 +
 .../internal/io/HadoopMapReduceCommitProtocol.html |   588 +
 .../spark/internal/io/HadoopWriteConfigUtil.html   |   391 +
 .../spark/internal/io/SparkHadoopWriter.html       |   292 +
 .../spark/internal/io/SparkHadoopWriterUtils.html  |   366 +
 .../apache/spark/internal/io/package-frame.html    |    27 +
 .../apache/spark/internal/io/package-summary.html  |   184 +
 .../org/apache/spark/internal/io/package-tree.html |   151 +
 .../org/apache/spark/internal/package-frame.html   |    20 +
 .../org/apache/spark/internal/package-summary.html |   142 +
 .../org/apache/spark/internal/package-tree.html    |   131 +
 .../java/org/apache/spark/io/CompressionCodec.html |   245 +
 .../org/apache/spark/io/LZ4CompressionCodec.html   |   305 +
 .../org/apache/spark/io/LZFCompressionCodec.html   |   304 +
 .../spark/io/NioBufferedFileInputStream.html       |   410 +
 .../org/apache/spark/io/ReadAheadInputStream.html  |   399 +
 .../apache/spark/io/SnappyCompressionCodec.html    |   318 +
 .../apache/spark/io/SnappyOutputStreamWrapper.html |   363 +
 .../org/apache/spark/io/ZStdCompressionCodec.html  |   305 +
 .../java/org/apache/spark/io/package-frame.html    |    30 +
 .../java/org/apache/spark/io/package-summary.html  |   214 +
 .../api/java/org/apache/spark/io/package-tree.html |   153 +
 .../apache/spark/launcher/AbstractLauncher.html    |   600 +
 .../apache/spark/launcher/InProcessLauncher.html   |   313 +
 .../spark/launcher/SparkAppHandle.Listener.html    |   258 +
 .../spark/launcher/SparkAppHandle.State.html       |   463 +
 .../org/apache/spark/launcher/SparkAppHandle.html  |   347 +
 .../org/apache/spark/launcher/SparkLauncher.html   |  1253 +
 .../org/apache/spark/launcher/package-frame.html   |    31 +
 .../org/apache/spark/launcher/package-summary.html |   275 +
 .../org/apache/spark/launcher/package-tree.html    |   157 +
 .../apache/spark/mapred/SparkHadoopMapRedUtil.html |   291 +
 .../org/apache/spark/mapred/package-frame.html     |    20 +
 .../org/apache/spark/mapred/package-summary.html   |   140 +
 .../java/org/apache/spark/mapred/package-tree.html |   135 +
 .../spark/metrics/sink/StatsdMetricType.html       |   313 +
 .../apache/spark/metrics/sink/package-frame.html   |    20 +
 .../apache/spark/metrics/sink/package-summary.html |   140 +
 .../apache/spark/metrics/sink/package-tree.html    |   135 +
 .../spark/metrics/source/CodegenMetrics.html       |   364 +
 .../spark/metrics/source/HiveCatalogMetrics.html   |   465 +
 .../apache/spark/metrics/source/StaticSources.html |   277 +
 .../apache/spark/metrics/source/package-frame.html |    22 +
 .../spark/metrics/source/package-summary.html      |   154 +
 .../apache/spark/metrics/source/package-tree.html  |   137 +
 .../api/java/org/apache/spark/ml/Estimator.html    |   470 +
 .../2.4.3/api/java/org/apache/spark/ml/Model.html  |   409 +
 .../apache/spark/ml/Pipeline.SharedReadWrite$.html |   399 +
 .../api/java/org/apache/spark/ml/Pipeline.html     |   794 +
 .../java/org/apache/spark/ml/PipelineModel.html    |   744 +
 .../java/org/apache/spark/ml/PipelineStage.html    |   350 +
 .../java/org/apache/spark/ml/PredictionModel.html  |   507 +
 .../api/java/org/apache/spark/ml/Predictor.html    |   499 +
 .../api/java/org/apache/spark/ml/Transformer.html  |   435 +
 .../java/org/apache/spark/ml/UnaryTransformer.html |   438 +
 .../java/org/apache/spark/ml/ann/ApplyInPlace.html |   293 +
 .../java/org/apache/spark/ml/ann/BreezeUtil.html   |   321 +
 .../org/apache/spark/ml/ann/package-frame.html     |    21 +
 .../org/apache/spark/ml/ann/package-summary.html   |   148 +
 .../java/org/apache/spark/ml/ann/package-tree.html |   136 +
 .../org/apache/spark/ml/attribute/Attribute.html   |   514 +
 .../apache/spark/ml/attribute/AttributeGroup.html  |   620 +
 .../apache/spark/ml/attribute/AttributeKeys.html   |   426 +
 .../apache/spark/ml/attribute/AttributeType.html   |   358 +
 .../apache/spark/ml/attribute/BinaryAttribute.html |   609 +
 .../spark/ml/attribute/NominalAttribute.html       |   796 +
 .../spark/ml/attribute/NumericAttribute.html       |   754 +
 .../spark/ml/attribute/UnresolvedAttribute.html    |   440 +
 .../apache/spark/ml/attribute/package-frame.html   |    27 +
 .../apache/spark/ml/attribute/package-summary.html |   219 +
 .../apache/spark/ml/attribute/package-tree.html    |   145 +
 .../BinaryLogisticRegressionSummary.html           |   411 +
 .../BinaryLogisticRegressionSummaryImpl.html       |   291 +
 .../BinaryLogisticRegressionTrainingSummary.html   |   213 +
 ...inaryLogisticRegressionTrainingSummaryImpl.html |   344 +
 .../ml/classification/ClassificationModel.html     |   505 +
 .../apache/spark/ml/classification/Classifier.html |   417 +
 .../DecisionTreeClassificationModel.html           |  1584 +
 .../ml/classification/DecisionTreeClassifier.html  |  1471 +
 .../ml/classification/GBTClassificationModel.html  |  1924 +
 .../spark/ml/classification/GBTClassifier.html     |  1754 +
 .../apache/spark/ml/classification/LinearSVC.html  |  1476 +
 .../spark/ml/classification/LinearSVCModel.html    |  1404 +
 .../ml/classification/LogisticRegression.html      |  2150 +
 .../ml/classification/LogisticRegressionModel.html |  2046 +
 .../classification/LogisticRegressionSummary.html  |   591 +
 .../LogisticRegressionSummaryImpl.html             |   400 +
 .../LogisticRegressionTrainingSummary.html         |   262 +
 .../LogisticRegressionTrainingSummaryImpl.html     |   332 +
 .../MultilayerPerceptronClassificationModel.html   |  1185 +
 .../MultilayerPerceptronClassifier.html            |  1655 +
 .../apache/spark/ml/classification/NaiveBayes.html |  1322 +
 .../spark/ml/classification/NaiveBayesModel.html   |  1324 +
 .../apache/spark/ml/classification/OneVsRest.html  |  1081 +
 .../spark/ml/classification/OneVsRestModel.html    |  1040 +
 .../ProbabilisticClassificationModel.html          |  1066 +
 .../ml/classification/ProbabilisticClassifier.html |   455 +
 .../RandomForestClassificationModel.html           |  1694 +
 .../ml/classification/RandomForestClassifier.html  |  1604 +
 .../spark/ml/classification/package-frame.html     |    50 +
 .../spark/ml/classification/package-summary.html   |   327 +
 .../spark/ml/classification/package-tree.html      |   225 +
 .../spark/ml/clustering/BisectingKMeans.html       |  1107 +
 .../spark/ml/clustering/BisectingKMeansModel.html  |  1145 +
 .../ml/clustering/BisectingKMeansSummary.html      |   223 +
 .../apache/spark/ml/clustering/ClusterData.html    |   386 +
 .../spark/ml/clustering/ClusteringSummary.html     |   348 +
 .../spark/ml/clustering/DistributedLDAModel.html   |  1959 +
 .../spark/ml/clustering/ExpectationAggregator.html |   393 +
 .../spark/ml/clustering/GaussianMixture.html       |  1087 +
 .../spark/ml/clustering/GaussianMixtureModel.html  |  1156 +
 .../ml/clustering/GaussianMixtureSummary.html      |   299 +
 .../ml/clustering/InternalKMeansModelWriter.html   |   370 +
 .../org/apache/spark/ml/clustering/KMeans.html     |  1218 +
 .../apache/spark/ml/clustering/KMeansModel.html    |  1249 +
 .../apache/spark/ml/clustering/KMeansSummary.html  |   265 +
 .../java/org/apache/spark/ml/clustering/LDA.html   |  1862 +
 .../org/apache/spark/ml/clustering/LDAModel.html   |  1156 +
 .../apache/spark/ml/clustering/LocalLDAModel.html  |  1826 +
 .../spark/ml/clustering/PMMLKMeansModelWriter.html |   370 +
 .../ml/clustering/PowerIterationClustering.html    |  1023 +
 .../apache/spark/ml/clustering/package-frame.html  |    38 +
 .../spark/ml/clustering/package-summary.html       |   258 +
 .../apache/spark/ml/clustering/package-tree.html   |   175 +
 .../evaluation/BinaryClassificationEvaluator.html  |   820 +
 .../spark/ml/evaluation/ClusteringEvaluator.html   |   874 +
 .../spark/ml/evaluation/CosineSilhouette.html      |   452 +
 .../org/apache/spark/ml/evaluation/Evaluator.html  |   386 +
 .../MulticlassClassificationEvaluator.html         |   820 +
 .../spark/ml/evaluation/RegressionEvaluator.html   |   823 +
 .../SquaredEuclideanSilhouette.ClusterStats$.html  |   306 +
 .../SquaredEuclideanSilhouette.ClusterStats.html   |   326 +
 .../ml/evaluation/SquaredEuclideanSilhouette.html  |   580 +
 .../apache/spark/ml/evaluation/package-frame.html  |    28 +
 .../spark/ml/evaluation/package-summary.html       |   193 +
 .../apache/spark/ml/evaluation/package-tree.html   |   150 +
 .../org/apache/spark/ml/feature/Binarizer.html     |   838 +
 .../ml/feature/BucketedRandomProjectionLSH.html    |  1100 +
 .../feature/BucketedRandomProjectionLSHModel.html  |  1258 +
 .../org/apache/spark/ml/feature/Bucketizer.html    |  1112 +
 .../org/apache/spark/ml/feature/ChiSqSelector.html |  1294 +
 .../spark/ml/feature/ChiSqSelectorModel.html       |  1239 +
 .../org/apache/spark/ml/feature/ColumnPruner.html  |   729 +
 .../apache/spark/ml/feature/CountVectorizer.html   |  1196 +
 .../spark/ml/feature/CountVectorizerModel.html     |  1253 +
 .../api/java/org/apache/spark/ml/feature/DCT.html  |   854 +
 .../api/java/org/apache/spark/ml/feature/Dot.html  |   334 +
 .../spark/ml/feature/ElementwiseProduct.html       |   849 +
 .../org/apache/spark/ml/feature/FeatureHasher.html |   942 +
 .../org/apache/spark/ml/feature/HashingTF.html     |   890 +
 .../api/java/org/apache/spark/ml/feature/IDF.html  |   884 +
 .../java/org/apache/spark/ml/feature/IDFModel.html |   921 +
 .../java/org/apache/spark/ml/feature/Imputer.html  |   973 +
 .../org/apache/spark/ml/feature/ImputerModel.html  |   981 +
 .../org/apache/spark/ml/feature/IndexToString.html |   842 +
 .../org/apache/spark/ml/feature/Interaction.html   |   796 +
 .../org/apache/spark/ml/feature/LabeledPoint.html  |   406 +
 .../org/apache/spark/ml/feature/MaxAbsScaler.html  |   807 +
 .../apache/spark/ml/feature/MaxAbsScalerModel.html |   853 +
 .../org/apache/spark/ml/feature/MinHashLSH.html    |  1020 +
 .../apache/spark/ml/feature/MinHashLSHModel.html   |  1196 +
 .../org/apache/spark/ml/feature/MinMaxScaler.html  |   967 +
 .../apache/spark/ml/feature/MinMaxScalerModel.html |  1018 +
 .../java/org/apache/spark/ml/feature/NGram.html    |   855 +
 .../org/apache/spark/ml/feature/Normalizer.html    |   848 +
 .../org/apache/spark/ml/feature/OneHotEncoder.html |   948 +
 .../spark/ml/feature/OneHotEncoderCommon.html      |   343 +
 .../spark/ml/feature/OneHotEncoderEstimator.html   |   969 +
 .../spark/ml/feature/OneHotEncoderModel.html       |   999 +
 .../api/java/org/apache/spark/ml/feature/PCA.html  |   877 +
 .../java/org/apache/spark/ml/feature/PCAModel.html |   931 +
 .../spark/ml/feature/PolynomialExpansion.html      |   871 +
 .../spark/ml/feature/QuantileDiscretizer.html      |  1208 +
 .../java/org/apache/spark/ml/feature/RFormula.html |  1146 +
 .../org/apache/spark/ml/feature/RFormulaModel.html |  1074 +
 .../apache/spark/ml/feature/RFormulaParser.html    |   786 +
 .../apache/spark/ml/feature/RegexTokenizer.html    |  1008 +
 .../apache/spark/ml/feature/SQLTransformer.html    |   755 +
 .../apache/spark/ml/feature/StandardScaler.html    |   958 +
 .../spark/ml/feature/StandardScalerModel.html      |   989 +
 .../apache/spark/ml/feature/StopWordsRemover.html  |   966 +
 .../org/apache/spark/ml/feature/StringIndexer.html |   963 +
 .../spark/ml/feature/StringIndexerModel.html       |  1046 +
 .../org/apache/spark/ml/feature/Tokenizer.html     |   819 +
 .../apache/spark/ml/feature/VectorAssembler.html   |   852 +
 .../spark/ml/feature/VectorAttributeRewriter.html  |   752 +
 .../org/apache/spark/ml/feature/VectorIndexer.html |   971 +
 .../spark/ml/feature/VectorIndexerModel.html       |  1003 +
 .../apache/spark/ml/feature/VectorSizeHint.html    |   860 +
 .../org/apache/spark/ml/feature/VectorSlicer.html  |   894 +
 .../java/org/apache/spark/ml/feature/Word2Vec.html |  1319 +
 .../Word2VecModel.Word2VecModelWriter$.html        |   329 +
 .../org/apache/spark/ml/feature/Word2VecModel.html |  1401 +
 .../org/apache/spark/ml/feature/package-frame.html |    76 +
 .../apache/spark/ml/feature/package-summary.html   |   594 +
 .../org/apache/spark/ml/feature/package-tree.html  |   211 +
 .../org/apache/spark/ml/fpm/AssociationRules.html  |   295 +
 .../api/java/org/apache/spark/ml/fpm/FPGrowth.html |  1068 +
 .../org/apache/spark/ml/fpm/FPGrowthModel.html     |  1113 +
 .../java/org/apache/spark/ml/fpm/PrefixSpan.html   |   573 +
 .../org/apache/spark/ml/fpm/package-frame.html     |    23 +
 .../org/apache/spark/ml/fpm/package-summary.html   |   161 +
 .../java/org/apache/spark/ml/fpm/package-tree.html |   154 +
 .../org/apache/spark/ml/image/ImageSchema.html     |   585 +
 .../org/apache/spark/ml/image/RecursiveFlag.html   |   285 +
 .../apache/spark/ml/image/SamplePathFilter.html    |   421 +
 .../org/apache/spark/ml/image/package-frame.html   |    22 +
 .../org/apache/spark/ml/image/package-summary.html |   153 +
 .../org/apache/spark/ml/image/package-tree.html    |   141 +
 .../api/java/org/apache/spark/ml/impl/Utils.html   |   269 +
 .../org/apache/spark/ml/impl/package-frame.html    |    20 +
 .../org/apache/spark/ml/impl/package-summary.html  |   140 +
 .../org/apache/spark/ml/impl/package-tree.html     |   135 +
 .../api/java/org/apache/spark/ml/linalg/BLAS.html  |   534 +
 .../org/apache/spark/ml/linalg/DenseMatrix.html    |   962 +
 .../org/apache/spark/ml/linalg/DenseVector.html    |   594 +
 .../spark/ml/linalg/JsonMatrixConverter.html       |   316 +
 .../spark/ml/linalg/JsonVectorConverter.html       |   300 +
 .../java/org/apache/spark/ml/linalg/Matrices.html  |   604 +
 .../java/org/apache/spark/ml/linalg/Matrix.html    |   957 +
 .../org/apache/spark/ml/linalg/SQLDataTypes.html   |   290 +
 .../org/apache/spark/ml/linalg/SparseMatrix.html   |   993 +
 .../org/apache/spark/ml/linalg/SparseVector.html   |   600 +
 .../java/org/apache/spark/ml/linalg/Vector.html    |   539 +
 .../java/org/apache/spark/ml/linalg/Vectors.html   |   485 +
 .../org/apache/spark/ml/linalg/package-frame.html  |    34 +
 .../apache/spark/ml/linalg/package-summary.html    |   216 +
 .../org/apache/spark/ml/linalg/package-tree.html   |   157 +
 .../java/org/apache/spark/ml/package-frame.html    |    29 +
 .../java/org/apache/spark/ml/package-summary.html  |   215 +
 .../api/java/org/apache/spark/ml/package-tree.html |   156 +
 .../org/apache/spark/ml/param/BooleanParam.html    |   340 +
 .../spark/ml/param/DoubleArrayArrayParam.html      |   358 +
 .../apache/spark/ml/param/DoubleArrayParam.html    |   358 +
 .../org/apache/spark/ml/param/DoubleParam.html     |   512 +
 .../java/org/apache/spark/ml/param/FloatParam.html |   512 +
 .../org/apache/spark/ml/param/IntArrayParam.html   |   358 +
 .../java/org/apache/spark/ml/param/IntParam.html   |   376 +
 .../java/org/apache/spark/ml/param/JavaParams.html |   263 +
 .../java/org/apache/spark/ml/param/LongParam.html  |   376 +
 .../api/java/org/apache/spark/ml/param/Param.html  |   493 +
 .../java/org/apache/spark/ml/param/ParamMap.html   |   575 +
 .../java/org/apache/spark/ml/param/ParamPair.html  |   388 +
 .../org/apache/spark/ml/param/ParamValidators.html |   480 +
 .../api/java/org/apache/spark/ml/param/Params.html |   782 +
 .../apache/spark/ml/param/StringArrayParam.html    |   358 +
 .../org/apache/spark/ml/param/package-frame.html   |    37 +
 .../org/apache/spark/ml/param/package-summary.html |   250 +
 .../org/apache/spark/ml/param/package-tree.html    |   168 +
 .../spark/ml/param/shared/HasAggregationDepth.html |   260 +
 .../ml/param/shared/HasCheckpointInterval.html     |   260 +
 .../spark/ml/param/shared/HasCollectSubModels.html |   264 +
 .../spark/ml/param/shared/HasDistanceMeasure.html  |   260 +
 .../spark/ml/param/shared/HasElasticNetParam.html  |   260 +
 .../spark/ml/param/shared/HasFeaturesCol.html      |   264 +
 .../spark/ml/param/shared/HasFitIntercept.html     |   260 +
 .../spark/ml/param/shared/HasHandleInvalid.html    |   264 +
 .../apache/spark/ml/param/shared/HasInputCol.html  |   264 +
 .../apache/spark/ml/param/shared/HasInputCols.html |   264 +
 .../apache/spark/ml/param/shared/HasLabelCol.html  |   264 +
 .../org/apache/spark/ml/param/shared/HasLoss.html  |   260 +
 .../apache/spark/ml/param/shared/HasMaxIter.html   |   260 +
 .../apache/spark/ml/param/shared/HasOutputCol.html |   264 +
 .../spark/ml/param/shared/HasOutputCols.html       |   264 +
 .../spark/ml/param/shared/HasPredictionCol.html    |   264 +
 .../spark/ml/param/shared/HasProbabilityCol.html   |   260 +
 .../spark/ml/param/shared/HasRawPredictionCol.html |   264 +
 .../apache/spark/ml/param/shared/HasRegParam.html  |   260 +
 .../org/apache/spark/ml/param/shared/HasSeed.html  |   264 +
 .../apache/spark/ml/param/shared/HasSolver.html    |   260 +
 .../spark/ml/param/shared/HasStandardization.html  |   260 +
 .../apache/spark/ml/param/shared/HasStepSize.html  |   260 +
 .../apache/spark/ml/param/shared/HasThreshold.html |   260 +
 .../spark/ml/param/shared/HasThresholds.html       |   260 +
 .../org/apache/spark/ml/param/shared/HasTol.html   |   260 +
 .../ml/param/shared/HasValidationIndicatorCol.html |   260 +
 .../spark/ml/param/shared/HasVarianceCol.html      |   260 +
 .../apache/spark/ml/param/shared/HasWeightCol.html |   260 +
 .../spark/ml/param/shared/SharedParamsCodeGen.html |   273 +
 .../spark/ml/param/shared/package-frame.html       |    52 +
 .../spark/ml/param/shared/package-summary.html     |   327 +
 .../apache/spark/ml/param/shared/package-tree.html |   216 +
 .../java/org/apache/spark/ml/r/RWrapperUtils.html  |   311 +
 .../api/java/org/apache/spark/ml/r/RWrappers.html  |   297 +
 .../java/org/apache/spark/ml/r/package-frame.html  |    21 +
 .../org/apache/spark/ml/r/package-summary.html     |   146 +
 .../java/org/apache/spark/ml/r/package-tree.html   |   136 +
 .../spark/ml/recommendation/ALS.InBlock$.html      |   287 +
 .../spark/ml/recommendation/ALS.Rating$.html       |   287 +
 .../apache/spark/ml/recommendation/ALS.Rating.html |   330 +
 .../spark/ml/recommendation/ALS.RatingBlock$.html  |   287 +
 .../org/apache/spark/ml/recommendation/ALS.html    |  2032 +
 .../apache/spark/ml/recommendation/ALSModel.html   |  1172 +
 .../spark/ml/recommendation/package-frame.html     |    25 +
 .../spark/ml/recommendation/package-summary.html   |   167 +
 .../spark/ml/recommendation/package-tree.html      |   156 +
 .../apache/spark/ml/regression/AFTAggregator.html  |   439 +
 .../org/apache/spark/ml/regression/AFTCostFun.html |   337 +
 .../spark/ml/regression/AFTSurvivalRegression.html |  1329 +
 .../ml/regression/AFTSurvivalRegressionModel.html  |  1303 +
 .../ml/regression/DecisionTreeRegressionModel.html |  1405 +
 .../spark/ml/regression/DecisionTreeRegressor.html |  1330 +
 .../spark/ml/regression/GBTRegressionModel.html    |  1738 +
 .../apache/spark/ml/regression/GBTRegressor.html   |  1574 +
 .../GeneralizedLinearRegression.Binomial$.html     |   440 +
 .../GeneralizedLinearRegression.CLogLog$.html      |   368 +
 .../GeneralizedLinearRegression.Family$.html       |   334 +
 ...GeneralizedLinearRegression.FamilyAndLink$.html |   330 +
 .../GeneralizedLinearRegression.Gamma$.html        |   453 +
 .../GeneralizedLinearRegression.Gaussian$.html     |   453 +
 .../GeneralizedLinearRegression.Identity$.html     |   381 +
 .../GeneralizedLinearRegression.Inverse$.html      |   381 +
 .../GeneralizedLinearRegression.Link$.html         |   333 +
 .../GeneralizedLinearRegression.Log$.html          |   381 +
 .../GeneralizedLinearRegression.Logit$.html        |   368 +
 .../GeneralizedLinearRegression.Poisson$.html      |   453 +
 .../GeneralizedLinearRegression.Probit$.html       |   368 +
 .../GeneralizedLinearRegression.Sqrt$.html         |   381 +
 .../GeneralizedLinearRegression.Tweedie$.html      |   324 +
 .../ml/regression/GeneralizedLinearRegression.html |  1993 +
 .../GeneralizedLinearRegressionModel.html          |  1736 +
 .../GeneralizedLinearRegressionSummary.html        |   485 +
 ...GeneralizedLinearRegressionTrainingSummary.html |   370 +
 .../InternalLinearRegressionModelWriter.html       |   370 +
 .../spark/ml/regression/IsotonicRegression.html    |  1098 +
 .../ml/regression/IsotonicRegressionModel.html     |  1132 +
 .../spark/ml/regression/LinearRegression.html      |  1734 +
 .../spark/ml/regression/LinearRegressionModel.html |  1535 +
 .../ml/regression/LinearRegressionSummary.html     |   603 +
 .../LinearRegressionTrainingSummary.html           |   286 +
 .../PMMLLinearRegressionModelWriter.html           |   370 +
 .../ml/regression/RandomForestRegressionModel.html |  1512 +
 .../spark/ml/regression/RandomForestRegressor.html |  1424 +
 .../spark/ml/regression/RegressionModel.html       |   390 +
 .../apache/spark/ml/regression/package-frame.html  |    57 +
 .../spark/ml/regression/package-summary.html       |   358 +
 .../apache/spark/ml/regression/package-tree.html   |   205 +
 .../spark/ml/source/image/ImageDataSource.html     |   231 +
 .../spark/ml/source/image/package-frame.html       |    20 +
 .../spark/ml/source/image/package-summary.html     |   142 +
 .../apache/spark/ml/source/image/package-tree.html |   135 +
 .../spark/ml/source/libsvm/LibSVMDataSource.html   |   230 +
 .../spark/ml/source/libsvm/package-frame.html      |    20 +
 .../spark/ml/source/libsvm/package-summary.html    |   142 +
 .../spark/ml/source/libsvm/package-tree.html       |   135 +
 .../org/apache/spark/ml/stat/ChiSquareTest.html    |   301 +
 .../java/org/apache/spark/ml/stat/Correlation.html |   338 +
 .../spark/ml/stat/KolmogorovSmirnovTest.html       |   360 +
 .../java/org/apache/spark/ml/stat/Summarizer.html  |   581 +
 .../org/apache/spark/ml/stat/SummaryBuilder.html   |   299 +
 .../ml/stat/distribution/MultivariateGaussian.html |   345 +
 .../spark/ml/stat/distribution/package-frame.html  |    20 +
 .../ml/stat/distribution/package-summary.html      |   142 +
 .../spark/ml/stat/distribution/package-tree.html   |   135 +
 .../org/apache/spark/ml/stat/package-frame.html    |    24 +
 .../org/apache/spark/ml/stat/package-summary.html  |   166 +
 .../org/apache/spark/ml/stat/package-tree.html     |   139 +
 .../org/apache/spark/ml/tree/CategoricalSplit.html |   336 +
 .../org/apache/spark/ml/tree/ContinuousSplit.html  |   303 +
 .../tree/DecisionTreeModelReadWrite.NodeData$.html |   336 +
 .../tree/DecisionTreeModelReadWrite.NodeData.html  |   409 +
 .../DecisionTreeModelReadWrite.SplitData$.html     |   321 +
 .../tree/DecisionTreeModelReadWrite.SplitData.html |   346 +
 .../spark/ml/tree/DecisionTreeModelReadWrite.html  |   345 +
 .../EnsembleModelReadWrite.EnsembleNodeData$.html  |   334 +
 .../EnsembleModelReadWrite.EnsembleNodeData.html   |   315 +
 .../spark/ml/tree/EnsembleModelReadWrite.html      |   348 +
 .../org/apache/spark/ml/tree/InternalNode.html     |   374 +
 .../java/org/apache/spark/ml/tree/LeafNode.html    |   304 +
 .../api/java/org/apache/spark/ml/tree/Node.html    |   327 +
 .../api/java/org/apache/spark/ml/tree/Split.html   |   296 +
 .../spark/ml/tree/impl/GradientBoostedTrees.html   |   537 +
 .../apache/spark/ml/tree/impl/RandomForest.html    |   339 +
 .../apache/spark/ml/tree/impl/package-frame.html   |    21 +
 .../apache/spark/ml/tree/impl/package-summary.html |   146 +
 .../apache/spark/ml/tree/impl/package-tree.html    |   136 +
 .../org/apache/spark/ml/tree/package-frame.html    |    36 +
 .../org/apache/spark/ml/tree/package-summary.html  |   224 +
 .../org/apache/spark/ml/tree/package-tree.html     |   162 +
 .../org/apache/spark/ml/tuning/CrossValidator.html |  1202 +
 ...ssValidatorModel.CrossValidatorModelWriter.html |   327 +
 .../spark/ml/tuning/CrossValidatorModel.html       |  1126 +
 .../apache/spark/ml/tuning/ParamGridBuilder.html   |   490 +
 .../spark/ml/tuning/TrainValidationSplit.html      |  1201 +
 ...SplitModel.TrainValidationSplitModelWriter.html |   327 +
 .../spark/ml/tuning/TrainValidationSplitModel.html |  1123 +
 .../org/apache/spark/ml/tuning/package-frame.html  |    26 +
 .../apache/spark/ml/tuning/package-summary.html    |   182 +
 .../org/apache/spark/ml/tuning/package-tree.html   |   161 +
 .../org/apache/spark/ml/util/DatasetUtils.html     |   303 +
 .../spark/ml/util/DefaultParamsReadable.html       |   257 +
 .../spark/ml/util/DefaultParamsWritable.html       |   257 +
 .../apache/spark/ml/util/GeneralMLWritable.html    |   245 +
 .../org/apache/spark/ml/util/GeneralMLWriter.html  |   422 +
 .../org/apache/spark/ml/util/Identifiable.html     |   257 +
 .../org/apache/spark/ml/util/MLFormatRegister.html |   310 +
 .../java/org/apache/spark/ml/util/MLReadable.html  |   261 +
 .../java/org/apache/spark/ml/util/MLReader.html    |   398 +
 .../java/org/apache/spark/ml/util/MLWritable.html  |   258 +
 .../java/org/apache/spark/ml/util/MLWriter.html    |   456 +
 .../org/apache/spark/ml/util/MLWriterFormat.html   |   254 +
 .../spark/ml/util/MetaAlgorithmReadWrite.html      |   281 +
 .../org/apache/spark/ml/util/MetadataUtils.html    |   334 +
 .../java/org/apache/spark/ml/util/SchemaUtils.html |   423 +
 .../org/apache/spark/ml/util/package-frame.html    |    37 +
 .../org/apache/spark/ml/util/package-summary.html  |   236 +
 .../org/apache/spark/ml/util/package-tree.html     |   164 +
 .../java/org/apache/spark/mllib/JavaPackage.html   |   202 +
 .../mllib/classification/ClassificationModel.html  |   285 +
 .../classification/LogisticRegressionModel.html    |   622 +
 .../LogisticRegressionWithLBFGS.html               |   417 +
 .../classification/LogisticRegressionWithSGD.html  |   548 +
 .../spark/mllib/classification/NaiveBayes.html     |   487 +
 .../NaiveBayesModel.SaveLoadV1_0$.Data$.html       |   306 +
 .../NaiveBayesModel.SaveLoadV1_0$.Data.html        |   405 +
 .../NaiveBayesModel.SaveLoadV1_0$.html             |   385 +
 .../NaiveBayesModel.SaveLoadV2_0$.Data$.html       |   306 +
 .../NaiveBayesModel.SaveLoadV2_0$.Data.html        |   420 +
 .../NaiveBayesModel.SaveLoadV2_0$.html             |   385 +
 .../mllib/classification/NaiveBayesModel.html      |   469 +
 .../spark/mllib/classification/SVMModel.html       |   560 +
 .../spark/mllib/classification/SVMWithSGD.html     |   551 +
 .../StreamingLogisticRegressionWithSGD.html        |   390 +
 ...GLMClassificationModel.SaveLoadV1_0$.Data$.html |   306 +
 .../GLMClassificationModel.SaveLoadV1_0$.Data.html |   405 +
 .../impl/GLMClassificationModel.SaveLoadV1_0$.html |   409 +
 .../impl/GLMClassificationModel.html               |   255 +
 .../mllib/classification/impl/package-frame.html   |    21 +
 .../mllib/classification/impl/package-summary.html |   146 +
 .../mllib/classification/impl/package-tree.html    |   142 +
 .../spark/mllib/classification/package-frame.html  |    33 +
 .../mllib/classification/package-summary.html      |   212 +
 .../spark/mllib/classification/package-tree.html   |   180 +
 .../spark/mllib/clustering/BisectingKMeans.html    |   553 +
 .../BisectingKMeansModel.SaveLoadV1_0$.html        |   331 +
 .../BisectingKMeansModel.SaveLoadV2_0$.html        |   331 +
 .../mllib/clustering/BisectingKMeansModel.html     |   536 +
 .../mllib/clustering/DistributedLDAModel.html      |   664 +
 .../spark/mllib/clustering/EMLDAOptimizer.html     |   324 +
 .../spark/mllib/clustering/ExpectationSum.html     |   370 +
 .../spark/mllib/clustering/GaussianMixture.html    |   578 +
 .../mllib/clustering/GaussianMixtureModel.html     |   482 +
 .../org/apache/spark/mllib/clustering/KMeans.html  |   928 +
 .../clustering/KMeansModel.SaveLoadV1_0$.html      |   331 +
 .../clustering/KMeansModel.SaveLoadV2_0$.html      |   331 +
 .../apache/spark/mllib/clustering/KMeansModel.html |   589 +
 .../org/apache/spark/mllib/clustering/LDA.html     |   893 +
 .../apache/spark/mllib/clustering/LDAModel.html    |   398 +
 .../spark/mllib/clustering/LDAOptimizer.html       |   266 +
 .../apache/spark/mllib/clustering/LDAUtils.html    |   236 +
 .../apache/spark/mllib/clustering/LocalKMeans.html |   293 +
 .../spark/mllib/clustering/LocalLDAModel.html      |   672 +
 .../spark/mllib/clustering/OnlineLDAOptimizer.html |   463 +
 .../PowerIterationClustering.Assignment$.html      |   306 +
 .../PowerIterationClustering.Assignment.html       |   314 +
 .../mllib/clustering/PowerIterationClustering.html |   455 +
 ...owerIterationClusteringModel.SaveLoadV1_0$.html |   331 +
 .../clustering/PowerIterationClusteringModel.html  |   365 +
 .../spark/mllib/clustering/StreamingKMeans.html    |   650 +
 .../mllib/clustering/StreamingKMeansModel.html     |   401 +
 .../spark/mllib/clustering/package-frame.html      |    49 +
 .../spark/mllib/clustering/package-summary.html    |   306 +
 .../spark/mllib/clustering/package-tree.html       |   174 +
 .../spark/mllib/evaluation/AreaUnderCurve.html     |   303 +
 .../evaluation/BinaryClassificationMetrics.html    |   544 +
 .../spark/mllib/evaluation/MulticlassMetrics.html  |   663 +
 .../spark/mllib/evaluation/MultilabelMetrics.html  |   533 +
 .../spark/mllib/evaluation/RankingMetrics.html     |   391 +
 .../spark/mllib/evaluation/RegressionMetrics.html  |   403 +
 .../mllib/evaluation/binary/FalsePositiveRate.html |   270 +
 .../spark/mllib/evaluation/binary/Precision.html   |   270 +
 .../spark/mllib/evaluation/binary/Recall.html      |   270 +
 .../mllib/evaluation/binary/package-frame.html     |    22 +
 .../mllib/evaluation/binary/package-summary.html   |   154 +
 .../mllib/evaluation/binary/package-tree.html      |   137 +
 .../spark/mllib/evaluation/package-frame.html      |    25 +
 .../spark/mllib/evaluation/package-summary.html    |   172 +
 .../spark/mllib/evaluation/package-tree.html       |   140 +
 .../apache/spark/mllib/feature/ChiSqSelector.html  |   495 +
 .../ChiSqSelectorModel.SaveLoadV1_0$.Data$.html    |   306 +
 .../ChiSqSelectorModel.SaveLoadV1_0$.Data.html     |   375 +
 .../feature/ChiSqSelectorModel.SaveLoadV1_0$.html  |   356 +
 .../spark/mllib/feature/ChiSqSelectorModel.html    |   381 +
 .../spark/mllib/feature/ElementwiseProduct.html    |   314 +
 .../org/apache/spark/mllib/feature/HashingTF.html  |   450 +
 .../feature/IDF.DocumentFrequencyAggregator.html   |   343 +
 .../java/org/apache/spark/mllib/feature/IDF.html   |   356 +
 .../org/apache/spark/mllib/feature/IDFModel.html   |   317 +
 .../org/apache/spark/mllib/feature/Normalizer.html |   317 +
 .../java/org/apache/spark/mllib/feature/PCA.html   |   317 +
 .../org/apache/spark/mllib/feature/PCAModel.html   |   307 +
 .../org/apache/spark/mllib/feature/PCAUtil.html    |   271 +
 .../apache/spark/mllib/feature/StandardScaler.html |   315 +
 .../spark/mllib/feature/StandardScalerModel.html   |   437 +
 .../spark/mllib/feature/VectorTransformer.html     |   286 +
 .../org/apache/spark/mllib/feature/VocabWord.html  |   431 +
 .../org/apache/spark/mllib/feature/Word2Vec.html   |   514 +
 .../apache/spark/mllib/feature/Word2VecModel.html  |   416 +
 .../apache/spark/mllib/feature/package-frame.html  |    40 +
 .../spark/mllib/feature/package-summary.html       |   259 +
 .../apache/spark/mllib/feature/package-tree.html   |   169 +
 .../spark/mllib/fpm/AssociationRules.Rule.html     |   371 +
 .../apache/spark/mllib/fpm/AssociationRules.html   |   398 +
 .../spark/mllib/fpm/FPGrowth.FreqItemset.html      |   343 +
 .../java/org/apache/spark/mllib/fpm/FPGrowth.html  |   407 +
 .../mllib/fpm/FPGrowthModel.SaveLoadV1_0$.html     |   348 +
 .../org/apache/spark/mllib/fpm/FPGrowthModel.html  |   405 +
 .../spark/mllib/fpm/PrefixSpan.FreqSequence.html   |   324 +
 .../spark/mllib/fpm/PrefixSpan.Postfix$.html       |   287 +
 .../apache/spark/mllib/fpm/PrefixSpan.Prefix$.html |   324 +
 .../org/apache/spark/mllib/fpm/PrefixSpan.html     |   499 +
 .../mllib/fpm/PrefixSpanModel.SaveLoadV1_0$.html   |   348 +
 .../apache/spark/mllib/fpm/PrefixSpanModel.html    |   352 +
 .../org/apache/spark/mllib/fpm/package-frame.html  |    31 +
 .../apache/spark/mllib/fpm/package-summary.html    |   201 +
 .../org/apache/spark/mllib/fpm/package-tree.html   |   146 +
 .../java/org/apache/spark/mllib/linalg/BLAS.html   |   498 +
 .../spark/mllib/linalg/CholeskyDecomposition.html  |   311 +
 .../org/apache/spark/mllib/linalg/DenseMatrix.html |   885 +
 .../org/apache/spark/mllib/linalg/DenseVector.html |   664 +
 .../mllib/linalg/EigenValueDecomposition.html      |   300 +
 .../org/apache/spark/mllib/linalg/Matrices.html    |   626 +
 .../java/org/apache/spark/mllib/linalg/Matrix.html |   667 +
 .../apache/spark/mllib/linalg/MatrixImplicits.html |   336 +
 .../apache/spark/mllib/linalg/QRDecomposition.html |   388 +
 .../mllib/linalg/SingularValueDecomposition.html   |   403 +
 .../apache/spark/mllib/linalg/SparseMatrix.html    |   916 +
 .../apache/spark/mllib/linalg/SparseVector.html    |   670 +
 .../java/org/apache/spark/mllib/linalg/Vector.html |   583 +
 .../apache/spark/mllib/linalg/VectorImplicits.html |   336 +
 .../org/apache/spark/mllib/linalg/VectorUDT.html   |   369 +
 .../org/apache/spark/mllib/linalg/Vectors.html     |   551 +
 .../mllib/linalg/distributed/BlockMatrix.html      |   674 +
 .../mllib/linalg/distributed/CoordinateMatrix.html |   444 +
 .../linalg/distributed/DistributedMatrix.html      |   264 +
 .../spark/mllib/linalg/distributed/IndexedRow.html |   386 +
 .../mllib/linalg/distributed/IndexedRowMatrix.html |   552 +
 .../mllib/linalg/distributed/MatrixEntry.html      |   404 +
 .../spark/mllib/linalg/distributed/RowMatrix.html  |   676 +
 .../mllib/linalg/distributed/package-frame.html    |    29 +
 .../mllib/linalg/distributed/package-summary.html  |   190 +
 .../mllib/linalg/distributed/package-tree.html     |   152 +
 .../apache/spark/mllib/linalg/package-frame.html   |    38 +
 .../apache/spark/mllib/linalg/package-summary.html |   245 +
 .../apache/spark/mllib/linalg/package-tree.html    |   165 +
 .../apache/spark/mllib/optimization/Gradient.html  |   336 +
 .../spark/mllib/optimization/GradientDescent.html  |   542 +
 .../spark/mllib/optimization/HingeGradient.html    |   346 +
 .../apache/spark/mllib/optimization/L1Updater.html |   329 +
 .../org/apache/spark/mllib/optimization/LBFGS.html |   503 +
 .../mllib/optimization/LeastSquaresGradient.html   |   345 +
 .../spark/mllib/optimization/LogisticGradient.html |   429 +
 .../spark/mllib/optimization/NNLS.Workspace.html   |   364 +
 .../org/apache/spark/mllib/optimization/NNLS.html  |   335 +
 .../apache/spark/mllib/optimization/Optimizer.html |   242 +
 .../spark/mllib/optimization/SimpleUpdater.html    |   315 +
 .../spark/mllib/optimization/SquaredL2Updater.html |   316 +
 .../apache/spark/mllib/optimization/Updater.html   |   320 +
 .../spark/mllib/optimization/package-frame.html    |    35 +
 .../spark/mllib/optimization/package-summary.html  |   235 +
 .../spark/mllib/optimization/package-tree.html     |   164 +
 .../java/org/apache/spark/mllib/package-frame.html |    20 +
 .../org/apache/spark/mllib/package-summary.html    |   174 +
 .../java/org/apache/spark/mllib/package-tree.html  |   135 +
 .../apache/spark/mllib/pmml/PMMLExportable.html    |   317 +
 .../mllib/pmml/export/PMMLModelExportFactory.html  |   280 +
 .../spark/mllib/pmml/export/package-frame.html     |    20 +
 .../spark/mllib/pmml/export/package-summary.html   |   140 +
 .../spark/mllib/pmml/export/package-tree.html      |   135 +
 .../org/apache/spark/mllib/pmml/package-frame.html |    20 +
 .../apache/spark/mllib/pmml/package-summary.html   |   145 +
 .../org/apache/spark/mllib/pmml/package-tree.html  |   131 +
 .../spark/mllib/random/ExponentialGenerator.html   |   351 +
 .../apache/spark/mllib/random/GammaGenerator.html  |   367 +
 .../spark/mllib/random/LogNormalGenerator.html     |   368 +
 .../spark/mllib/random/PoissonGenerator.html       |   351 +
 .../spark/mllib/random/RandomDataGenerator.html    |   266 +
 .../org/apache/spark/mllib/random/RandomRDDs.html  |  2185 +
 .../mllib/random/StandardNormalGenerator.html      |   336 +
 .../spark/mllib/random/UniformGenerator.html       |   336 +
 .../spark/mllib/random/WeibullGenerator.html       |   368 +
 .../apache/spark/mllib/random/package-frame.html   |    31 +
 .../apache/spark/mllib/random/package-summary.html |   209 +
 .../apache/spark/mllib/random/package-tree.html    |   159 +
 .../apache/spark/mllib/rdd/MLPairRDDFunctions.html |   320 +
 .../org/apache/spark/mllib/rdd/RDDFunctions.html   |   340 +
 .../org/apache/spark/mllib/rdd/package-frame.html  |    21 +
 .../apache/spark/mllib/rdd/package-summary.html    |   150 +
 .../org/apache/spark/mllib/rdd/package-tree.html   |   136 +
 .../org/apache/spark/mllib/recommendation/ALS.html |   933 +
 .../MatrixFactorizationModel.SaveLoadV1_0$.html    |   339 +
 .../recommendation/MatrixFactorizationModel.html   |   582 +
 .../apache/spark/mllib/recommendation/Rating.html  |   401 +
 .../spark/mllib/recommendation/package-frame.html  |    23 +
 .../mllib/recommendation/package-summary.html      |   158 +
 .../spark/mllib/recommendation/package-tree.html   |   138 +
 .../regression/GeneralizedLinearAlgorithm.html     |   443 +
 .../mllib/regression/GeneralizedLinearModel.html   |   375 +
 .../spark/mllib/regression/IsotonicRegression.html |   361 +
 .../mllib/regression/IsotonicRegressionModel.html  |   474 +
 .../spark/mllib/regression/LabeledPoint.html       |   431 +
 .../apache/spark/mllib/regression/LassoModel.html  |   487 +
 .../spark/mllib/regression/LassoWithSGD.html       |   550 +
 .../mllib/regression/LinearRegressionModel.html    |   487 +
 .../mllib/regression/LinearRegressionWithSGD.html  |   542 +
 .../spark/mllib/regression/RegressionModel.html    |   286 +
 .../mllib/regression/RidgeRegressionModel.html     |   487 +
 .../mllib/regression/RidgeRegressionWithSGD.html   |   546 +
 .../mllib/regression/StreamingLinearAlgorithm.html |   459 +
 .../StreamingLinearRegressionWithSGD.html          |   457 +
 .../GLMRegressionModel.SaveLoadV1_0$.Data$.html    |   306 +
 .../GLMRegressionModel.SaveLoadV1_0$.Data.html     |   390 +
 .../impl/GLMRegressionModel.SaveLoadV1_0$.html     |   401 +
 .../mllib/regression/impl/GLMRegressionModel.html  |   255 +
 .../spark/mllib/regression/impl/package-frame.html |    21 +
 .../mllib/regression/impl/package-summary.html     |   146 +
 .../spark/mllib/regression/impl/package-tree.html  |   142 +
 .../spark/mllib/regression/package-frame.html      |    36 +
 .../spark/mllib/regression/package-summary.html    |   235 +
 .../spark/mllib/regression/package-tree.html       |   168 +
 .../org/apache/spark/mllib/stat/KernelDensity.html |   387 +
 .../mllib/stat/MultivariateOnlineSummarizer.html   |   514 +
 .../mllib/stat/MultivariateStatisticalSummary.html |   371 +
 .../org/apache/spark/mllib/stat/Statistics.html    |   754 +
 .../mllib/stat/correlation/CorrelationNames.html   |   289 +
 .../spark/mllib/stat/correlation/Correlations.html |   302 +
 .../mllib/stat/correlation/PearsonCorrelation.html |   348 +
 .../stat/correlation/SpearmanCorrelation.html      |   325 +
 .../mllib/stat/correlation/package-frame.html      |    23 +
 .../mllib/stat/correlation/package-summary.html    |   162 +
 .../spark/mllib/stat/correlation/package-tree.html |   138 +
 .../stat/distribution/MultivariateGaussian.html    |   346 +
 .../mllib/stat/distribution/package-frame.html     |    20 +
 .../mllib/stat/distribution/package-summary.html   |   143 +
 .../mllib/stat/distribution/package-tree.html      |   135 +
 .../org/apache/spark/mllib/stat/package-frame.html |    26 +
 .../apache/spark/mllib/stat/package-summary.html   |   174 +
 .../org/apache/spark/mllib/stat/package-tree.html  |   141 +
 .../apache/spark/mllib/stat/test/BinarySample.html |   406 +
 .../spark/mllib/stat/test/ChiSqTest.Method$.html   |   306 +
 .../spark/mllib/stat/test/ChiSqTest.Method.html    |   313 +
 .../mllib/stat/test/ChiSqTest.NullHypothesis$.html |   367 +
 .../apache/spark/mllib/stat/test/ChiSqTest.html    |   369 +
 .../spark/mllib/stat/test/ChiSqTestResult.html     |   363 +
 .../KolmogorovSmirnovTest.NullHypothesis$.html     |   354 +
 .../mllib/stat/test/KolmogorovSmirnovTest.html     |   377 +
 .../stat/test/KolmogorovSmirnovTestResult.html     |   350 +
 .../spark/mllib/stat/test/StreamingTest.html       |   400 +
 .../apache/spark/mllib/stat/test/StudentTTest.html |   303 +
 .../apache/spark/mllib/stat/test/TestResult.html   |   322 +
 .../apache/spark/mllib/stat/test/WelchTTest.html   |   303 +
 .../spark/mllib/stat/test/package-frame.html       |    35 +
 .../spark/mllib/stat/test/package-summary.html     |   220 +
 .../apache/spark/mllib/stat/test/package-tree.html |   158 +
 .../org/apache/spark/mllib/tree/DecisionTree.html  |   642 +
 .../spark/mllib/tree/GradientBoostedTrees.html     |   446 +
 .../org/apache/spark/mllib/tree/RandomForest.html  |   634 +
 .../spark/mllib/tree/configuration/Algo.html       |   348 +
 .../mllib/tree/configuration/BoostingStrategy.html |   626 +
 .../configuration/EnsembleCombiningStrategy.html   |   361 +
 .../mllib/tree/configuration/FeatureType.html      |   348 +
 .../mllib/tree/configuration/QuantileStrategy.html |   361 +
 .../spark/mllib/tree/configuration/Strategy.html   |   981 +
 .../mllib/tree/configuration/package-frame.html    |    25 +
 .../mllib/tree/configuration/package-summary.html  |   173 +
 .../mllib/tree/configuration/package-tree.html     |   140 +
 .../apache/spark/mllib/tree/impurity/Entropy.html  |   335 +
 .../org/apache/spark/mllib/tree/impurity/Gini.html |   337 +
 .../spark/mllib/tree/impurity/Impurities.html      |   270 +
 .../apache/spark/mllib/tree/impurity/Impurity.html |   272 +
 .../apache/spark/mllib/tree/impurity/Variance.html |   335 +
 .../spark/mllib/tree/impurity/package-frame.html   |    27 +
 .../spark/mllib/tree/impurity/package-summary.html |   179 +
 .../spark/mllib/tree/impurity/package-tree.html    |   150 +
 .../spark/mllib/tree/loss/AbsoluteError.html       |   290 +
 .../org/apache/spark/mllib/tree/loss/LogLoss.html  |   292 +
 .../org/apache/spark/mllib/tree/loss/Loss.html     |   298 +
 .../org/apache/spark/mllib/tree/loss/Losses.html   |   269 +
 .../apache/spark/mllib/tree/loss/SquaredError.html |   290 +
 .../spark/mllib/tree/loss/package-frame.html       |    27 +
 .../spark/mllib/tree/loss/package-summary.html     |   179 +
 .../apache/spark/mllib/tree/loss/package-tree.html |   150 +
 .../DecisionTreeModel.SaveLoadV1_0$.NodeData$.html |   336 +
 .../DecisionTreeModel.SaveLoadV1_0$.NodeData.html  |   523 +
 ...cisionTreeModel.SaveLoadV1_0$.PredictData$.html |   334 +
 ...ecisionTreeModel.SaveLoadV1_0$.PredictData.html |   428 +
 ...DecisionTreeModel.SaveLoadV1_0$.SplitData$.html |   334 +
 .../DecisionTreeModel.SaveLoadV1_0$.SplitData.html |   458 +
 .../model/DecisionTreeModel.SaveLoadV1_0$.html     |   437 +
 .../spark/mllib/tree/model/DecisionTreeModel.html  |   524 +
 .../tree/model/GradientBoostedTreesModel.html      |   711 +
 .../mllib/tree/model/InformationGainStats.html     |   412 +
 .../org/apache/spark/mllib/tree/model/Node.html    |   681 +
 .../org/apache/spark/mllib/tree/model/Predict.html |   348 +
 .../spark/mllib/tree/model/RandomForestModel.html  |   594 +
 .../org/apache/spark/mllib/tree/model/Split.html   |   439 +
 .../spark/mllib/tree/model/package-frame.html      |    27 +
 .../spark/mllib/tree/model/package-summary.html    |   196 +
 .../spark/mllib/tree/model/package-tree.html       |   148 +
 .../org/apache/spark/mllib/tree/package-frame.html |    22 +
 .../apache/spark/mllib/tree/package-summary.html   |   157 +
 .../org/apache/spark/mllib/tree/package-tree.html  |   137 +
 .../apache/spark/mllib/util/DataValidators.html    |   304 +
 .../spark/mllib/util/KMeansDataGenerator.html      |   311 +
 .../spark/mllib/util/LinearDataGenerator.html      |   473 +
 .../java/org/apache/spark/mllib/util/Loader.html   |   238 +
 .../util/LogisticRegressionDataGenerator.html      |   310 +
 .../apache/spark/mllib/util/MFDataGenerator.html   |   291 +
 .../java/org/apache/spark/mllib/util/MLUtils.html  |   805 +
 .../org/apache/spark/mllib/util/NumericParser.html |   277 +
 .../apache/spark/mllib/util/SVMDataGenerator.html  |   272 +
 .../java/org/apache/spark/mllib/util/Saveable.html |   261 +
 .../org/apache/spark/mllib/util/package-frame.html |    32 +
 .../apache/spark/mllib/util/package-summary.html   |   213 +
 .../org/apache/spark/mllib/util/package-tree.html  |   147 +
 .../api/java/org/apache/spark/package-frame.html   |   106 +
 .../api/java/org/apache/spark/package-summary.html |   644 +
 .../api/java/org/apache/spark/package-tree.html    |   287 +
 .../org/apache/spark/partial/BoundedDouble.html    |   372 +
 .../org/apache/spark/partial/PartialResult.html    |   389 +
 .../org/apache/spark/partial/package-frame.html    |    21 +
 .../org/apache/spark/partial/package-summary.html  |   146 +
 .../org/apache/spark/partial/package-tree.html     |   136 +
 .../java/org/apache/spark/rdd/AsyncRDDActions.html |   394 +
 .../java/org/apache/spark/rdd/CheckpointState.html |   363 +
 .../java/org/apache/spark/rdd/CoGroupedRDD.html    |   444 +
 ...faultPartitionCoalescer.PartitionLocations.html |   299 +
 .../spark/rdd/DefaultPartitionCoalescer.html       |   595 +
 .../org/apache/spark/rdd/DeterministicLevel.html   |   369 +
 .../org/apache/spark/rdd/DoubleRDDFunctions.html   |   561 +
 ...HadoopRDD.HadoopMapPartitionsWithSplitRDD$.html |   287 +
 .../api/java/org/apache/spark/rdd/HadoopRDD.html   |  2353 +
 .../org/apache/spark/rdd/InputFileBlockHolder.html |   360 +
 .../spark/rdd/JdbcRDD.ConnectionFactory.html       |   233 +
 .../api/java/org/apache/spark/rdd/JdbcRDD.html     |  2294 +
 ...oopRDD.NewHadoopMapPartitionsWithSplitRDD$.html |   287 +
 .../java/org/apache/spark/rdd/NewHadoopRDD.html    |  2245 +
 .../org/apache/spark/rdd/OrderedRDDFunctions.html  |   382 +
 .../org/apache/spark/rdd/PairRDDFunctions.html     |  2336 +
 .../org/apache/spark/rdd/PartitionCoalescer.html   |   239 +
 .../java/org/apache/spark/rdd/PartitionGroup.html  |   298 +
 .../org/apache/spark/rdd/PartitionPruningRDD.html  |  2136 +
 .../2.4.3/api/java/org/apache/spark/rdd/RDD.html   |  2787 +
 .../api/java/org/apache/spark/rdd/RDDBarrier.html  |   262 +
 .../apache/spark/rdd/SequenceFileRDDFunctions.html |   318 +
 .../api/java/org/apache/spark/rdd/ShuffledRDD.html |   496 +
 .../api/java/org/apache/spark/rdd/UnionRDD.html    |  2208 +
 .../java/org/apache/spark/rdd/package-frame.html   |    45 +
 .../java/org/apache/spark/rdd/package-summary.html |   301 +
 .../java/org/apache/spark/rdd/package-tree.html    |   172 +
 .../java/org/apache/spark/rpc/netty/OnStart.html   |   334 +
 .../java/org/apache/spark/rpc/netty/OnStop.html    |   334 +
 .../org/apache/spark/rpc/netty/package-frame.html  |    21 +
 .../apache/spark/rpc/netty/package-summary.html    |   144 +
 .../org/apache/spark/rpc/netty/package-tree.html   |   136 +
 .../apache/spark/scheduler/AccumulableInfo.html    |   463 +
 .../apache/spark/scheduler/AllJobsCancelled.html   |   334 +
 .../scheduler/AskPermissionToCommitOutput.html     |   415 +
 .../apache/spark/scheduler/AsyncEventQueue.html    |   408 +
 .../spark/scheduler/BlacklistedExecutor.html       |   385 +
 .../org/apache/spark/scheduler/ExecutorKilled.html |   282 +
 .../apache/spark/scheduler/InputFormatInfo.html    |   427 +
 .../java/org/apache/spark/scheduler/JobResult.html |   167 +
 .../org/apache/spark/scheduler/JobSucceeded.html   |   334 +
 .../apache/spark/scheduler/LossReasonPending.html  |   287 +
 .../scheduler/OutputCommitCoordinationMessage.html |   170 +
 .../spark/scheduler/ResubmitFailedStages.html      |   334 +
 .../apache/spark/scheduler/RuntimePercentage.html  |   415 +
 .../org/apache/spark/scheduler/SchedulingMode.html |   363 +
 .../org/apache/spark/scheduler/SparkListener.html  |   767 +
 .../scheduler/SparkListenerApplicationEnd.html     |   377 +
 .../scheduler/SparkListenerApplicationStart.html   |   452 +
 .../scheduler/SparkListenerBlockManagerAdded.html  |   437 +
 .../SparkListenerBlockManagerRemoved.html          |   392 +
 .../spark/scheduler/SparkListenerBlockUpdated.html |   377 +
 .../scheduler/SparkListenerEnvironmentUpdate.html  |   377 +
 .../apache/spark/scheduler/SparkListenerEvent.html |   227 +
 .../scheduler/SparkListenerExecutorAdded.html      |   407 +
 .../SparkListenerExecutorBlacklisted.html          |   407 +
 .../SparkListenerExecutorBlacklistedForStage.html  |   437 +
 .../SparkListenerExecutorMetricsUpdate.html        |   395 +
 .../scheduler/SparkListenerExecutorRemoved.html    |   407 +
 .../SparkListenerExecutorUnblacklisted.html        |   392 +
 .../spark/scheduler/SparkListenerJobEnd.html       |   407 +
 .../spark/scheduler/SparkListenerJobStart.html     |   435 +
 .../spark/scheduler/SparkListenerLogStart.html     |   378 +
 .../scheduler/SparkListenerNodeBlacklisted.html    |   407 +
 .../SparkListenerNodeBlacklistedForStage.html      |   437 +
 .../scheduler/SparkListenerNodeUnblacklisted.html  |   392 +
 .../SparkListenerSpeculativeTaskSubmitted.html     |   377 +
 .../scheduler/SparkListenerStageCompleted.html     |   377 +
 .../scheduler/SparkListenerStageSubmitted.html     |   392 +
 .../spark/scheduler/SparkListenerTaskEnd.html      |   452 +
 .../scheduler/SparkListenerTaskGettingResult.html  |   377 +
 .../spark/scheduler/SparkListenerTaskStart.html    |   407 +
 .../spark/scheduler/SparkListenerUnpersistRDD.html |   377 +
 .../java/org/apache/spark/scheduler/SplitInfo.html |   414 +
 .../java/org/apache/spark/scheduler/StageInfo.html |   517 +
 .../spark/scheduler/StatsReportListener.html       |   904 +
 .../apache/spark/scheduler/StopCoordinator.html    |   334 +
 .../java/org/apache/spark/scheduler/TaskInfo.html  |   567 +
 .../org/apache/spark/scheduler/TaskLocality.html   |   401 +
 ...arseGrainedClusterMessages.AddWebUIFilter$.html |   306 +
 ...oarseGrainedClusterMessages.AddWebUIFilter.html |   326 +
 ...inedClusterMessages.GetExecutorLossReason$.html |   306 +
 ...ainedClusterMessages.GetExecutorLossReason.html |   296 +
 ...oarseGrainedClusterMessages.KillExecutors$.html |   306 +
 ...CoarseGrainedClusterMessages.KillExecutors.html |   296 +
 ...rainedClusterMessages.KillExecutorsOnHost$.html |   306 +
 ...GrainedClusterMessages.KillExecutorsOnHost.html |   296 +
 .../CoarseGrainedClusterMessages.KillTask$.html    |   306 +
 .../CoarseGrainedClusterMessages.KillTask.html     |   341 +
 .../CoarseGrainedClusterMessages.LaunchTask$.html  |   306 +
 .../CoarseGrainedClusterMessages.LaunchTask.html   |   296 +
 ...nedClusterMessages.RegisterClusterManager$.html |   306 +
 ...inedClusterMessages.RegisterClusterManager.html |   296 +
 ...seGrainedClusterMessages.RegisterExecutor$.html |   306 +
 ...rseGrainedClusterMessages.RegisterExecutor.html |   356 +
 ...nedClusterMessages.RegisterExecutorFailed$.html |   306 +
 ...inedClusterMessages.RegisterExecutorFailed.html |   296 +
 ...edClusterMessages.RegisterExecutorResponse.html |   173 +
 ...GrainedClusterMessages.RegisteredExecutor$.html |   301 +
 ...arseGrainedClusterMessages.RemoveExecutor$.html |   306 +
 ...oarseGrainedClusterMessages.RemoveExecutor.html |   311 +
 ...CoarseGrainedClusterMessages.RemoveWorker$.html |   306 +
 .../CoarseGrainedClusterMessages.RemoveWorker.html |   326 +
 ...seGrainedClusterMessages.RequestExecutors$.html |   306 +
 ...rseGrainedClusterMessages.RequestExecutors.html |   341 +
 ...rMessages.RetrieveLastAllocatedExecutorId$.html |   301 +
 ...nedClusterMessages.RetrieveSparkAppConfig$.html |   301 +
 ...CoarseGrainedClusterMessages.ReviveOffers$.html |   301 +
 .../CoarseGrainedClusterMessages.SetupDriver$.html |   306 +
 .../CoarseGrainedClusterMessages.SetupDriver.html  |   296 +
 .../CoarseGrainedClusterMessages.Shutdown$.html    |   301 +
 ...arseGrainedClusterMessages.SparkAppConfig$.html |   306 +
 ...oarseGrainedClusterMessages.SparkAppConfig.html |   326 +
 ...CoarseGrainedClusterMessages.StatusUpdate$.html |   330 +
 .../CoarseGrainedClusterMessages.StatusUpdate.html |   341 +
 .../CoarseGrainedClusterMessages.StopDriver$.html  |   301 +
 ...CoarseGrainedClusterMessages.StopExecutor$.html |   301 +
 ...oarseGrainedClusterMessages.StopExecutors$.html |   301 +
 ...nedClusterMessages.UpdateDelegationTokens$.html |   306 +
 ...inedClusterMessages.UpdateDelegationTokens.html |   296 +
 .../cluster/CoarseGrainedClusterMessages.html      |   414 +
 .../spark/scheduler/cluster/ExecutorInfo.html      |   348 +
 .../scheduler/cluster/SchedulerBackendUtils.html   |   297 +
 .../spark/scheduler/cluster/package-frame.html     |    66 +
 .../spark/scheduler/cluster/package-summary.html   |   326 +
 .../spark/scheduler/cluster/package-tree.html      |   201 +
 .../org/apache/spark/scheduler/local/KillTask.html |   400 +
 .../apache/spark/scheduler/local/ReviveOffers.html |   357 +
 .../apache/spark/scheduler/local/StatusUpdate.html |   400 +
 .../apache/spark/scheduler/local/StopExecutor.html |   357 +
 .../spark/scheduler/local/package-frame.html       |    23 +
 .../spark/scheduler/local/package-summary.html     |   152 +
 .../apache/spark/scheduler/local/package-tree.html |   138 +
 .../org/apache/spark/scheduler/package-frame.html  |    69 +
 .../apache/spark/scheduler/package-summary.html    |   378 +
 .../org/apache/spark/scheduler/package-tree.html   |   195 +
 .../CryptoStreamUtils.BaseErrorHandler.html        |   309 +
 ...toStreamUtils.ErrorHandlingReadableChannel.html |   315 +
 .../apache/spark/security/CryptoStreamUtils.html   |   455 +
 .../security/GroupMappingServiceProvider.html      |   234 +
 .../org/apache/spark/security/package-frame.html   |    26 +
 .../org/apache/spark/security/package-summary.html |   169 +
 .../org/apache/spark/security/package-tree.html    |   149 +
 .../spark/serializer/DeserializationStream.html    |   372 +
 .../spark/serializer/DummySerializerInstance.html  |   362 +
 .../serializer/JavaIterableWrapperSerializer.html  |   409 +
 .../apache/spark/serializer/JavaSerializer.html    |   339 +
 .../apache/spark/serializer/KryoRegistrator.html   |   221 +
 .../apache/spark/serializer/KryoSerializer.html    |   364 +
 ...lizationDebugger.ObjectStreamClassMethods$.html |   278 +
 ...alizationDebugger.ObjectStreamClassMethods.html |   359 +
 .../spark/serializer/SerializationDebugger.html    |   309 +
 .../spark/serializer/SerializationStream.html      |   370 +
 .../org/apache/spark/serializer/Serializer.html    |   316 +
 .../spark/serializer/SerializerInstance.html       |   340 +
 .../org/apache/spark/serializer/package-frame.html |    34 +
 .../apache/spark/serializer/package-summary.html   |   231 +
 .../org/apache/spark/serializer/package-tree.html  |   163 +
 .../org/apache/spark/sql/AnalysisException.html    |   518 +
 .../api/java/org/apache/spark/sql/Column.html      |  2127 +
 .../api/java/org/apache/spark/sql/ColumnName.html  |   534 +
 .../org/apache/spark/sql/DataFrameNaFunctions.html |  1066 +
 .../java/org/apache/spark/sql/DataFrameReader.html |  1707 +
 .../apache/spark/sql/DataFrameStatFunctions.html   |  1017 +
 .../java/org/apache/spark/sql/DataFrameWriter.html |  1122 +
 .../api/java/org/apache/spark/sql/Dataset.html     |  6014 +++
 .../java/org/apache/spark/sql/DatasetHolder.html   |   372 +
 .../api/java/org/apache/spark/sql/Encoder.html     |   290 +
 .../api/java/org/apache/spark/sql/Encoders.html    |  1002 +
 .../org/apache/spark/sql/ExperimentalMethods.html  |   288 +
 .../java/org/apache/spark/sql/ForeachWriter.html   |   428 +
 .../apache/spark/sql/KeyValueGroupedDataset.html   |  1117 +
 .../apache/spark/sql/LowPrioritySQLImplicits.html  |   232 +
 .../sql/RelationalGroupedDataset.CubeType$.html    |   317 +
 .../sql/RelationalGroupedDataset.GroupByType$.html |   317 +
 .../sql/RelationalGroupedDataset.PivotType$.html   |   306 +
 .../sql/RelationalGroupedDataset.RollupType$.html  |   317 +
 .../apache/spark/sql/RelationalGroupedDataset.html |  1031 +
 .../2.4.3/api/java/org/apache/spark/sql/Row.html   |  1142 +
 .../api/java/org/apache/spark/sql/RowFactory.html  |   283 +
 .../java/org/apache/spark/sql/RuntimeConfig.html   |   465 +
 .../api/java/org/apache/spark/sql/SQLContext.html  |  2001 +
 .../apache/spark/sql/SQLContext.implicits$.html    |   293 +
 .../spark/sql/SQLImplicits.StringToColumn.html     |   279 +
 .../java/org/apache/spark/sql/SQLImplicits.html    |  1134 +
 .../api/java/org/apache/spark/sql/SaveMode.html    |   409 +
 .../org/apache/spark/sql/SparkSession.Builder.html |   552 +
 .../java/org/apache/spark/sql/SparkSession.html    |  1608 +
 .../apache/spark/sql/SparkSession.implicits$.html  |   293 +
 .../apache/spark/sql/SparkSessionExtensions.html   |   422 +
 .../api/java/org/apache/spark/sql/TypedColumn.html |   324 +
 .../java/org/apache/spark/sql/UDFRegistration.html |  2408 +
 .../java/org/apache/spark/sql/api/java/UDF0.html   |   231 +
 .../java/org/apache/spark/sql/api/java/UDF1.html   |   233 +
 .../java/org/apache/spark/sql/api/java/UDF10.html  |   251 +
 .../java/org/apache/spark/sql/api/java/UDF11.html  |   253 +
 .../java/org/apache/spark/sql/api/java/UDF12.html  |   255 +
 .../java/org/apache/spark/sql/api/java/UDF13.html  |   257 +
 .../java/org/apache/spark/sql/api/java/UDF14.html  |   259 +
 .../java/org/apache/spark/sql/api/java/UDF15.html  |   261 +
 .../java/org/apache/spark/sql/api/java/UDF16.html  |   263 +
 .../java/org/apache/spark/sql/api/java/UDF17.html  |   265 +
 .../java/org/apache/spark/sql/api/java/UDF18.html  |   267 +
 .../java/org/apache/spark/sql/api/java/UDF19.html  |   269 +
 .../java/org/apache/spark/sql/api/java/UDF2.html   |   235 +
 .../java/org/apache/spark/sql/api/java/UDF20.html  |   271 +
 .../java/org/apache/spark/sql/api/java/UDF21.html  |   273 +
 .../java/org/apache/spark/sql/api/java/UDF22.html  |   275 +
 .../java/org/apache/spark/sql/api/java/UDF3.html   |   237 +
 .../java/org/apache/spark/sql/api/java/UDF4.html   |   239 +
 .../java/org/apache/spark/sql/api/java/UDF5.html   |   241 +
 .../java/org/apache/spark/sql/api/java/UDF6.html   |   243 +
 .../java/org/apache/spark/sql/api/java/UDF7.html   |   245 +
 .../java/org/apache/spark/sql/api/java/UDF8.html   |   247 +
 .../java/org/apache/spark/sql/api/java/UDF9.html   |   249 +
 .../apache/spark/sql/api/java/package-frame.html   |    42 +
 .../apache/spark/sql/api/java/package-summary.html |   283 +
 .../apache/spark/sql/api/java/package-tree.html    |   157 +
 .../java/org/apache/spark/sql/api/r/SQLUtils.html  |   528 +
 .../org/apache/spark/sql/api/r/package-frame.html  |    20 +
 .../apache/spark/sql/api/r/package-summary.html    |   140 +
 .../org/apache/spark/sql/api/r/package-tree.html   |   135 +
 .../java/org/apache/spark/sql/catalog/Catalog.html |  1515 +
 .../java/org/apache/spark/sql/catalog/Column.html  |   378 +
 .../org/apache/spark/sql/catalog/Database.html     |   330 +
 .../org/apache/spark/sql/catalog/Function.html     |   362 +
 .../java/org/apache/spark/sql/catalog/Table.html   |   362 +
 .../apache/spark/sql/catalog/package-frame.html    |    24 +
 .../apache/spark/sql/catalog/package-summary.html  |   166 +
 .../org/apache/spark/sql/catalog/package-tree.html |   139 +
 .../apache/spark/sql/expressions/Aggregator.html   |   468 +
 .../sql/expressions/MutableAggregationBuffer.html  |   296 +
 .../sql/expressions/SparkUserDefinedFunction.html  |   273 +
 .../expressions/UserDefinedAggregateFunction.html  |   599 +
 .../spark/sql/expressions/UserDefinedFunction.html |   543 +
 .../org/apache/spark/sql/expressions/Window.html   |   689 +
 .../apache/spark/sql/expressions/WindowSpec.html   |   595 +
 .../sql/expressions/javalang/package-frame.html    |    20 +
 .../sql/expressions/javalang/package-summary.html  |   143 +
 .../sql/expressions/javalang/package-tree.html     |   135 +
 .../spark/sql/expressions/javalang/typed.html      |   345 +
 .../spark/sql/expressions/package-frame.html       |    26 +
 .../spark/sql/expressions/package-summary.html     |   178 +
 .../apache/spark/sql/expressions/package-tree.html |   141 +
 .../sql/expressions/scalalang/package-frame.html   |    20 +
 .../sql/expressions/scalalang/package-summary.html |   143 +
 .../sql/expressions/scalalang/package-tree.html    |   135 +
 .../spark/sql/expressions/scalalang/typed.html     |   365 +
 .../api/java/org/apache/spark/sql/functions.html   | 11293 ++++
 .../apache/spark/sql/hive/DetermineTableStats.html |   296 +
 .../org/apache/spark/sql/hive/HiveAnalysis.html    |   286 +
 .../org/apache/spark/sql/hive/HiveContext.html     |   378 +
 .../spark/sql/hive/HiveSessionResourceLoader.html  |   291 +
 .../spark/sql/hive/HiveSessionStateBuilder.html    |   310 +
 .../sql/hive/HiveShim.HiveFunctionWrapper$.html    |   306 +
 .../java/org/apache/spark/sql/hive/HiveShim.html   |   374 +
 .../org/apache/spark/sql/hive/HiveTableUtil.html   |   273 +
 .../org/apache/spark/sql/hive/HiveUDAFBuffer.html  |   385 +
 .../java/org/apache/spark/sql/hive/HiveUtils.html  |   463 +
 .../apache/spark/sql/hive/RelationConversions.html |   441 +
 .../spark/sql/hive/ResolveHiveSerdeTable.html      |   298 +
 .../execution/CreateHiveTableAsSelectCommand.html  |  1596 +
 .../spark/sql/hive/execution/HiveFileFormat.html   |   363 +
 .../spark/sql/hive/execution/HiveOptions.html      |   450 +
 .../spark/sql/hive/execution/HiveOutputWriter.html |   301 +
 .../sql/hive/execution/HiveScriptIOSchema.html     |   731 +
 .../hive/execution/InsertIntoHiveDirCommand.html   |  1797 +
 .../sql/hive/execution/InsertIntoHiveTable.html    |  1837 +
 .../hive/execution/ScriptTransformationExec.html   |  1462 +
 .../ScriptTransformationWriterThread.html          |   365 +
 .../spark/sql/hive/execution/package-frame.html    |    28 +
 .../spark/sql/hive/execution/package-summary.html  |   184 +
 .../spark/sql/hive/execution/package-tree.html     |   167 +
 .../apache/spark/sql/hive/orc/OrcFileFormat.html   |   541 +
 .../apache/spark/sql/hive/orc/OrcFileOperator.html |   346 +
 .../org/apache/spark/sql/hive/orc/OrcFilters.html  |   299 +
 .../apache/spark/sql/hive/orc/package-frame.html   |    22 +
 .../apache/spark/sql/hive/orc/package-summary.html |   152 +
 .../apache/spark/sql/hive/orc/package-tree.html    |   137 +
 .../org/apache/spark/sql/hive/package-frame.html   |    31 +
 .../org/apache/spark/sql/hive/package-summary.html |   195 +
 .../org/apache/spark/sql/hive/package-tree.html    |   166 +
 .../apache/spark/sql/jdbc/AggregatedDialect.html   |   500 +
 .../java/org/apache/spark/sql/jdbc/DB2Dialect.html |   422 +
 .../org/apache/spark/sql/jdbc/DerbyDialect.html    |   422 +
 .../org/apache/spark/sql/jdbc/JdbcDialect.html     |   555 +
 .../org/apache/spark/sql/jdbc/JdbcDialects.html    |   333 +
 .../java/org/apache/spark/sql/jdbc/JdbcType.html   |   391 +
 .../apache/spark/sql/jdbc/MsSqlServerDialect.html  |   422 +
 .../org/apache/spark/sql/jdbc/MySQLDialect.html    |   500 +
 .../org/apache/spark/sql/jdbc/NoopDialect.html     |   423 +
 .../org/apache/spark/sql/jdbc/OracleDialect.html   |   498 +
 .../org/apache/spark/sql/jdbc/PostgresDialect.html |   425 +
 .../org/apache/spark/sql/jdbc/TeradataDialect.html |   500 +
 .../org/apache/spark/sql/jdbc/package-frame.html   |    31 +
 .../org/apache/spark/sql/jdbc/package-summary.html |   199 +
 .../org/apache/spark/sql/jdbc/package-tree.html    |   149 +
 .../java/org/apache/spark/sql/package-frame.html   |    60 +
 .../java/org/apache/spark/sql/package-summary.html |   366 +
 .../java/org/apache/spark/sql/package-tree.html    |   209 +
 .../api/java/org/apache/spark/sql/sources/And.html |   417 +
 .../org/apache/spark/sql/sources/BaseRelation.html |   388 +
 .../org/apache/spark/sql/sources/CatalystScan.html |   232 +
 .../sql/sources/CreatableRelationProvider.html     |   245 +
 .../spark/sql/sources/DataSourceRegister.html      |   248 +
 .../apache/spark/sql/sources/EqualNullSafe.html    |   419 +
 .../java/org/apache/spark/sql/sources/EqualTo.html |   418 +
 .../java/org/apache/spark/sql/sources/Filter.html  |   288 +
 .../org/apache/spark/sql/sources/GreaterThan.html  |   418 +
 .../spark/sql/sources/GreaterThanOrEqual.html      |   418 +
 .../api/java/org/apache/spark/sql/sources/In.html  |   457 +
 .../spark/sql/sources/InsertableRelation.html      |   239 +
 .../org/apache/spark/sql/sources/IsNotNull.html    |   402 +
 .../java/org/apache/spark/sql/sources/IsNull.html  |   402 +
 .../org/apache/spark/sql/sources/LessThan.html     |   418 +
 .../apache/spark/sql/sources/LessThanOrEqual.html  |   418 +
 .../api/java/org/apache/spark/sql/sources/Not.html |   402 +
 .../api/java/org/apache/spark/sql/sources/Or.html  |   417 +
 .../spark/sql/sources/PrunedFilteredScan.html      |   235 +
 .../org/apache/spark/sql/sources/PrunedScan.html   |   226 +
 .../apache/spark/sql/sources/RelationProvider.html |   250 +
 .../spark/sql/sources/SchemaRelationProvider.html  |   259 +
 .../spark/sql/sources/StreamSinkProvider.html      |   232 +
 .../spark/sql/sources/StreamSourceProvider.html    |   279 +
 .../apache/spark/sql/sources/StringContains.html   |   418 +
 .../apache/spark/sql/sources/StringEndsWith.html   |   418 +
 .../apache/spark/sql/sources/StringStartsWith.html |   418 +
 .../org/apache/spark/sql/sources/TableScan.html    |   225 +
 .../apache/spark/sql/sources/package-frame.html    |    50 +
 .../apache/spark/sql/sources/package-summary.html  |   327 +
 .../org/apache/spark/sql/sources/package-tree.html |   168 +
 .../sql/sources/v2/ContinuousReadSupport.html      |   243 +
 .../spark/sql/sources/v2/DataSourceOptions.html    |   575 +
 .../apache/spark/sql/sources/v2/DataSourceV2.html  |   175 +
 .../sql/sources/v2/MicroBatchReadSupport.html      |   250 +
 .../apache/spark/sql/sources/v2/ReadSupport.html   |   268 +
 .../spark/sql/sources/v2/SessionConfigSupport.html |   233 +
 .../spark/sql/sources/v2/StreamWriteSupport.html   |   248 +
 .../apache/spark/sql/sources/v2/WriteSupport.html  |   253 +
 .../apache/spark/sql/sources/v2/package-frame.html |    30 +
 .../spark/sql/sources/v2/package-summary.html      |   195 +
 .../apache/spark/sql/sources/v2/package-tree.html  |   153 +
 .../v2/reader/ContinuousInputPartition.html        |   241 +
 .../sql/sources/v2/reader/DataSourceReader.html    |   277 +
 .../sql/sources/v2/reader/InputPartition.html      |   271 +
 .../sources/v2/reader/InputPartitionReader.html    |   272 +
 .../spark/sql/sources/v2/reader/Statistics.html    |   235 +
 .../sources/v2/reader/SupportsPushDownFilters.html |   263 +
 .../v2/reader/SupportsPushDownRequiredColumns.html |   245 +
 .../v2/reader/SupportsReportPartitioning.html      |   240 +
 .../v2/reader/SupportsReportStatistics.html        |   241 +
 .../v2/reader/SupportsScanColumnarBatch.html       |   289 +
 .../spark/sql/sources/v2/reader/package-frame.html |    29 +
 .../sql/sources/v2/reader/package-summary.html     |   201 +
 .../spark/sql/sources/v2/reader/package-tree.html  |   158 +
 .../reader/partitioning/ClusteredDistribution.html |   283 +
 .../v2/reader/partitioning/Distribution.html       |   185 +
 .../v2/reader/partitioning/Partitioning.html       |   250 +
 .../v2/reader/partitioning/package-frame.html      |    25 +
 .../v2/reader/partitioning/package-summary.html    |   168 +
 .../v2/reader/partitioning/package-tree.html       |   140 +
 .../streaming/ContinuousInputPartitionReader.html  |   247 +
 .../v2/reader/streaming/ContinuousReader.html      |   349 +
 .../v2/reader/streaming/MicroBatchReader.html      |   341 +
 .../sql/sources/v2/reader/streaming/Offset.html    |   353 +
 .../v2/reader/streaming/PartitionOffset.html       |   175 +
 .../sources/v2/reader/streaming/package-frame.html |    27 +
 .../v2/reader/streaming/package-summary.html       |   178 +
 .../sources/v2/reader/streaming/package-tree.html  |   172 +
 .../sql/sources/v2/writer/DataSourceWriter.html    |   353 +
 .../spark/sql/sources/v2/writer/DataWriter.html    |   327 +
 .../sql/sources/v2/writer/DataWriterFactory.html   |   257 +
 .../sql/sources/v2/writer/WriterCommitMessage.html |   177 +
 .../spark/sql/sources/v2/writer/package-frame.html |    23 +
 .../sql/sources/v2/writer/package-summary.html     |   166 +
 .../spark/sql/sources/v2/writer/package-tree.html  |   138 +
 .../sources/v2/writer/streaming/StreamWriter.html  |   347 +
 .../sources/v2/writer/streaming/package-frame.html |    20 +
 .../v2/writer/streaming/package-summary.html       |   142 +
 .../sources/v2/writer/streaming/package-tree.html  |   135 +
 .../spark/sql/streaming/DataStreamReader.html      |   883 +
 .../spark/sql/streaming/DataStreamWriter.html      |   791 +
 .../org/apache/spark/sql/streaming/GroupState.html |   732 +
 .../spark/sql/streaming/GroupStateTimeout.html     |   319 +
 .../org/apache/spark/sql/streaming/OutputMode.html |   332 +
 .../apache/spark/sql/streaming/ProcessingTime.html |   567 +
 .../apache/spark/sql/streaming/SinkProgress.html   |   299 +
 .../apache/spark/sql/streaming/SourceProgress.html |   370 +
 .../spark/sql/streaming/StateOperatorProgress.html |   333 +
 .../apache/spark/sql/streaming/StreamingQuery.html |   578 +
 .../sql/streaming/StreamingQueryException.html     |   340 +
 .../streaming/StreamingQueryListener.Event.html    |   204 +
 .../StreamingQueryListener.QueryProgressEvent.html |   257 +
 .../StreamingQueryListener.QueryStartedEvent.html  |   285 +
 ...treamingQueryListener.QueryTerminatedEvent.html |   287 +
 .../sql/streaming/StreamingQueryListener.html      |   382 +
 .../spark/sql/streaming/StreamingQueryManager.html |   467 +
 .../sql/streaming/StreamingQueryProgress.html      |   483 +
 .../spark/sql/streaming/StreamingQueryStatus.html  |   328 +
 .../org/apache/spark/sql/streaming/Trigger.html    |   498 +
 .../apache/spark/sql/streaming/package-frame.html  |    45 +
 .../spark/sql/streaming/package-summary.html       |   284 +
 .../apache/spark/sql/streaming/package-tree.html   |   176 +
 .../org/apache/spark/sql/types/AnyDataType.html    |   236 +
 .../java/org/apache/spark/sql/types/ArrayType.html |   540 +
 .../org/apache/spark/sql/types/BinaryType.html     |   334 +
 .../org/apache/spark/sql/types/BooleanType.html    |   338 +
 .../java/org/apache/spark/sql/types/ByteType.html  |   343 +
 .../spark/sql/types/CalendarIntervalType.html      |   347 +
 .../java/org/apache/spark/sql/types/CharType.html  |   496 +
 .../java/org/apache/spark/sql/types/DataType.html  |   484 +
 .../java/org/apache/spark/sql/types/DataTypes.html |   689 +
 .../java/org/apache/spark/sql/types/DateType.html  |   342 +
 .../sql/types/Decimal.DecimalAsIfIntegral$.html    |   584 +
 .../sql/types/Decimal.DecimalIsFractional$.html    |   565 +
 .../java/org/apache/spark/sql/types/Decimal.html   |  1234 +
 .../spark/sql/types/DecimalType.Expression$.html   |   312 +
 .../apache/spark/sql/types/DecimalType.Fixed$.html |   312 +
 .../org/apache/spark/sql/types/DecimalType.html    |   735 +
 .../org/apache/spark/sql/types/DoubleType.html     |   343 +
 .../java/org/apache/spark/sql/types/FloatType.html |   343 +
 .../org/apache/spark/sql/types/HiveStringType.html |   392 +
 .../org/apache/spark/sql/types/IntegerType.html    |   343 +
 .../java/org/apache/spark/sql/types/LongType.html  |   343 +
 .../java/org/apache/spark/sql/types/MapType.html   |   583 +
 .../java/org/apache/spark/sql/types/Metadata.html  |   517 +
 .../apache/spark/sql/types/MetadataBuilder.html    |   503 +
 .../java/org/apache/spark/sql/types/NullType.html  |   341 +
 .../org/apache/spark/sql/types/NumericType.html    |   382 +
 .../org/apache/spark/sql/types/ObjectType.html     |   546 +
 .../apache/spark/sql/types/SQLUserDefinedType.html |   220 +
 .../java/org/apache/spark/sql/types/ShortType.html |   343 +
 .../org/apache/spark/sql/types/StringType.html     |   338 +
 .../org/apache/spark/sql/types/StructField.html    |   507 +
 .../org/apache/spark/sql/types/StructType.html     |  3392 ++
 .../org/apache/spark/sql/types/TimestampType.html  |   339 +
 .../apache/spark/sql/types/UDTRegistration.html    |   328 +
 .../org/apache/spark/sql/types/VarcharType.html    |   496 +
 .../org/apache/spark/sql/types/package-frame.html  |    57 +
 .../apache/spark/sql/types/package-summary.html    |   353 +
 .../org/apache/spark/sql/types/package-tree.html   |   181 +
 .../spark/sql/util/ExecutionListenerManager.html   |   315 +
 .../spark/sql/util/QueryExecutionListener.html     |   276 +
 .../org/apache/spark/sql/util/SchemaUtils.html     |   343 +
 .../org/apache/spark/sql/util/package-frame.html   |    25 +
 .../org/apache/spark/sql/util/package-summary.html |   166 +
 .../org/apache/spark/sql/util/package-tree.html    |   140 +
 .../spark/sql/vectorized/ArrowColumnVector.html    |   664 +
 .../apache/spark/sql/vectorized/ColumnVector.html  |   746 +
 .../apache/spark/sql/vectorized/ColumnarArray.html |   704 +
 .../apache/spark/sql/vectorized/ColumnarBatch.html |   373 +
 .../apache/spark/sql/vectorized/ColumnarMap.html   |   351 +
 .../apache/spark/sql/vectorized/ColumnarRow.html   |   586 +
 .../apache/spark/sql/vectorized/package-frame.html |    25 +
 .../spark/sql/vectorized/package-summary.html      |   172 +
 .../apache/spark/sql/vectorized/package-tree.html  |   155 +
 .../org/apache/spark/status/AppStatusUtils.html    |   322 +
 .../api/java/org/apache/spark/status/KVUtils.html  |   309 +
 .../org/apache/spark/status/LiveEntityHelpers.html |   393 +
 .../java/org/apache/spark/status/LiveExecutor.html |   691 +
 .../spark/status/LiveExecutorStageSummary.html     |   368 +
 .../api/java/org/apache/spark/status/LiveJob.html  |   491 +
 .../api/java/org/apache/spark/status/LiveRDD.html  |   442 +
 .../apache/spark/status/LiveRDDDistribution.html   |   347 +
 .../org/apache/spark/status/LiveRDDPartition.html  |   366 +
 .../java/org/apache/spark/status/LiveStage.html    |   572 +
 .../api/java/org/apache/spark/status/LiveTask.html |   342 +
 .../org/apache/spark/status/RDDPartitionSeq.html   |   471 +
 .../org/apache/spark/status/SchedulerPool.html     |   299 +
 .../org/apache/spark/status/TaskIndexNames.html    |   765 +
 .../spark/status/api/v1/AccumulableInfo.html       |   274 +
 .../status/api/v1/ApplicationAttemptInfo.html      |   466 +
 .../status/api/v1/ApplicationEnvironmentInfo.html  |   274 +
 .../spark/status/api/v1/ApplicationInfo.html       |   414 +
 .../spark/status/api/v1/ApplicationStatus.html     |   352 +
 .../spark/status/api/v1/ExecutorStageSummary.html  |   417 +
 .../spark/status/api/v1/ExecutorSummary.html       |   547 +
 .../status/api/v1/InputMetricDistributions.html    |   248 +
 .../apache/spark/status/api/v1/InputMetrics.html   |   248 +
 .../org/apache/spark/status/api/v1/JobData.html    |   482 +
 .../apache/spark/status/api/v1/MemoryMetrics.html  |   274 +
 .../status/api/v1/OutputMetricDistributions.html   |   248 +
 .../apache/spark/status/api/v1/OutputMetrics.html  |   248 +
 .../spark/status/api/v1/RDDDataDistribution.html   |   326 +
 .../spark/status/api/v1/RDDPartitionInfo.html      |   287 +
 .../apache/spark/status/api/v1/RDDStorageInfo.html |   339 +
 .../apache/spark/status/api/v1/RuntimeInfo.html    |   261 +
 .../api/v1/ShuffleReadMetricDistributions.html     |   326 +
 .../spark/status/api/v1/ShuffleReadMetrics.html    |   313 +
 .../api/v1/ShuffleWriteMetricDistributions.html    |   261 +
 .../spark/status/api/v1/ShuffleWriteMetrics.html   |   261 +
 .../org/apache/spark/status/api/v1/StackTrace.html |   417 +
 .../org/apache/spark/status/api/v1/StageData.html  |   664 +
 .../apache/spark/status/api/v1/StageStatus.html    |   388 +
 .../org/apache/spark/status/api/v1/TaskData.html   |   404 +
 .../status/api/v1/TaskMetricDistributions.html     |   443 +
 .../apache/spark/status/api/v1/TaskMetrics.html    |   404 +
 .../apache/spark/status/api/v1/TaskSorting.html    |   364 +
 .../spark/status/api/v1/ThreadStackTrace.html      |   460 +
 .../status/api/v1/UIRootFromServletContext.html    |   284 +
 .../apache/spark/status/api/v1/VersionInfo.html    |   235 +
 .../apache/spark/status/api/v1/package-frame.html  |    53 +
 .../spark/status/api/v1/package-summary.html       |   271 +
 .../apache/spark/status/api/v1/package-tree.html   |   176 +
 .../spark/status/api/v1/streaming/BatchInfo.html   |   391 +
 .../spark/status/api/v1/streaming/BatchStatus.html |   364 +
 .../api/v1/streaming/OutputOperationInfo.html      |   326 +
 .../status/api/v1/streaming/ReceiverInfo.html      |   352 +
 .../api/v1/streaming/StreamingStatistics.html      |   404 +
 .../status/api/v1/streaming/package-frame.html     |    27 +
 .../status/api/v1/streaming/package-summary.html   |   167 +
 .../status/api/v1/streaming/package-tree.html      |   150 +
 .../api/java/org/apache/spark/status/config.html   |   360 +
 .../org/apache/spark/status/package-frame.html     |    34 +
 .../org/apache/spark/status/package-summary.html   |   200 +
 .../java/org/apache/spark/status/package-tree.html |   149 +
 .../spark/storage/BasicBlockReplicationPolicy.html |   310 +
 .../api/java/org/apache/spark/storage/BlockId.html |   494 +
 .../org/apache/spark/storage/BlockManagerId.html   |   484 +
 ...ckManagerMessages.BlockLocationsAndStatus$.html |   306 +
 ...ockManagerMessages.BlockLocationsAndStatus.html |   311 +
 ...lockManagerMessages.BlockManagerHeartbeat$.html |   306 +
 ...BlockManagerMessages.BlockManagerHeartbeat.html |   296 +
 .../BlockManagerMessages.GetBlockStatus$.html      |   306 +
 .../BlockManagerMessages.GetBlockStatus.html       |   311 +
 ...ockManagerMessages.GetExecutorEndpointRef$.html |   306 +
 ...lockManagerMessages.GetExecutorEndpointRef.html |   296 +
 .../BlockManagerMessages.GetLocations$.html        |   306 +
 .../storage/BlockManagerMessages.GetLocations.html |   296 +
 ...lockManagerMessages.GetLocationsAndStatus$.html |   306 +
 ...BlockManagerMessages.GetLocationsAndStatus.html |   296 +
 ...agerMessages.GetLocationsMultipleBlockIds$.html |   306 +
 ...nagerMessages.GetLocationsMultipleBlockIds.html |   296 +
 .../BlockManagerMessages.GetMatchingBlockIds$.html |   306 +
 .../BlockManagerMessages.GetMatchingBlockIds.html  |   311 +
 .../BlockManagerMessages.GetMemoryStatus$.html     |   301 +
 .../storage/BlockManagerMessages.GetPeers$.html    |   306 +
 .../storage/BlockManagerMessages.GetPeers.html     |   296 +
 .../BlockManagerMessages.GetStorageStatus$.html    |   301 +
 .../BlockManagerMessages.HasCachedBlocks$.html     |   306 +
 .../BlockManagerMessages.HasCachedBlocks.html      |   296 +
 ...BlockManagerMessages.RegisterBlockManager$.html |   306 +
 .../BlockManagerMessages.RegisterBlockManager.html |   341 +
 .../storage/BlockManagerMessages.RemoveBlock$.html |   306 +
 .../storage/BlockManagerMessages.RemoveBlock.html  |   296 +
 .../BlockManagerMessages.RemoveBroadcast$.html     |   306 +
 .../BlockManagerMessages.RemoveBroadcast.html      |   311 +
 .../BlockManagerMessages.RemoveExecutor$.html      |   306 +
 .../BlockManagerMessages.RemoveExecutor.html       |   296 +
 .../storage/BlockManagerMessages.RemoveRdd$.html   |   306 +
 .../storage/BlockManagerMessages.RemoveRdd.html    |   296 +
 .../BlockManagerMessages.RemoveShuffle$.html       |   306 +
 .../BlockManagerMessages.RemoveShuffle.html        |   296 +
 .../BlockManagerMessages.ReplicateBlock$.html      |   306 +
 .../BlockManagerMessages.ReplicateBlock.html       |   326 +
 ...ockManagerMessages.StopBlockManagerMaster$.html |   301 +
 .../BlockManagerMessages.ToBlockManagerMaster.html |   173 +
 .../BlockManagerMessages.ToBlockManagerSlave.html  |   173 +
 .../BlockManagerMessages.TriggerThreadDump$.html   |   302 +
 .../BlockManagerMessages.UpdateBlockInfo$.html     |   306 +
 .../BlockManagerMessages.UpdateBlockInfo.html      |   402 +
 .../apache/spark/storage/BlockManagerMessages.html |   420 +
 .../spark/storage/BlockNotFoundException.html      |   260 +
 .../spark/storage/BlockReplicationPolicy.html      |   252 +
 .../spark/storage/BlockReplicationUtils.html       |   286 +
 .../java/org/apache/spark/storage/BlockStatus.html |   426 +
 .../org/apache/spark/storage/BlockUpdatedInfo.html |   432 +
 .../org/apache/spark/storage/BroadcastBlockId.html |   483 +
 .../spark/storage/BufferReleasingInputStream.html  |   429 +
 .../spark/storage/CountingWritableChannel.html     |   329 +
 .../spark/storage/DefaultTopologyMapper.html       |   309 +
 .../org/apache/spark/storage/DiskBlockData.html    |   349 +
 .../spark/storage/FileBasedTopologyMapper.html     |   340 +
 .../java/org/apache/spark/storage/RDDBlockId.html  |   483 +
 .../api/java/org/apache/spark/storage/RDDInfo.html |   548 +
 .../storage/RandomBlockReplicationPolicy.html      |   307 +
 .../spark/storage/ReadableChannelFileRegion.html   |   364 +
 .../org/apache/spark/storage/ShuffleBlockId.html   |   498 +
 .../apache/spark/storage/ShuffleDataBlockId.html   |   498 +
 .../apache/spark/storage/ShuffleIndexBlockId.html  |   498 +
 .../org/apache/spark/storage/StorageLevel.html     |   780 +
 .../org/apache/spark/storage/StorageUtils.html     |   282 +
 .../org/apache/spark/storage/StreamBlockId.html    |   483 +
 .../apache/spark/storage/TaskResultBlockId.html    |   468 +
 .../spark/storage/TimeTrackingOutputStream.html    |   379 +
 .../org/apache/spark/storage/TopologyMapper.html   |   295 +
 .../apache/spark/storage/UnrecognizedBlockId.html  |   265 +
 .../storage/memory/DeserializedMemoryEntry.html    |   425 +
 .../storage/memory/DeserializedValuesHolder.html   |   350 +
 .../apache/spark/storage/memory/MemoryEntry.html   |   249 +
 .../spark/storage/memory/MemoryEntryBuilder.html   |   232 +
 .../storage/memory/SerializedMemoryEntry.html      |   425 +
 .../storage/memory/SerializedValuesHolder.html     |   384 +
 .../apache/spark/storage/memory/ValuesHolder.html  |   261 +
 .../apache/spark/storage/memory/package-frame.html |    29 +
 .../spark/storage/memory/package-summary.html      |   179 +
 .../apache/spark/storage/memory/package-tree.html  |   144 +
 .../org/apache/spark/storage/package-frame.html    |    96 +
 .../org/apache/spark/storage/package-summary.html  |   475 +
 .../org/apache/spark/storage/package-tree.html     |   262 +
 .../apache/spark/streaming/CheckpointReader.html   |   314 +
 .../java/org/apache/spark/streaming/Duration.html  |   569 +
 .../java/org/apache/spark/streaming/Durations.html |   313 +
 .../org/apache/spark/streaming/Milliseconds.html   |   271 +
 .../java/org/apache/spark/streaming/Minutes.html   |   271 +
 .../java/org/apache/spark/streaming/Seconds.html   |   271 +
 .../api/java/org/apache/spark/streaming/State.html |   462 +
 .../java/org/apache/spark/streaming/StateSpec.html |   537 +
 .../apache/spark/streaming/StreamingContext.html   |  1232 +
 .../streaming/StreamingContextPythonHelper.html    |   278 +
 .../spark/streaming/StreamingContextState.html     |   365 +
 .../api/java/org/apache/spark/streaming/Time.html  |   592 +
 .../spark/streaming/api/java/JavaDStream.html      |   973 +
 .../spark/streaming/api/java/JavaDStreamLike.html  |  1029 +
 .../spark/streaming/api/java/JavaInputDStream.html |   938 +
 .../api/java/JavaMapWithStateDStream.html          |   274 +
 .../spark/streaming/api/java/JavaPairDStream.html  |  2427 +
 .../streaming/api/java/JavaPairInputDStream.html   |  1767 +
 .../api/java/JavaPairReceiverInputDStream.html     |  1796 +
 .../api/java/JavaReceiverInputDStream.html         |   960 +
 .../streaming/api/java/JavaStreamingContext.html   |  1449 +
 .../spark/streaming/api/java/package-frame.html    |    31 +
 .../spark/streaming/api/java/package-summary.html  |   216 +
 .../spark/streaming/api/java/package-tree.html     |   166 +
 .../streaming/dstream/ConstantInputDStream.html    |   363 +
 .../apache/spark/streaming/dstream/DStream.html    |  1183 +
 .../spark/streaming/dstream/InputDStream.html      |   391 +
 .../streaming/dstream/MapWithStateDStream.html     |   314 +
 .../streaming/dstream/PairDStreamFunctions.html    |  1733 +
 .../streaming/dstream/ReceiverInputDStream.html    |   399 +
 .../spark/streaming/dstream/package-frame.html     |    25 +
 .../spark/streaming/dstream/package-summary.html   |   186 +
 .../spark/streaming/dstream/package-tree.html      |   146 +
 .../streaming/kinesis/DefaultCredentials.html      |   348 +
 .../KinesisInitialPositions.AtTimestamp.html       |   295 +
 .../kinesis/KinesisInitialPositions.Latest.html    |   282 +
 .../KinesisInitialPositions.TrimHorizon.html       |   282 +
 .../streaming/kinesis/KinesisInitialPositions.html |   310 +
 .../spark/streaming/kinesis/KinesisUtils.html      |   982 +
 .../kinesis/KinesisUtilsPythonHelper.html          |   308 +
 .../spark/streaming/kinesis/package-frame.html     |    26 +
 .../spark/streaming/kinesis/package-summary.html   |   169 +
 .../spark/streaming/kinesis/package-tree.html      |   141 +
 .../org/apache/spark/streaming/package-frame.html  |    34 +
 .../apache/spark/streaming/package-summary.html    |   223 +
 .../org/apache/spark/streaming/package-tree.html   |   157 +
 .../apache/spark/streaming/receiver/Receiver.html  |   780 +
 .../spark/streaming/receiver/StopReceiver.html     |   235 +
 .../spark/streaming/receiver/package-frame.html    |    21 +
 .../spark/streaming/receiver/package-summary.html  |   147 +
 .../spark/streaming/receiver/package-tree.html     |   136 +
 .../spark/streaming/scheduler/AllReceiverIds.html  |   336 +
 .../spark/streaming/scheduler/BatchInfo.html       |   541 +
 .../streaming/scheduler/GetAllReceiverInfo.html    |   334 +
 .../streaming/scheduler/OutputOperationInfo.html   |   489 +
 .../spark/streaming/scheduler/ReceiverInfo.html    |   477 +
 .../spark/streaming/scheduler/ReceiverState.html   |   361 +
 .../streaming/scheduler/StatsReportListener.html   |   450 +
 .../streaming/scheduler/StopAllReceivers.html      |   336 +
 .../spark/streaming/scheduler/StreamInputInfo.html |   440 +
 .../streaming/scheduler/StreamingListener.html     |   357 +
 .../scheduler/StreamingListenerBatchCompleted.html |   370 +
 .../scheduler/StreamingListenerBatchStarted.html   |   370 +
 .../scheduler/StreamingListenerBatchSubmitted.html |   370 +
 .../scheduler/StreamingListenerEvent.html          |   171 +
 .../StreamingListenerOutputOperationCompleted.html |   370 +
 .../StreamingListenerOutputOperationStarted.html   |   370 +
 .../scheduler/StreamingListenerReceiverError.html  |   370 +
 .../StreamingListenerReceiverStarted.html          |   370 +
 .../StreamingListenerReceiverStopped.html          |   370 +
 .../StreamingListenerStreamingStarted.html         |   370 +
 .../spark/streaming/scheduler/package-frame.html   |    42 +
 .../spark/streaming/scheduler/package-summary.html |   258 +
 .../spark/streaming/scheduler/package-tree.html    |   157 +
 .../org/apache/spark/streaming/ui/UIUtils.html     |   391 +
 .../apache/spark/streaming/ui/package-frame.html   |    20 +
 .../apache/spark/streaming/ui/package-summary.html |   140 +
 .../apache/spark/streaming/ui/package-tree.html    |   135 +
 .../org/apache/spark/streaming/util/HdfsUtils.html |   356 +
 .../apache/spark/streaming/util/RawTextHelper.html |   371 +
 .../apache/spark/streaming/util/RawTextSender.html |   271 +
 .../apache/spark/streaming/util/WriteAheadLog.html |   352 +
 .../streaming/util/WriteAheadLogRecordHandle.html  |   251 +
 .../spark/streaming/util/WriteAheadLogUtils.html   |   581 +
 .../apache/spark/streaming/util/package-frame.html |    25 +
 .../spark/streaming/util/package-summary.html      |   176 +
 .../apache/spark/streaming/util/package-tree.html  |   140 +
 .../apache/spark/ui/JettyUtils.ServletParams$.html |   278 +
 .../apache/spark/ui/JettyUtils.ServletParams.html  |   303 +
 .../api/java/org/apache/spark/ui/JettyUtils.html   |   573 +
 .../api/java/org/apache/spark/ui/ToolTips.html     |   516 +
 .../api/java/org/apache/spark/ui/UIUtils.html      |   738 +
 .../org/apache/spark/ui/UIWorkloadGenerator.html   |   298 +
 .../java/org/apache/spark/ui/jobs/ApiHelper.html   |   713 +
 .../spark/ui/jobs/TaskDetailsClassNames.html       |   352 +
 .../org/apache/spark/ui/jobs/package-frame.html    |    21 +
 .../org/apache/spark/ui/jobs/package-summary.html  |   146 +
 .../org/apache/spark/ui/jobs/package-tree.html     |   136 +
 .../java/org/apache/spark/ui/package-frame.html    |    25 +
 .../java/org/apache/spark/ui/package-summary.html  |   166 +
 .../api/java/org/apache/spark/ui/package-tree.html |   140 +
 .../spark/ui/storage/ExecutorStreamSummary.html    |   321 +
 .../org/apache/spark/ui/storage/package-frame.html |    20 +
 .../apache/spark/ui/storage/package-summary.html   |   140 +
 .../org/apache/spark/ui/storage/package-tree.html  |   135 +
 .../org/apache/spark/util/AccumulatorContext.html  |   380 +
 .../java/org/apache/spark/util/AccumulatorV2.html  |   496 +
 .../api/java/org/apache/spark/util/CausedBy.html   |   278 +
 .../spark/util/ChildFirstURLClassLoader.html       |   364 +
 .../java/org/apache/spark/util/ClosureCleaner.html |   287 +
 .../apache/spark/util/CollectionAccumulator.html   |   443 +
 .../org/apache/spark/util/CollectionsUtils.html    |   271 +
 .../org/apache/spark/util/DoubleAccumulator.html   |   507 +
 .../api/java/org/apache/spark/util/EnumUtil.html   |   271 +
 .../org/apache/spark/util/InnerClosureFinder.html  |   333 +
 .../api/java/org/apache/spark/util/IntParam.html   |   270 +
 .../java/org/apache/spark/util/JsonProtocol.html   |  1278 +
 .../spark/util/LegacyAccumulatorWrapper.html       |   421 +
 .../org/apache/spark/util/LongAccumulator.html     |   509 +
 .../java/org/apache/spark/util/MemoryParam.html    |   271 +
 .../org/apache/spark/util/MethodIdentifier.html    |   401 +
 .../java/org/apache/spark/util/MutablePair.html    |   469 +
 .../apache/spark/util/MutableURLClassLoader.html   |   313 +
 .../org/apache/spark/util/ParentClassLoader.html   |   311 +
 .../apache/spark/util/ReturnStatementFinder.html   |   465 +
 .../api/java/org/apache/spark/util/RpcUtils.html   |   364 +
 .../org/apache/spark/util/ShutdownHookManager.html |   464 +
 .../java/org/apache/spark/util/SignalUtils.html    |   301 +
 .../java/org/apache/spark/util/SizeEstimator.html  |   291 +
 .../java/org/apache/spark/util/SparkExitCode.html  |   314 +
 .../org/apache/spark/util/SparkShutdownHook.html   |   293 +
 .../java/org/apache/spark/util/StatCounter.html    |   579 +
 .../apache/spark/util/TaskCompletionListener.html  |   227 +
 .../org/apache/spark/util/TaskFailureListener.html |   230 +
 .../java/org/apache/spark/util/ThreadUtils.html    |   635 +
 .../api/java/org/apache/spark/util/Utils.html      |  3505 ++
 .../java/org/apache/spark/util/VersionUtils.html   |   326 +
 .../java/org/apache/spark/util/package-frame.html  |    54 +
 .../org/apache/spark/util/package-summary.html     |   338 +
 .../java/org/apache/spark/util/package-tree.html   |   195 +
 .../spark/util/random/BernoulliCellSampler.html    |   374 +
 .../apache/spark/util/random/BernoulliSampler.html |   350 +
 .../apache/spark/util/random/BinomialBounds.html   |   331 +
 .../apache/spark/util/random/PoissonBounds.html    |   303 +
 .../apache/spark/util/random/PoissonSampler.html   |   377 +
 .../org/apache/spark/util/random/Pseudorandom.html |   232 +
 .../apache/spark/util/random/RandomSampler.html    |   285 +
 .../apache/spark/util/random/SamplingUtils.html    |   336 +
 .../spark/util/random/StratifiedSamplingUtils.html |   488 +
 .../apache/spark/util/random/package-frame.html    |    31 +
 .../apache/spark/util/random/package-summary.html  |   215 +
 .../org/apache/spark/util/random/package-tree.html |   167 +
 .../spark/util/sketch/BloomFilter.Version.html     |   340 +
 .../org/apache/spark/util/sketch/BloomFilter.html  |   625 +
 .../spark/util/sketch/CountMinSketch.Version.html  |   350 +
 .../apache/spark/util/sketch/CountMinSketch.html   |   701 +
 .../util/sketch/IncompatibleMergeException.html    |   260 +
 .../apache/spark/util/sketch/package-frame.html    |    30 +
 .../apache/spark/util/sketch/package-summary.html  |   186 +
 .../org/apache/spark/util/sketch/package-tree.html |   158 +
 site/docs/2.4.3/api/java/overview-frame.html       |   139 +
 site/docs/2.4.3/api/java/overview-summary.html     |   652 +
 site/docs/2.4.3/api/java/overview-tree.html        |  2139 +
 site/docs/2.4.3/api/java/package-list              |   119 +
 site/docs/2.4.3/api/java/script.js                 |    30 +
 site/docs/2.4.3/api/java/serialized-form.html      | 17351 ++++++
 site/docs/2.4.3/api/java/stylesheet.css            |   627 +
 site/docs/2.4.3/api/python/_modules/index.html     |   101 +
 .../api/python/_modules/pyspark/accumulators.html  |   375 +
 .../api/python/_modules/pyspark/broadcast.html     |   277 +
 .../2.4.3/api/python/_modules/pyspark/conf.html    |   297 +
 .../2.4.3/api/python/_modules/pyspark/context.html |  1183 +
 .../2.4.3/api/python/_modules/pyspark/files.html   |   132 +
 .../2.4.3/api/python/_modules/pyspark/ml/base.html |   321 +
 .../python/_modules/pyspark/ml/classification.html |  2174 +
 .../api/python/_modules/pyspark/ml/clustering.html |  1494 +
 .../api/python/_modules/pyspark/ml/evaluation.html |   534 +
 .../api/python/_modules/pyspark/ml/feature.html    |  3974 ++
 .../2.4.3/api/python/_modules/pyspark/ml/fpm.html  |   433 +
 .../api/python/_modules/pyspark/ml/image.html      |   352 +
 .../api/python/_modules/pyspark/ml/linalg.html     |  1253 +
 .../api/python/_modules/pyspark/ml/param.html      |   595 +
 .../python/_modules/pyspark/ml/param/shared.html   |   902 +
 .../api/python/_modules/pyspark/ml/pipeline.html   |   474 +
 .../python/_modules/pyspark/ml/recommendation.html |   569 +
 .../api/python/_modules/pyspark/ml/regression.html |  1958 +
 .../2.4.3/api/python/_modules/pyspark/ml/stat.html |   498 +
 .../api/python/_modules/pyspark/ml/tuning.html     |   869 +
 .../2.4.3/api/python/_modules/pyspark/ml/util.html |   697 +
 .../api/python/_modules/pyspark/ml/wrapper.html    |   431 +
 .../_modules/pyspark/mllib/classification.html     |   855 +
 .../python/_modules/pyspark/mllib/clustering.html  |  1145 +
 .../api/python/_modules/pyspark/mllib/common.html  |   247 +
 .../python/_modules/pyspark/mllib/evaluation.html  |   640 +
 .../api/python/_modules/pyspark/mllib/feature.html |   910 +
 .../api/python/_modules/pyspark/mllib/fpm.html     |   290 +
 .../api/python/_modules/pyspark/mllib/linalg.html  |  1466 +
 .../_modules/pyspark/mllib/linalg/distributed.html |  1475 +
 .../api/python/_modules/pyspark/mllib/random.html  |   513 +
 .../_modules/pyspark/mllib/recommendation.html     |   418 +
 .../python/_modules/pyspark/mllib/regression.html  |   929 +
 .../_modules/pyspark/mllib/stat/KernelDensity.html |   143 +
 .../_modules/pyspark/mllib/stat/distribution.html  |   116 +
 .../python/_modules/pyspark/mllib/stat/test.html   |   166 +
 .../api/python/_modules/pyspark/mllib/tree.html    |   745 +
 .../api/python/_modules/pyspark/mllib/util.html    |   612 +
 .../api/python/_modules/pyspark/profiler.html      |   250 +
 .../2.4.3/api/python/_modules/pyspark/rdd.html     |  2642 +
 .../api/python/_modules/pyspark/serializers.html   |   865 +
 .../api/python/_modules/pyspark/sql/catalog.html   |   385 +
 .../api/python/_modules/pyspark/sql/column.html    |   787 +
 .../api/python/_modules/pyspark/sql/context.html   |   628 +
 .../api/python/_modules/pyspark/sql/dataframe.html |  2400 +
 .../api/python/_modules/pyspark/sql/functions.html |  3027 ++
 .../api/python/_modules/pyspark/sql/group.html     |   390 +
 .../python/_modules/pyspark/sql/readwriter.html    |  1090 +
 .../api/python/_modules/pyspark/sql/session.html   |   944 +
 .../api/python/_modules/pyspark/sql/streaming.html |  1218 +
 .../api/python/_modules/pyspark/sql/types.html     |  1956 +
 .../2.4.3/api/python/_modules/pyspark/sql/udf.html |   487 +
 .../api/python/_modules/pyspark/sql/window.html    |   314 +
 .../2.4.3/api/python/_modules/pyspark/status.html  |   169 +
 .../api/python/_modules/pyspark/storagelevel.html  |   144 +
 .../python/_modules/pyspark/streaming/context.html |   429 +
 .../python/_modules/pyspark/streaming/dstream.html |   720 +
 .../python/_modules/pyspark/streaming/flume.html   |   229 +
 .../python/_modules/pyspark/streaming/kafka.html   |   579 +
 .../python/_modules/pyspark/streaming/kinesis.html |   193 +
 .../_modules/pyspark/streaming/listener.html       |   154 +
 .../api/python/_modules/pyspark/taskcontext.html   |   298 +
 site/docs/2.4.3/api/python/_static/ajax-loader.gif |   Bin 0 -> 673 bytes
 site/docs/2.4.3/api/python/_static/basic.css       |   748 +
 .../2.4.3/api/python/_static/comment-bright.png    |   Bin 0 -> 756 bytes
 .../2.4.3/api/python/_static/comment-close.png     |   Bin 0 -> 829 bytes
 site/docs/2.4.3/api/python/_static/comment.png     |   Bin 0 -> 641 bytes
 site/docs/2.4.3/api/python/_static/doctools.js     |   314 +
 .../api/python/_static/documentation_options.js    |    10 +
 .../docs/2.4.3/api/python/_static/down-pressed.png |   Bin 0 -> 222 bytes
 site/docs/2.4.3/api/python/_static/down.png        |   Bin 0 -> 202 bytes
 site/docs/2.4.3/api/python/_static/file.png        |   Bin 0 -> 286 bytes
 site/docs/2.4.3/api/python/_static/jquery-3.1.0.js | 10074 ++++
 site/docs/2.4.3/api/python/_static/jquery-3.2.1.js | 10253 ++++
 site/docs/2.4.3/api/python/_static/jquery.js       |     4 +
 .../docs/2.4.3/api/python/_static/language_data.js |   297 +
 site/docs/2.4.3/api/python/_static/minus.png       |   Bin 0 -> 90 bytes
 site/docs/2.4.3/api/python/_static/nature.css      |   252 +
 site/docs/2.4.3/api/python/_static/plus.png        |   Bin 0 -> 90 bytes
 site/docs/2.4.3/api/python/_static/pygments.css    |    69 +
 site/docs/2.4.3/api/python/_static/pyspark.css     |    90 +
 site/docs/2.4.3/api/python/_static/pyspark.js      |    99 +
 site/docs/2.4.3/api/python/_static/searchtools.js  |   505 +
 .../2.4.3/api/python/_static/spark-logo-hd.png     |   Bin 0 -> 11306 bytes
 .../2.4.3/api/python/_static/underscore-1.3.1.js   |   999 +
 site/docs/2.4.3/api/python/_static/underscore.js   |    31 +
 site/docs/2.4.3/api/python/_static/up-pressed.png  |   Bin 0 -> 214 bytes
 site/docs/2.4.3/api/python/_static/up.png          |   Bin 0 -> 203 bytes
 site/docs/2.4.3/api/python/_static/websupport.js   |   808 +
 site/docs/2.4.3/api/python/index.html              |   179 +
 site/docs/2.4.3/api/python/objects.inv             |   Bin 0 -> 5617 bytes
 site/docs/2.4.3/api/python/pyspark.html            |  3040 ++
 site/docs/2.4.3/api/python/pyspark.ml.html         |   165 +
 site/docs/2.4.3/api/python/pyspark.mllib.html      |   151 +
 site/docs/2.4.3/api/python/pyspark.sql.html        | 11011 ++++
 site/docs/2.4.3/api/python/pyspark.streaming.html  |  1148 +
 site/docs/2.4.3/api/python/search.html             |    87 +
 site/docs/2.4.3/api/python/searchindex.js          |     1 +
 site/docs/2.4.3/api/scala/deprecated-list.html     |   188 +
 site/docs/2.4.3/api/scala/index.html               |   472 +
 site/docs/2.4.3/api/scala/index.js                 |     1 +
 site/docs/2.4.3/api/scala/index/index-_.html       |    83 +
 site/docs/2.4.3/api/scala/index/index-a.html       |   500 +
 site/docs/2.4.3/api/scala/index/index-b.html       |   341 +
 site/docs/2.4.3/api/scala/index/index-c.html       |   791 +
 site/docs/2.4.3/api/scala/index/index-d.html       |   512 +
 site/docs/2.4.3/api/scala/index/index-e.html       |   341 +
 site/docs/2.4.3/api/scala/index/index-f.html       |   434 +
 site/docs/2.4.3/api/scala/index/index-g.html       |   932 +
 site/docs/2.4.3/api/scala/index/index-h.html       |   266 +
 site/docs/2.4.3/api/scala/index/index-i.html       |   581 +
 site/docs/2.4.3/api/scala/index/index-j.html       |   215 +
 site/docs/2.4.3/api/scala/index/index-k.html       |   128 +
 site/docs/2.4.3/api/scala/index/index-l.html       |   449 +
 site/docs/2.4.3/api/scala/index/index-m.html       |   554 +
 site/docs/2.4.3/api/scala/index/index-n.html       |   464 +
 site/docs/2.4.3/api/scala/index/index-o.html       |   383 +
 site/docs/2.4.3/api/scala/index/index-p.html       |   515 +
 site/docs/2.4.3/api/scala/index/index-q.html       |    62 +
 site/docs/2.4.3/api/scala/index/index-r.html       |   731 +
 site/docs/2.4.3/api/scala/index/index-s.html       |  1967 +
 site/docs/2.4.3/api/scala/index/index-t.html       |   644 +
 site/docs/2.4.3/api/scala/index/index-u.html       |   263 +
 site/docs/2.4.3/api/scala/index/index-v.html       |   161 +
 site/docs/2.4.3/api/scala/index/index-w.html       |   218 +
 site/docs/2.4.3/api/scala/index/index-y.html       |    17 +
 site/docs/2.4.3/api/scala/index/index-z.html       |    35 +
 site/docs/2.4.3/api/scala/lib/arrow-down.png       |   Bin 0 -> 6232 bytes
 site/docs/2.4.3/api/scala/lib/arrow-right.png      |   Bin 0 -> 6220 bytes
 site/docs/2.4.3/api/scala/lib/class.png            |   Bin 0 -> 3357 bytes
 site/docs/2.4.3/api/scala/lib/class_big.png        |   Bin 0 -> 7516 bytes
 site/docs/2.4.3/api/scala/lib/class_diagram.png    |   Bin 0 -> 3910 bytes
 .../2.4.3/api/scala/lib/class_to_object_big.png    |   Bin 0 -> 9006 bytes
 site/docs/2.4.3/api/scala/lib/constructorsbg.gif   |   Bin 0 -> 1206 bytes
 site/docs/2.4.3/api/scala/lib/conversionbg.gif     |   Bin 0 -> 167 bytes
 site/docs/2.4.3/api/scala/lib/defbg-blue.gif       |   Bin 0 -> 1544 bytes
 site/docs/2.4.3/api/scala/lib/defbg-green.gif      |   Bin 0 -> 1341 bytes
 site/docs/2.4.3/api/scala/lib/diagrams.css         |   143 +
 site/docs/2.4.3/api/scala/lib/diagrams.js          |   324 +
 site/docs/2.4.3/api/scala/lib/filter_box_left.png  |   Bin 0 -> 1692 bytes
 site/docs/2.4.3/api/scala/lib/filter_box_left2.gif |   Bin 0 -> 1462 bytes
 site/docs/2.4.3/api/scala/lib/filter_box_right.png |   Bin 0 -> 1803 bytes
 site/docs/2.4.3/api/scala/lib/filterbg.gif         |   Bin 0 -> 1324 bytes
 site/docs/2.4.3/api/scala/lib/filterboxbarbg.gif   |   Bin 0 -> 1104 bytes
 site/docs/2.4.3/api/scala/lib/filterboxbarbg.png   |   Bin 0 -> 965 bytes
 site/docs/2.4.3/api/scala/lib/filterboxbg.gif      |   Bin 0 -> 1366 bytes
 site/docs/2.4.3/api/scala/lib/fullcommenttopbg.gif |   Bin 0 -> 1115 bytes
 site/docs/2.4.3/api/scala/lib/index.css            |   339 +
 site/docs/2.4.3/api/scala/lib/index.js             |   577 +
 site/docs/2.4.3/api/scala/lib/jquery-ui.js         |     6 +
 site/docs/2.4.3/api/scala/lib/jquery.js            |     2 +
 site/docs/2.4.3/api/scala/lib/jquery.layout.js     |  5486 ++
 site/docs/2.4.3/api/scala/lib/modernizr.custom.js  |     4 +
 site/docs/2.4.3/api/scala/lib/navigation-li-a.png  |   Bin 0 -> 1198 bytes
 site/docs/2.4.3/api/scala/lib/navigation-li.png    |   Bin 0 -> 2441 bytes
 site/docs/2.4.3/api/scala/lib/object.png           |   Bin 0 -> 3356 bytes
 site/docs/2.4.3/api/scala/lib/object_big.png       |   Bin 0 -> 7653 bytes
 site/docs/2.4.3/api/scala/lib/object_diagram.png   |   Bin 0 -> 3903 bytes
 .../2.4.3/api/scala/lib/object_to_class_big.png    |   Bin 0 -> 9158 bytes
 .../2.4.3/api/scala/lib/object_to_trait_big.png    |   Bin 0 -> 9200 bytes
 .../2.4.3/api/scala/lib/object_to_type_big.png     |   Bin 0 -> 9158 bytes
 site/docs/2.4.3/api/scala/lib/ownderbg2.gif        |   Bin 0 -> 1145 bytes
 site/docs/2.4.3/api/scala/lib/ownerbg.gif          |   Bin 0 -> 1118 bytes
 site/docs/2.4.3/api/scala/lib/ownerbg2.gif         |   Bin 0 -> 1145 bytes
 site/docs/2.4.3/api/scala/lib/package.png          |   Bin 0 -> 3335 bytes
 site/docs/2.4.3/api/scala/lib/package_big.png      |   Bin 0 -> 7312 bytes
 site/docs/2.4.3/api/scala/lib/packagesbg.gif       |   Bin 0 -> 1201 bytes
 site/docs/2.4.3/api/scala/lib/permalink.png        |   Bin 0 -> 943 bytes
 site/docs/2.4.3/api/scala/lib/ref-index.css        |    30 +
 site/docs/2.4.3/api/scala/lib/remove.png           |   Bin 0 -> 3186 bytes
 site/docs/2.4.3/api/scala/lib/scheduler.js         |    71 +
 .../2.4.3/api/scala/lib/selected-implicits.png     |   Bin 0 -> 1150 bytes
 .../api/scala/lib/selected-right-implicits.png     |   Bin 0 -> 646 bytes
 site/docs/2.4.3/api/scala/lib/selected-right.png   |   Bin 0 -> 1380 bytes
 site/docs/2.4.3/api/scala/lib/selected.png         |   Bin 0 -> 1864 bytes
 site/docs/2.4.3/api/scala/lib/selected2-right.png  |   Bin 0 -> 1434 bytes
 site/docs/2.4.3/api/scala/lib/selected2.png        |   Bin 0 -> 1965 bytes
 site/docs/2.4.3/api/scala/lib/signaturebg.gif      |   Bin 0 -> 1214 bytes
 site/docs/2.4.3/api/scala/lib/signaturebg2.gif     |   Bin 0 -> 1209 bytes
 site/docs/2.4.3/api/scala/lib/template.css         |   929 +
 site/docs/2.4.3/api/scala/lib/template.js          |   565 +
 site/docs/2.4.3/api/scala/lib/tools.tooltip.js     |    14 +
 site/docs/2.4.3/api/scala/lib/trait.png            |   Bin 0 -> 3374 bytes
 site/docs/2.4.3/api/scala/lib/trait_big.png        |   Bin 0 -> 7410 bytes
 site/docs/2.4.3/api/scala/lib/trait_diagram.png    |   Bin 0 -> 3882 bytes
 .../2.4.3/api/scala/lib/trait_to_object_big.png    |   Bin 0 -> 8967 bytes
 site/docs/2.4.3/api/scala/lib/type.png             |   Bin 0 -> 1445 bytes
 site/docs/2.4.3/api/scala/lib/type_big.png         |   Bin 0 -> 4236 bytes
 site/docs/2.4.3/api/scala/lib/type_diagram.png     |   Bin 0 -> 1841 bytes
 .../2.4.3/api/scala/lib/type_to_object_big.png     |   Bin 0 -> 4969 bytes
 site/docs/2.4.3/api/scala/lib/typebg.gif           |   Bin 0 -> 1206 bytes
 site/docs/2.4.3/api/scala/lib/unselected.png       |   Bin 0 -> 1879 bytes
 site/docs/2.4.3/api/scala/lib/valuemembersbg.gif   |   Bin 0 -> 1206 bytes
 site/docs/2.4.3/api/scala/org/apache/package.html  |   131 +
 .../api/scala/org/apache/spark/Accumulable.html    |   706 +
 .../scala/org/apache/spark/AccumulableParam.html   |   552 +
 .../api/scala/org/apache/spark/Accumulator.html    |   697 +
 .../AccumulatorParam$$DoubleAccumulatorParam$.html |   548 +
 .../AccumulatorParam$$FloatAccumulatorParam$.html  |   548 +
 .../AccumulatorParam$$IntAccumulatorParam$.html    |   548 +
 .../AccumulatorParam$$LongAccumulatorParam$.html   |   548 +
 .../scala/org/apache/spark/AccumulatorParam$.html  |   574 +
 .../scala/org/apache/spark/AccumulatorParam.html   |   557 +
 .../api/scala/org/apache/spark/Aggregator.html     |   549 +
 .../org/apache/spark/BarrierTaskContext$.html      |   525 +
 .../scala/org/apache/spark/BarrierTaskContext.html |  1121 +
 .../scala/org/apache/spark/BarrierTaskInfo.html    |   509 +
 .../org/apache/spark/ComplexFutureAction.html      |  1012 +
 .../api/scala/org/apache/spark/Dependency.html     |   534 +
 .../scala/org/apache/spark/ExceptionFailure.html   |   615 +
 .../org/apache/spark/ExecutorLostFailure.html      |   559 +
 .../api/scala/org/apache/spark/ExecutorPlugin.html |   516 +
 .../api/scala/org/apache/spark/FetchFailed.html    |   596 +
 .../api/scala/org/apache/spark/FutureAction.html   |   979 +
 .../scala/org/apache/spark/HashPartitioner.html    |   546 +
 .../org/apache/spark/InterruptibleIterator.html    |  2050 +
 .../scala/org/apache/spark/JobExecutionStatus.html |   570 +
 .../api/scala/org/apache/spark/JobSubmitter.html   |   510 +
 .../scala/org/apache/spark/NarrowDependency.html   |   554 +
 .../scala/org/apache/spark/OneToOneDependency.html |   549 +
 .../api/scala/org/apache/spark/Partition.html      |   508 +
 .../api/scala/org/apache/spark/Partitioner$.html   |   512 +
 .../api/scala/org/apache/spark/Partitioner.html    |   551 +
 .../scala/org/apache/spark/RangeDependency.html    |   548 +
 .../scala/org/apache/spark/RangePartitioner.html   |   580 +
 .../api/scala/org/apache/spark/Resubmitted$.html   |   506 +
 .../org/apache/spark/SerializableWritable.html     |   541 +
 .../scala/org/apache/spark/ShuffleDependency.html  |   654 +
 .../scala/org/apache/spark/SimpleFutureAction.html |   980 +
 .../api/scala/org/apache/spark/SparkConf.html      |  1510 +
 .../api/scala/org/apache/spark/SparkContext$.html  |   828 +
 .../api/scala/org/apache/spark/SparkContext.html   |  2859 +
 .../api/scala/org/apache/spark/SparkEnv$.html      |   775 +
 .../2.4.3/api/scala/org/apache/spark/SparkEnv.html |   991 +
 .../api/scala/org/apache/spark/SparkException.html |   732 +
 .../scala/org/apache/spark/SparkExecutorInfo.html  |   623 +
 .../api/scala/org/apache/spark/SparkFiles$.html    |   517 +
 .../org/apache/spark/SparkFirehoseListener.html    |   985 +
 .../api/scala/org/apache/spark/SparkJobInfo.html   |   538 +
 .../api/scala/org/apache/spark/SparkStageInfo.html |   623 +
 .../scala/org/apache/spark/SparkStatusTracker.html |   598 +
 .../2.4.3/api/scala/org/apache/spark/Success$.html |   463 +
 .../scala/org/apache/spark/TaskCommitDenied.html   |   557 +
 .../api/scala/org/apache/spark/TaskContext$.html   |   562 +
 .../api/scala/org/apache/spark/TaskContext.html    |   802 +
 .../api/scala/org/apache/spark/TaskEndReason.html  |   492 +
 .../scala/org/apache/spark/TaskFailedReason.html   |   534 +
 .../api/scala/org/apache/spark/TaskKilled.html     |   541 +
 .../org/apache/spark/TaskKilledException.html      |   753 +
 .../scala/org/apache/spark/TaskResultLost$.html    |   505 +
 .../api/scala/org/apache/spark/UnknownReason$.html |   505 +
 .../scala/org/apache/spark/WritableConverter$.html |   758 +
 .../scala/org/apache/spark/WritableFactory$.html   |   622 +
 .../org/apache/spark/api/java/JavaDoubleRDD$.html  |   522 +
 .../org/apache/spark/api/java/JavaDoubleRDD.html   |  2729 +
 .../apache/spark/api/java/JavaFutureAction.html    |   616 +
 .../org/apache/spark/api/java/JavaHadoopRDD.html   |  3987 ++
 .../apache/spark/api/java/JavaNewHadoopRDD.html    |  3987 ++
 .../org/apache/spark/api/java/JavaPairRDD$.html    |   539 +
 .../org/apache/spark/api/java/JavaPairRDD.html     |  3908 ++
 .../scala/org/apache/spark/api/java/JavaRDD$.html  |   522 +
 .../scala/org/apache/spark/api/java/JavaRDD.html   |  2429 +
 .../org/apache/spark/api/java/JavaRDDLike.html     |  1976 +
 .../apache/spark/api/java/JavaSparkContext$.html   |   557 +
 .../apache/spark/api/java/JavaSparkContext.html    |  2178 +
 .../spark/api/java/JavaSparkStatusTracker.html     |   580 +
 .../scala/org/apache/spark/api/java/Optional.html  |   569 +
 .../org/apache/spark/api/java/StorageLevels.html   |   502 +
 .../spark/api/java/function/CoGroupFunction.html   |   504 +
 .../api/java/function/DoubleFlatMapFunction.html   |   504 +
 .../spark/api/java/function/DoubleFunction.html    |   504 +
 .../spark/api/java/function/FilterFunction.html    |   504 +
 .../spark/api/java/function/FlatMapFunction.html   |   504 +
 .../spark/api/java/function/FlatMapFunction2.html  |   504 +
 .../api/java/function/FlatMapGroupsFunction.html   |   504 +
 .../function/FlatMapGroupsWithStateFunction.html   |   504 +
 .../spark/api/java/function/ForeachFunction.html   |   504 +
 .../java/function/ForeachPartitionFunction.html    |   504 +
 .../apache/spark/api/java/function/Function.html   |   504 +
 .../apache/spark/api/java/function/Function0.html  |   504 +
 .../apache/spark/api/java/function/Function2.html  |   504 +
 .../apache/spark/api/java/function/Function3.html  |   504 +
 .../apache/spark/api/java/function/Function4.html  |   504 +
 .../spark/api/java/function/MapFunction.html       |   504 +
 .../spark/api/java/function/MapGroupsFunction.html |   504 +
 .../java/function/MapGroupsWithStateFunction.html  |   504 +
 .../api/java/function/MapPartitionsFunction.html   |   504 +
 .../api/java/function/PairFlatMapFunction.html     |   504 +
 .../spark/api/java/function/PairFunction.html      |   504 +
 .../spark/api/java/function/ReduceFunction.html    |   504 +
 .../spark/api/java/function/VoidFunction.html      |   504 +
 .../spark/api/java/function/VoidFunction2.html     |   504 +
 .../apache/spark/api/java/function/package.html    |   538 +
 .../scala/org/apache/spark/api/java/package.html   |   422 +
 .../api/scala/org/apache/spark/api/package.html    |   118 +
 .../org/apache/spark/broadcast/Broadcast.html      |   946 +
 .../scala/org/apache/spark/broadcast/package.html  |   161 +
 .../api/scala/org/apache/spark/graphx/Edge$.html   |   488 +
 .../api/scala/org/apache/spark/graphx/Edge.html    |   556 +
 .../org/apache/spark/graphx/EdgeContext$.html      |   505 +
 .../scala/org/apache/spark/graphx/EdgeContext.html |   645 +
 .../org/apache/spark/graphx/EdgeDirection$.html    |   557 +
 .../org/apache/spark/graphx/EdgeDirection.html     |   508 +
 .../scala/org/apache/spark/graphx/EdgeRDD$.html    |   506 +
 .../api/scala/org/apache/spark/graphx/EdgeRDD.html |  2758 +
 .../scala/org/apache/spark/graphx/EdgeTriplet.html |   676 +
 .../api/scala/org/apache/spark/graphx/Graph$.html  |   572 +
 .../api/scala/org/apache/spark/graphx/Graph.html   |  1085 +
 .../org/apache/spark/graphx/GraphLoader$.html      |   771 +
 .../scala/org/apache/spark/graphx/GraphOps.html    |  1003 +
 .../org/apache/spark/graphx/GraphXUtils$.html      |   499 +
 ...rtitionStrategy$$CanonicalRandomVertexCut$.html |   478 +
 .../PartitionStrategy$$EdgePartition1D$.html       |   477 +
 .../PartitionStrategy$$EdgePartition2D$.html       |   504 +
 .../PartitionStrategy$$RandomVertexCut$.html       |   477 +
 .../apache/spark/graphx/PartitionStrategy$.html    |   608 +
 .../org/apache/spark/graphx/PartitionStrategy.html |   513 +
 .../api/scala/org/apache/spark/graphx/Pregel$.html |   806 +
 .../org/apache/spark/graphx/TripletFields.html     |   521 +
 .../scala/org/apache/spark/graphx/VertexRDD$.html  |   569 +
 .../scala/org/apache/spark/graphx/VertexRDD.html   |  3017 ++
 .../apache/spark/graphx/impl/EdgeActiveness.html   |   570 +
 .../org/apache/spark/graphx/impl/EdgeRDDImpl.html  |  2797 +
 .../org/apache/spark/graphx/impl/GraphImpl$.html   |   580 +
 .../org/apache/spark/graphx/impl/GraphImpl.html    |  1132 +
 .../apache/spark/graphx/impl/VertexRDDImpl.html    |  3009 ++
 .../org/apache/spark/graphx/impl/package.html      |   218 +
 .../spark/graphx/lib/ConnectedComponents$.html     |   524 +
 .../apache/spark/graphx/lib/LabelPropagation$.html |   505 +
 .../org/apache/spark/graphx/lib/PageRank$.html     |   871 +
 .../apache/spark/graphx/lib/SVDPlusPlus$$Conf.html |   642 +
 .../org/apache/spark/graphx/lib/SVDPlusPlus$.html  |   527 +
 .../apache/spark/graphx/lib/ShortestPaths$.html    |   528 +
 .../graphx/lib/StronglyConnectedComponents$.html   |   502 +
 .../apache/spark/graphx/lib/TriangleCount$.html    |   520 +
 .../scala/org/apache/spark/graphx/lib/package.html |   271 +
 .../api/scala/org/apache/spark/graphx/package.html |   621 +
 .../apache/spark/graphx/util/GraphGenerators$.html |   906 +
 .../org/apache/spark/graphx/util/package.html      |   145 +
 .../org/apache/spark/input/PortableDataStream.html |   603 +
 .../api/scala/org/apache/spark/input/package.html  |   120 +
 .../scala/org/apache/spark/internal/Logging.html   |   743 +
 ...ileCommitProtocol$$EmptyTaskCommitMessage$.html |   505 +
 .../io/FileCommitProtocol$$TaskCommitMessage.html  |   526 +
 .../spark/internal/io/FileCommitProtocol$.html     |   795 +
 .../spark/internal/io/FileCommitProtocol.html      |   719 +
 .../internal/io/HadoopMapRedCommitProtocol.html    |   985 +
 .../internal/io/HadoopMapReduceCommitProtocol.html |   993 +
 .../spark/internal/io/HadoopWriteConfigUtil.html   |   653 +
 .../org/apache/spark/internal/io/package.html      |   214 +
 .../scala/org/apache/spark/internal/package.html   |   141 +
 .../org/apache/spark/io/CompressionCodec.html      |   529 +
 .../org/apache/spark/io/LZ4CompressionCodec.html   |   546 +
 .../org/apache/spark/io/LZFCompressionCodec.html   |   545 +
 .../spark/io/NioBufferedFileInputStream.html       |   684 +
 .../org/apache/spark/io/ReadAheadInputStream.html  |   673 +
 .../apache/spark/io/SnappyCompressionCodec.html    |   563 +
 .../org/apache/spark/io/ZStdCompressionCodec.html  |   546 +
 .../api/scala/org/apache/spark/io/package.html     |   291 +
 .../apache/spark/launcher/AbstractLauncher.html    |   743 +
 .../apache/spark/launcher/InProcessLauncher.html   |   759 +
 .../org/apache/spark/launcher/SparkAppHandle.html  |   624 +
 .../org/apache/spark/launcher/SparkLauncher.html   |   946 +
 .../scala/org/apache/spark/launcher/package.html   |   169 +
 .../spark/mapred/SparkHadoopMapRedUtil$.html       |   761 +
 .../api/scala/org/apache/spark/mapred/package.html |   118 +
 .../scala/org/apache/spark/metrics/package.html    |   118 +
 .../spark/metrics/source/CodegenMetrics$.html      |   591 +
 .../spark/metrics/source/HiveCatalogMetrics$.html  |   712 +
 .../org/apache/spark/metrics/source/package.html   |   174 +
 .../api/scala/org/apache/spark/ml/Estimator.html   |  1379 +
 .../2.4.3/api/scala/org/apache/spark/ml/Model.html |  1401 +
 .../api/scala/org/apache/spark/ml/Pipeline$.html   |   544 +
 .../api/scala/org/apache/spark/ml/Pipeline.html    |  1571 +
 .../scala/org/apache/spark/ml/PipelineModel$.html  |   544 +
 .../scala/org/apache/spark/ml/PipelineModel.html   |  1475 +
 .../scala/org/apache/spark/ml/PipelineStage.html   |  1274 +
 .../scala/org/apache/spark/ml/PredictionModel.html |  1656 +
 .../api/scala/org/apache/spark/ml/Predictor.html   |  1608 +
 .../api/scala/org/apache/spark/ml/Transformer.html |  1348 +
 .../org/apache/spark/ml/UnaryTransformer.html      |  1514 +
 .../org/apache/spark/ml/attribute/Attribute$.html  |   512 +
 .../org/apache/spark/ml/attribute/Attribute.html   |   720 +
 .../apache/spark/ml/attribute/AttributeGroup$.html |   510 +
 .../apache/spark/ml/attribute/AttributeGroup.html  |   788 +
 .../apache/spark/ml/attribute/AttributeType$.html  |   573 +
 .../apache/spark/ml/attribute/AttributeType.html   |   507 +
 .../spark/ml/attribute/BinaryAttribute$.html       |   530 +
 .../apache/spark/ml/attribute/BinaryAttribute.html |   769 +
 .../spark/ml/attribute/NominalAttribute$.html      |   530 +
 .../spark/ml/attribute/NominalAttribute.html       |   929 +
 .../spark/ml/attribute/NumericAttribute$.html      |   530 +
 .../spark/ml/attribute/NumericAttribute.html       |   939 +
 .../spark/ml/attribute/UnresolvedAttribute$.html   |   717 +
 .../org/apache/spark/ml/attribute/package.html     |   439 +
 .../BinaryLogisticRegressionSummary.html           |  1135 +
 .../BinaryLogisticRegressionTrainingSummary.html   |  1184 +
 .../ml/classification/ClassificationModel.html     |  1764 +
 .../apache/spark/ml/classification/Classifier.html |  1704 +
 .../DecisionTreeClassificationModel$.html          |   544 +
 .../DecisionTreeClassificationModel.html           |  2649 +
 .../ml/classification/DecisionTreeClassifier$.html |   563 +
 .../ml/classification/DecisionTreeClassifier.html  |  2468 +
 .../ml/classification/GBTClassificationModel$.html |   544 +
 .../ml/classification/GBTClassificationModel.html  |  3106 ++
 .../spark/ml/classification/GBTClassifier$.html    |   563 +
 .../spark/ml/classification/GBTClassifier.html     |  2890 +
 .../apache/spark/ml/classification/LinearSVC$.html |   540 +
 .../apache/spark/ml/classification/LinearSVC.html  |  2308 +
 .../spark/ml/classification/LinearSVCModel$.html   |   544 +
 .../spark/ml/classification/LinearSVCModel.html    |  2215 +
 .../ml/classification/LogisticRegression$.html     |   540 +
 .../ml/classification/LogisticRegression.html      |  2948 ++
 .../classification/LogisticRegressionModel$.html   |   544 +
 .../ml/classification/LogisticRegressionModel.html |  2885 +
 .../classification/LogisticRegressionSummary.html  |   972 +
 .../LogisticRegressionTrainingSummary.html         |  1022 +
 .../MultilayerPerceptronClassificationModel$.html  |   544 +
 .../MultilayerPerceptronClassificationModel.html   |  2043 +
 .../MultilayerPerceptronClassifier$.html           |   540 +
 .../MultilayerPerceptronClassifier.html            |  2454 +
 .../spark/ml/classification/NaiveBayes$.html       |   540 +
 .../apache/spark/ml/classification/NaiveBayes.html |  2099 +
 .../spark/ml/classification/NaiveBayesModel$.html  |   544 +
 .../spark/ml/classification/NaiveBayesModel.html   |  2166 +
 .../apache/spark/ml/classification/OneVsRest$.html |   544 +
 .../apache/spark/ml/classification/OneVsRest.html  |  1970 +
 .../spark/ml/classification/OneVsRestModel$.html   |   544 +
 .../spark/ml/classification/OneVsRestModel.html    |  1868 +
 .../ProbabilisticClassificationModel.html          |  1951 +
 .../ml/classification/ProbabilisticClassifier.html |  1813 +
 .../RandomForestClassificationModel$.html          |   544 +
 .../RandomForestClassificationModel.html           |  2831 +
 .../ml/classification/RandomForestClassifier$.html |   586 +
 .../ml/classification/RandomForestClassifier.html  |  2657 +
 .../apache/spark/ml/classification/package.html    |  1086 +
 .../spark/ml/clustering/BisectingKMeans$.html      |   540 +
 .../spark/ml/clustering/BisectingKMeans.html       |  1959 +
 .../spark/ml/clustering/BisectingKMeansModel$.html |   538 +
 .../spark/ml/clustering/BisectingKMeansModel.html  |  1908 +
 .../ml/clustering/BisectingKMeansSummary.html      |   625 +
 .../spark/ml/clustering/ClusteringSummary.html     |   619 +
 .../spark/ml/clustering/DistributedLDAModel$.html  |   544 +
 .../spark/ml/clustering/DistributedLDAModel.html   |  2621 +
 .../spark/ml/clustering/GaussianMixture$.html      |   540 +
 .../spark/ml/clustering/GaussianMixture.html       |  1939 +
 .../spark/ml/clustering/GaussianMixtureModel$.html |   544 +
 .../spark/ml/clustering/GaussianMixtureModel.html  |  1942 +
 .../ml/clustering/GaussianMixtureSummary.html      |   697 +
 .../org/apache/spark/ml/clustering/KMeans$.html    |   540 +
 .../org/apache/spark/ml/clustering/KMeans.html     |  2080 +
 .../apache/spark/ml/clustering/KMeansModel$.html   |   544 +
 .../apache/spark/ml/clustering/KMeansModel.html    |  1999 +
 .../apache/spark/ml/clustering/KMeansSummary.html  |   650 +
 .../scala/org/apache/spark/ml/clustering/LDA$.html |   538 +
 .../scala/org/apache/spark/ml/clustering/LDA.html  |  2583 +
 .../org/apache/spark/ml/clustering/LDAModel.html   |  2477 +
 .../apache/spark/ml/clustering/LocalLDAModel$.html |   544 +
 .../apache/spark/ml/clustering/LocalLDAModel.html  |  2481 +
 .../ml/clustering/PowerIterationClustering$.html   |   540 +
 .../ml/clustering/PowerIterationClustering.html    |  1498 +
 .../org/apache/spark/ml/clustering/package.html    |   741 +
 .../evaluation/BinaryClassificationEvaluator$.html |   540 +
 .../evaluation/BinaryClassificationEvaluator.html  |  1342 +
 .../spark/ml/evaluation/ClusteringEvaluator$.html  |   540 +
 .../spark/ml/evaluation/ClusteringEvaluator.html   |  1415 +
 .../org/apache/spark/ml/evaluation/Evaluator.html  |  1059 +
 .../MulticlassClassificationEvaluator$.html        |   540 +
 .../MulticlassClassificationEvaluator.html         |  1342 +
 .../spark/ml/evaluation/RegressionEvaluator$.html  |   540 +
 .../spark/ml/evaluation/RegressionEvaluator.html   |  1341 +
 .../org/apache/spark/ml/evaluation/package.html    |   339 +
 .../org/apache/spark/ml/feature/Binarizer$.html    |   540 +
 .../org/apache/spark/ml/feature/Binarizer.html     |  1643 +
 .../ml/feature/BucketedRandomProjectionLSH$.html   |   540 +
 .../ml/feature/BucketedRandomProjectionLSH.html    |  1815 +
 .../feature/BucketedRandomProjectionLSHModel$.html |   544 +
 .../feature/BucketedRandomProjectionLSHModel.html  |  1817 +
 .../org/apache/spark/ml/feature/Bucketizer$.html   |   540 +
 .../org/apache/spark/ml/feature/Bucketizer.html    |  1962 +
 .../apache/spark/ml/feature/ChiSqSelector$.html    |   540 +
 .../org/apache/spark/ml/feature/ChiSqSelector.html |  2087 +
 .../spark/ml/feature/ChiSqSelectorModel$.html      |   544 +
 .../spark/ml/feature/ChiSqSelectorModel.html       |  1918 +
 .../apache/spark/ml/feature/CountVectorizer$.html  |   540 +
 .../apache/spark/ml/feature/CountVectorizer.html   |  1927 +
 .../spark/ml/feature/CountVectorizerModel$.html    |   544 +
 .../spark/ml/feature/CountVectorizerModel.html     |  1901 +
 .../scala/org/apache/spark/ml/feature/DCT$.html    |   540 +
 .../api/scala/org/apache/spark/ml/feature/DCT.html |  1673 +
 .../spark/ml/feature/ElementwiseProduct$.html      |   540 +
 .../spark/ml/feature/ElementwiseProduct.html       |  1670 +
 .../apache/spark/ml/feature/FeatureHasher$.html    |   540 +
 .../org/apache/spark/ml/feature/FeatureHasher.html |  1765 +
 .../org/apache/spark/ml/feature/HashingTF$.html    |   540 +
 .../org/apache/spark/ml/feature/HashingTF.html     |  1718 +
 .../scala/org/apache/spark/ml/feature/IDF$.html    |   540 +
 .../api/scala/org/apache/spark/ml/feature/IDF.html |  1680 +
 .../org/apache/spark/ml/feature/IDFModel$.html     |   544 +
 .../org/apache/spark/ml/feature/IDFModel.html      |  1658 +
 .../org/apache/spark/ml/feature/Imputer$.html      |   540 +
 .../scala/org/apache/spark/ml/feature/Imputer.html |  1732 +
 .../org/apache/spark/ml/feature/ImputerModel$.html |   544 +
 .../org/apache/spark/ml/feature/ImputerModel.html  |  1672 +
 .../apache/spark/ml/feature/IndexToString$.html    |   540 +
 .../org/apache/spark/ml/feature/IndexToString.html |  1643 +
 .../org/apache/spark/ml/feature/Interaction$.html  |   540 +
 .../org/apache/spark/ml/feature/Interaction.html   |  1576 +
 .../org/apache/spark/ml/feature/LabeledPoint.html  |   531 +
 .../org/apache/spark/ml/feature/MaxAbsScaler$.html |   540 +
 .../org/apache/spark/ml/feature/MaxAbsScaler.html  |  1623 +
 .../spark/ml/feature/MaxAbsScalerModel$.html       |   544 +
 .../apache/spark/ml/feature/MaxAbsScalerModel.html |  1621 +
 .../org/apache/spark/ml/feature/MinHashLSH$.html   |   540 +
 .../org/apache/spark/ml/feature/MinHashLSH.html    |  1754 +
 .../apache/spark/ml/feature/MinHashLSHModel$.html  |   544 +
 .../apache/spark/ml/feature/MinHashLSHModel.html   |  1780 +
 .../org/apache/spark/ml/feature/MinMaxScaler$.html |   540 +
 .../org/apache/spark/ml/feature/MinMaxScaler.html  |  1746 +
 .../spark/ml/feature/MinMaxScalerModel$.html       |   544 +
 .../apache/spark/ml/feature/MinMaxScalerModel.html |  1765 +
 .../scala/org/apache/spark/ml/feature/NGram$.html  |   540 +
 .../scala/org/apache/spark/ml/feature/NGram.html   |  1674 +
 .../org/apache/spark/ml/feature/Normalizer$.html   |   540 +
 .../org/apache/spark/ml/feature/Normalizer.html    |  1669 +
 .../apache/spark/ml/feature/OneHotEncoder$.html    |   540 +
 .../org/apache/spark/ml/feature/OneHotEncoder.html |  1651 +
 .../spark/ml/feature/OneHotEncoderEstimator$.html  |   540 +
 .../spark/ml/feature/OneHotEncoderEstimator.html   |  1771 +
 .../spark/ml/feature/OneHotEncoderModel$.html      |   544 +
 .../spark/ml/feature/OneHotEncoderModel.html       |  1761 +
 .../scala/org/apache/spark/ml/feature/PCA$.html    |   540 +
 .../api/scala/org/apache/spark/ml/feature/PCA.html |  1679 +
 .../org/apache/spark/ml/feature/PCAModel$.html     |   544 +
 .../org/apache/spark/ml/feature/PCAModel.html      |  1682 +
 .../spark/ml/feature/PolynomialExpansion$.html     |   548 +
 .../spark/ml/feature/PolynomialExpansion.html      |  1682 +
 .../spark/ml/feature/QuantileDiscretizer$.html     |   797 +
 .../spark/ml/feature/QuantileDiscretizer.html      |  1991 +
 .../org/apache/spark/ml/feature/RFormula$.html     |   540 +
 .../org/apache/spark/ml/feature/RFormula.html      |  1934 +
 .../apache/spark/ml/feature/RFormulaModel$.html    |   544 +
 .../org/apache/spark/ml/feature/RFormulaModel.html |  1762 +
 .../apache/spark/ml/feature/RegexTokenizer$.html   |   540 +
 .../apache/spark/ml/feature/RegexTokenizer.html    |  1888 +
 .../apache/spark/ml/feature/SQLTransformer$.html   |   540 +
 .../apache/spark/ml/feature/SQLTransformer.html    |  1530 +
 .../apache/spark/ml/feature/StandardScaler$.html   |   540 +
 .../apache/spark/ml/feature/StandardScaler.html    |  1742 +
 .../spark/ml/feature/StandardScalerModel$.html     |   544 +
 .../spark/ml/feature/StandardScalerModel.html      |  1716 +
 .../apache/spark/ml/feature/StopWordsRemover$.html |   566 +
 .../apache/spark/ml/feature/StopWordsRemover.html  |  1783 +
 .../apache/spark/ml/feature/StringIndexer$.html    |   540 +
 .../org/apache/spark/ml/feature/StringIndexer.html |  1767 +
 .../spark/ml/feature/StringIndexerModel$.html      |   544 +
 .../spark/ml/feature/StringIndexerModel.html       |  1786 +
 .../org/apache/spark/ml/feature/Tokenizer$.html    |   540 +
 .../org/apache/spark/ml/feature/Tokenizer.html     |  1605 +
 .../apache/spark/ml/feature/VectorAssembler$.html  |   540 +
 .../apache/spark/ml/feature/VectorAssembler.html   |  1642 +
 .../apache/spark/ml/feature/VectorIndexer$.html    |   540 +
 .../org/apache/spark/ml/feature/VectorIndexer.html |  1744 +
 .../spark/ml/feature/VectorIndexerModel$.html      |   544 +
 .../spark/ml/feature/VectorIndexerModel.html       |  1742 +
 .../apache/spark/ml/feature/VectorSizeHint$.html   |   542 +
 .../apache/spark/ml/feature/VectorSizeHint.html    |  1657 +
 .../org/apache/spark/ml/feature/VectorSlicer$.html |   540 +
 .../org/apache/spark/ml/feature/VectorSlicer.html  |  1718 +
 .../org/apache/spark/ml/feature/Word2Vec$.html     |   540 +
 .../org/apache/spark/ml/feature/Word2Vec.html      |  2105 +
 .../apache/spark/ml/feature/Word2VecModel$.html    |   544 +
 .../org/apache/spark/ml/feature/Word2VecModel.html |  2026 +
 .../scala/org/apache/spark/ml/feature/package.html |  2813 +
 .../scala/org/apache/spark/ml/fpm/FPGrowth$.html   |   540 +
 .../scala/org/apache/spark/ml/fpm/FPGrowth.html    |  1870 +
 .../org/apache/spark/ml/fpm/FPGrowthModel$.html    |   544 +
 .../org/apache/spark/ml/fpm/FPGrowthModel.html     |  1853 +
 .../scala/org/apache/spark/ml/fpm/PrefixSpan.html  |  1332 +
 .../api/scala/org/apache/spark/ml/fpm/package.html |   246 +
 .../org/apache/spark/ml/image/ImageSchema$.html    |   766 +
 .../scala/org/apache/spark/ml/image/package.html   |   129 +
 .../org/apache/spark/ml/linalg/DenseMatrix$.html   |   634 +
 .../org/apache/spark/ml/linalg/DenseMatrix.html    |  1133 +
 .../org/apache/spark/ml/linalg/DenseVector$.html   |   517 +
 .../org/apache/spark/ml/linalg/DenseVector.html    |   767 +
 .../org/apache/spark/ml/linalg/Matrices$.html      |   795 +
 .../scala/org/apache/spark/ml/linalg/Matrix.html   |  1100 +
 .../org/apache/spark/ml/linalg/SQLDataTypes$.html  |   526 +
 .../org/apache/spark/ml/linalg/SparseMatrix$.html  |   615 +
 .../org/apache/spark/ml/linalg/SparseMatrix.html   |  1186 +
 .../org/apache/spark/ml/linalg/SparseVector$.html  |   517 +
 .../org/apache/spark/ml/linalg/SparseVector.html   |   795 +
 .../scala/org/apache/spark/ml/linalg/Vector.html   |   768 +
 .../scala/org/apache/spark/ml/linalg/Vectors$.html |   683 +
 .../scala/org/apache/spark/ml/linalg/package.html  |   429 +
 .../api/scala/org/apache/spark/ml/package.html     |   744 +
 .../org/apache/spark/ml/param/BooleanParam.html    |   667 +
 .../spark/ml/param/DoubleArrayArrayParam.html      |   684 +
 .../apache/spark/ml/param/DoubleArrayParam.html    |   684 +
 .../org/apache/spark/ml/param/DoubleParam.html     |   701 +
 .../org/apache/spark/ml/param/FloatParam.html      |   701 +
 .../org/apache/spark/ml/param/IntArrayParam.html   |   684 +
 .../scala/org/apache/spark/ml/param/IntParam.html  |   701 +
 .../org/apache/spark/ml/param/JavaParams.html      |   971 +
 .../scala/org/apache/spark/ml/param/LongParam.html |   701 +
 .../api/scala/org/apache/spark/ml/param/Param.html |   704 +
 .../scala/org/apache/spark/ml/param/ParamMap$.html |   544 +
 .../scala/org/apache/spark/ml/param/ParamMap.html  |   845 +
 .../scala/org/apache/spark/ml/param/ParamPair.html |   518 +
 .../apache/spark/ml/param/ParamValidators$.html    |   670 +
 .../scala/org/apache/spark/ml/param/Params.html    |   940 +
 .../apache/spark/ml/param/StringArrayParam.html    |   684 +
 .../scala/org/apache/spark/ml/param/package.html   |   497 +
 .../spark/ml/param/shared/HasAggregationDepth.html |   990 +
 .../ml/param/shared/HasCheckpointInterval.html     |   989 +
 .../spark/ml/param/shared/HasCollectSubModels.html |   993 +
 .../spark/ml/param/shared/HasDistanceMeasure.html  |   989 +
 .../spark/ml/param/shared/HasElasticNetParam.html  |   989 +
 .../spark/ml/param/shared/HasFeaturesCol.html      |   992 +
 .../spark/ml/param/shared/HasFitIntercept.html     |   989 +
 .../spark/ml/param/shared/HasHandleInvalid.html    |   992 +
 .../apache/spark/ml/param/shared/HasInputCol.html  |   992 +
 .../apache/spark/ml/param/shared/HasInputCols.html |   992 +
 .../apache/spark/ml/param/shared/HasLabelCol.html  |   992 +
 .../org/apache/spark/ml/param/shared/HasLoss.html  |   989 +
 .../apache/spark/ml/param/shared/HasMaxIter.html   |   989 +
 .../apache/spark/ml/param/shared/HasOutputCol.html |   992 +
 .../spark/ml/param/shared/HasOutputCols.html       |   992 +
 .../spark/ml/param/shared/HasPredictionCol.html    |   992 +
 .../spark/ml/param/shared/HasProbabilityCol.html   |   989 +
 .../spark/ml/param/shared/HasRawPredictionCol.html |   992 +
 .../apache/spark/ml/param/shared/HasRegParam.html  |   989 +
 .../org/apache/spark/ml/param/shared/HasSeed.html  |   992 +
 .../apache/spark/ml/param/shared/HasSolver.html    |   989 +
 .../spark/ml/param/shared/HasStandardization.html  |   989 +
 .../apache/spark/ml/param/shared/HasStepSize.html  |   989 +
 .../apache/spark/ml/param/shared/HasThreshold.html |   989 +
 .../spark/ml/param/shared/HasThresholds.html       |   989 +
 .../org/apache/spark/ml/param/shared/HasTol.html   |   989 +
 .../ml/param/shared/HasValidationIndicatorCol.html |   989 +
 .../spark/ml/param/shared/HasVarianceCol.html      |   989 +
 .../apache/spark/ml/param/shared/HasWeightCol.html |   989 +
 .../org/apache/spark/ml/param/shared/package.html  |   741 +
 .../spark/ml/recommendation/ALS$$Rating.html       |   515 +
 .../org/apache/spark/ml/recommendation/ALS$.html   |   865 +
 .../org/apache/spark/ml/recommendation/ALS.html    |  2577 +
 .../apache/spark/ml/recommendation/ALSModel$.html  |   544 +
 .../apache/spark/ml/recommendation/ALSModel.html   |  1894 +
 .../apache/spark/ml/recommendation/package.html    |   220 +
 .../ml/regression/AFTSurvivalRegression$.html      |   540 +
 .../spark/ml/regression/AFTSurvivalRegression.html |  2173 +
 .../ml/regression/AFTSurvivalRegressionModel$.html |   544 +
 .../ml/regression/AFTSurvivalRegressionModel.html  |  2094 +
 .../regression/DecisionTreeRegressionModel$.html   |   544 +
 .../ml/regression/DecisionTreeRegressionModel.html |  2397 +
 .../ml/regression/DecisionTreeRegressor$.html      |   557 +
 .../spark/ml/regression/DecisionTreeRegressor.html |  2314 +
 .../spark/ml/regression/GBTRegressionModel$.html   |   544 +
 .../spark/ml/regression/GBTRegressionModel.html    |  2782 +
 .../apache/spark/ml/regression/GBTRegressor$.html  |   563 +
 .../apache/spark/ml/regression/GBTRegressor.html   |  2679 +
 .../regression/GeneralizedLinearRegression$.html   |   540 +
 .../ml/regression/GeneralizedLinearRegression.html |  2555 +
 .../GeneralizedLinearRegressionModel$.html         |   544 +
 .../GeneralizedLinearRegressionModel.html          |  2375 +
 .../GeneralizedLinearRegressionSummary.html        |   830 +
 ...GeneralizedLinearRegressionTrainingSummary.html |   956 +
 .../spark/ml/regression/IsotonicRegression$.html   |   540 +
 .../spark/ml/regression/IsotonicRegression.html    |  1877 +
 .../ml/regression/IsotonicRegressionModel$.html    |   544 +
 .../ml/regression/IsotonicRegressionModel.html     |  1829 +
 .../spark/ml/regression/LinearRegression$.html     |   567 +
 .../spark/ml/regression/LinearRegression.html      |  2463 +
 .../ml/regression/LinearRegressionModel$.html      |   544 +
 .../spark/ml/regression/LinearRegressionModel.html |  2280 +
 .../ml/regression/LinearRegressionSummary.html     |   872 +
 .../LinearRegressionTrainingSummary.html           |   916 +
 .../regression/RandomForestRegressionModel$.html   |   544 +
 .../ml/regression/RandomForestRegressionModel.html |  2509 +
 .../ml/regression/RandomForestRegressor$.html      |   586 +
 .../spark/ml/regression/RandomForestRegressor.html |  2444 +
 .../spark/ml/regression/RegressionModel.html       |  1655 +
 .../org/apache/spark/ml/regression/package.html    |   968 +
 .../spark/ml/source/image/ImageDataSource.html     |   498 +
 .../org/apache/spark/ml/source/image/package.html  |   134 +
 .../spark/ml/source/libsvm/LibSVMDataSource.html   |   500 +
 .../org/apache/spark/ml/source/libsvm/package.html |   136 +
 .../scala/org/apache/spark/ml/source/package.html  |   135 +
 .../org/apache/spark/ml/stat/ChiSquareTest$.html   |   521 +
 .../org/apache/spark/ml/stat/Correlation$.html     |   555 +
 .../spark/ml/stat/KolmogorovSmirnovTest$.html      |   580 +
 .../org/apache/spark/ml/stat/Summarizer$.html      |  1151 +
 .../org/apache/spark/ml/stat/SummaryBuilder.html   |   542 +
 .../ml/stat/distribution/MultivariateGaussian.html |   621 +
 .../apache/spark/ml/stat/distribution/package.html |   131 +
 .../scala/org/apache/spark/ml/stat/package.html    |   266 +
 .../org/apache/spark/ml/tree/CategoricalSplit.html |   562 +
 .../org/apache/spark/ml/tree/ContinuousSplit.html  |   524 +
 .../org/apache/spark/ml/tree/InternalNode.html     |   591 +
 .../scala/org/apache/spark/ml/tree/LeafNode.html   |   522 +
 .../api/scala/org/apache/spark/ml/tree/Node.html   |   527 +
 .../api/scala/org/apache/spark/ml/tree/Split.html  |   511 +
 .../scala/org/apache/spark/ml/tree/package.html    |   204 +
 .../apache/spark/ml/tuning/CrossValidator$.html    |   544 +
 .../org/apache/spark/ml/tuning/CrossValidator.html |  1965 +
 ...sValidatorModel$$CrossValidatorModelWriter.html |   985 +
 .../spark/ml/tuning/CrossValidatorModel$.html      |   570 +
 .../spark/ml/tuning/CrossValidatorModel.html       |  1777 +
 .../apache/spark/ml/tuning/ParamGridBuilder.html   |   733 +
 .../spark/ml/tuning/TrainValidationSplit$.html     |   544 +
 .../spark/ml/tuning/TrainValidationSplit.html      |  1964 +
 ...plitModel$$TrainValidationSplitModelWriter.html |   985 +
 .../ml/tuning/TrainValidationSplitModel$.html      |   570 +
 .../spark/ml/tuning/TrainValidationSplitModel.html |  1771 +
 .../scala/org/apache/spark/ml/tuning/package.html  |   329 +
 .../spark/ml/util/DefaultParamsReadable.html       |   537 +
 .../spark/ml/util/DefaultParamsWritable.html       |   542 +
 .../apache/spark/ml/util/GeneralMLWritable.html    |   552 +
 .../org/apache/spark/ml/util/GeneralMLWriter.html  |  1036 +
 .../org/apache/spark/ml/util/Identifiable$.html    |   505 +
 .../org/apache/spark/ml/util/Identifiable.html     |   512 +
 .../org/apache/spark/ml/util/MLFormatRegister.html |   573 +
 .../scala/org/apache/spark/ml/util/MLReadable.html |   543 +
 .../scala/org/apache/spark/ml/util/MLReader.html   |   630 +
 .../scala/org/apache/spark/ml/util/MLWritable.html |   548 +
 .../scala/org/apache/spark/ml/util/MLWriter.html   |  1016 +
 .../org/apache/spark/ml/util/MLWriterFormat.html   |   521 +
 .../scala/org/apache/spark/ml/util/package.html    |   400 +
 .../scala/org/apache/spark/mllib/JavaPackage.html  |   482 +
 .../mllib/classification/ClassificationModel.html  |   571 +
 .../classification/LogisticRegressionModel$.html   |   520 +
 .../classification/LogisticRegressionModel.html    |   964 +
 .../LogisticRegressionWithLBFGS.html               |  1106 +
 .../classification/LogisticRegressionWithSGD$.html |   603 +
 .../classification/LogisticRegressionWithSGD.html  |  1088 +
 .../spark/mllib/classification/NaiveBayes$.html    |   582 +
 .../spark/mllib/classification/NaiveBayes.html     |   923 +
 .../mllib/classification/NaiveBayesModel$.html     |   514 +
 .../mllib/classification/NaiveBayesModel.html      |   756 +
 .../spark/mllib/classification/SVMModel$.html      |   520 +
 .../spark/mllib/classification/SVMModel.html       |   881 +
 .../spark/mllib/classification/SVMWithSGD$.html    |   601 +
 .../spark/mllib/classification/SVMWithSGD.html     |  1084 +
 .../StreamingLogisticRegressionWithSGD.html        |  1109 +
 .../apache/spark/mllib/classification/package.html |   494 +
 .../spark/mllib/clustering/BisectingKMeans.html    |  1068 +
 .../mllib/clustering/BisectingKMeansModel$.html    |   520 +
 .../mllib/clustering/BisectingKMeansModel.html     |  1034 +
 .../spark/mllib/clustering/DistanceMeasure$.html   |   538 +
 .../mllib/clustering/DistributedLDAModel$.html     |   519 +
 .../mllib/clustering/DistributedLDAModel.html      |   993 +
 .../spark/mllib/clustering/EMLDAOptimizer.html     |   567 +
 .../spark/mllib/clustering/GaussianMixture.html    |   833 +
 .../mllib/clustering/GaussianMixtureModel$.html    |   520 +
 .../mllib/clustering/GaussianMixtureModel.html     |   767 +
 .../org/apache/spark/mllib/clustering/KMeans$.html |   700 +
 .../org/apache/spark/mllib/clustering/KMeans.html  |  1237 +
 .../spark/mllib/clustering/KMeansModel$.html       |   520 +
 .../apache/spark/mllib/clustering/KMeansModel.html |   902 +
 .../org/apache/spark/mllib/clustering/LDA.html     |  1421 +
 .../apache/spark/mllib/clustering/LDAModel.html    |   736 +
 .../spark/mllib/clustering/LDAOptimizer.html       |   495 +
 .../spark/mllib/clustering/LocalLDAModel$.html     |   521 +
 .../spark/mllib/clustering/LocalLDAModel.html      |   987 +
 .../spark/mllib/clustering/OnlineLDAOptimizer.html |   980 +
 .../PowerIterationClustering$$Assignment.html      |   499 +
 .../clustering/PowerIterationClustering$.html      |   777 +
 .../mllib/clustering/PowerIterationClustering.html |   684 +
 .../clustering/PowerIterationClusteringModel$.html |   520 +
 .../clustering/PowerIterationClusteringModel.html  |   611 +
 .../spark/mllib/clustering/StreamingKMeans.html    |  1185 +
 .../mllib/clustering/StreamingKMeansModel.html     |  1186 +
 .../org/apache/spark/mllib/clustering/package.html |   815 +
 .../evaluation/BinaryClassificationMetrics.html    |  1112 +
 .../spark/mllib/evaluation/MulticlassMetrics.html  |   982 +
 .../spark/mllib/evaluation/MultilabelMetrics.html  |   842 +
 .../spark/mllib/evaluation/RankingMetrics$.html    |   511 +
 .../spark/mllib/evaluation/RankingMetrics.html     |   848 +
 .../spark/mllib/evaluation/RegressionMetrics.html  |   925 +
 .../org/apache/spark/mllib/evaluation/package.html |   240 +
 .../apache/spark/mllib/feature/ChiSqSelector.html  |   818 +
 .../spark/mllib/feature/ChiSqSelectorModel$.html   |   514 +
 .../spark/mllib/feature/ChiSqSelectorModel.html    |   685 +
 .../spark/mllib/feature/ElementwiseProduct.html    |   617 +
 .../org/apache/spark/mllib/feature/HashingTF$.html |   488 +
 .../org/apache/spark/mllib/feature/HashingTF.html  |   727 +
 .../scala/org/apache/spark/mllib/feature/IDF.html  |   614 +
 .../org/apache/spark/mllib/feature/IDFModel.html   |   590 +
 .../org/apache/spark/mllib/feature/Normalizer.html |   617 +
 .../scala/org/apache/spark/mllib/feature/PCA.html  |   586 +
 .../org/apache/spark/mllib/feature/PCAModel.html   |   637 +
 .../apache/spark/mllib/feature/StandardScaler.html |   823 +
 .../spark/mllib/feature/StandardScalerModel.html   |   786 +
 .../spark/mllib/feature/VectorTransformer.html     |   574 +
 .../org/apache/spark/mllib/feature/Word2Vec.html   |  1026 +
 .../apache/spark/mllib/feature/Word2VecModel$.html |   520 +
 .../apache/spark/mllib/feature/Word2VecModel.html  |   661 +
 .../org/apache/spark/mllib/feature/package.html    |   530 +
 .../spark/mllib/fpm/AssociationRules$$Rule.html    |   633 +
 .../apache/spark/mllib/fpm/AssociationRules$.html  |   520 +
 .../apache/spark/mllib/fpm/AssociationRules.html   |   874 +
 .../spark/mllib/fpm/FPGrowth$$FreqItemset.html     |   587 +
 .../org/apache/spark/mllib/fpm/FPGrowth$.html      |   520 +
 .../scala/org/apache/spark/mllib/fpm/FPGrowth.html |   879 +
 .../org/apache/spark/mllib/fpm/FPGrowthModel$.html |   520 +
 .../org/apache/spark/mllib/fpm/FPGrowthModel.html  |   657 +
 .../spark/mllib/fpm/PrefixSpan$$FreqSequence.html  |   588 +
 .../org/apache/spark/mllib/fpm/PrefixSpan$.html    |   777 +
 .../org/apache/spark/mllib/fpm/PrefixSpan.html     |   980 +
 .../apache/spark/mllib/fpm/PrefixSpanModel$.html   |   520 +
 .../apache/spark/mllib/fpm/PrefixSpanModel.html    |   588 +
 .../scala/org/apache/spark/mllib/fpm/package.html  |   347 +
 .../apache/spark/mllib/linalg/DenseMatrix$.html    |   658 +
 .../org/apache/spark/mllib/linalg/DenseMatrix.html |   987 +
 .../apache/spark/mllib/linalg/DenseVector$.html    |   541 +
 .../org/apache/spark/mllib/linalg/DenseVector.html |   866 +
 .../org/apache/spark/mllib/linalg/Matrices$.html   |   819 +
 .../org/apache/spark/mllib/linalg/Matrix.html      |   881 +
 .../apache/spark/mllib/linalg/QRDecomposition.html |   500 +
 .../mllib/linalg/SingularValueDecomposition.html   |   517 +
 .../apache/spark/mllib/linalg/SparseMatrix$.html   |   639 +
 .../apache/spark/mllib/linalg/SparseMatrix.html    |  1040 +
 .../apache/spark/mllib/linalg/SparseVector$.html   |   541 +
 .../apache/spark/mllib/linalg/SparseVector.html    |   888 +
 .../org/apache/spark/mllib/linalg/Vector.html      |   819 +
 .../org/apache/spark/mllib/linalg/VectorUDT.html   |   743 +
 .../org/apache/spark/mllib/linalg/Vectors$.html    |   755 +
 .../mllib/linalg/distributed/BlockMatrix.html      |  1267 +
 .../mllib/linalg/distributed/CoordinateMatrix.html |   735 +
 .../linalg/distributed/DistributedMatrix.html      |   545 +
 .../spark/mllib/linalg/distributed/IndexedRow.html |   500 +
 .../mllib/linalg/distributed/IndexedRowMatrix.html |   826 +
 .../mllib/linalg/distributed/MatrixEntry.html      |   516 +
 .../spark/mllib/linalg/distributed/RowMatrix$.html |   494 +
 .../spark/mllib/linalg/distributed/RowMatrix.html  |  1171 +
 .../spark/mllib/linalg/distributed/package.html    |   296 +
 .../org/apache/spark/mllib/linalg/package.html     |   500 +
 .../apache/spark/mllib/optimization/Gradient.html  |   555 +
 .../spark/mllib/optimization/GradientDescent$.html |   797 +
 .../spark/mllib/optimization/GradientDescent.html  |   904 +
 .../spark/mllib/optimization/HingeGradient.html    |   552 +
 .../apache/spark/mllib/optimization/L1Updater.html |   542 +
 .../apache/spark/mllib/optimization/LBFGS$.html    |   776 +
 .../org/apache/spark/mllib/optimization/LBFGS.html |   907 +
 .../mllib/optimization/LeastSquaresGradient.html   |   554 +
 .../spark/mllib/optimization/LogisticGradient.html |   631 +
 .../apache/spark/mllib/optimization/Optimizer.html |   514 +
 .../spark/mllib/optimization/SimpleUpdater.html    |   536 +
 .../spark/mllib/optimization/SquaredL2Updater.html |   537 +
 .../apache/spark/mllib/optimization/Updater.html   |   544 +
 .../apache/spark/mllib/optimization/package.html   |   479 +
 .../api/scala/org/apache/spark/mllib/package.html  |   411 +
 .../apache/spark/mllib/pmml/PMMLExportable.html    |   597 +
 .../scala/org/apache/spark/mllib/pmml/package.html |   133 +
 .../spark/mllib/random/ExponentialGenerator.html   |   622 +
 .../apache/spark/mllib/random/GammaGenerator.html  |   645 +
 .../spark/mllib/random/LogNormalGenerator.html     |   646 +
 .../spark/mllib/random/PoissonGenerator.html       |   622 +
 .../spark/mllib/random/RandomDataGenerator.html    |   571 +
 .../org/apache/spark/mllib/random/RandomRDDs$.html |  1895 +
 .../mllib/random/StandardNormalGenerator.html      |   593 +
 .../spark/mllib/random/UniformGenerator.html       |   593 +
 .../spark/mllib/random/WeibullGenerator.html       |   605 +
 .../org/apache/spark/mllib/random/package.html     |   349 +
 .../spark/mllib/rdd/MLPairRDDFunctions$.html       |   509 +
 .../apache/spark/mllib/rdd/MLPairRDDFunctions.html |   534 +
 .../org/apache/spark/mllib/rdd/RDDFunctions$.html  |   509 +
 .../org/apache/spark/mllib/rdd/RDDFunctions.html   |   554 +
 .../scala/org/apache/spark/mllib/rdd/package.html  |   194 +
 .../apache/spark/mllib/recommendation/ALS$.html    |   718 +
 .../org/apache/spark/mllib/recommendation/ALS.html |  1181 +
 .../recommendation/MatrixFactorizationModel$.html  |   520 +
 .../recommendation/MatrixFactorizationModel.html   |  1080 +
 .../apache/spark/mllib/recommendation/Rating.html  |   541 +
 .../apache/spark/mllib/recommendation/package.html |   243 +
 .../regression/GeneralizedLinearAlgorithm.html     |  1079 +
 .../mllib/regression/GeneralizedLinearModel.html   |   643 +
 .../spark/mllib/regression/IsotonicRegression.html |   607 +
 .../mllib/regression/IsotonicRegressionModel$.html |   520 +
 .../mllib/regression/IsotonicRegressionModel.html  |   744 +
 .../spark/mllib/regression/LabeledPoint$.html      |   519 +
 .../spark/mllib/regression/LabeledPoint.html       |   539 +
 .../apache/spark/mllib/regression/LassoModel$.html |   520 +
 .../apache/spark/mllib/regression/LassoModel.html  |   807 +
 .../spark/mllib/regression/LassoWithSGD$.html      |   606 +
 .../spark/mllib/regression/LassoWithSGD.html       |  1090 +
 .../mllib/regression/LinearRegressionModel$.html   |   520 +
 .../mllib/regression/LinearRegressionModel.html    |   807 +
 .../mllib/regression/LinearRegressionWithSGD$.html |   606 +
 .../mllib/regression/LinearRegressionWithSGD.html  |  1091 +
 .../spark/mllib/regression/RegressionModel.html    |   569 +
 .../mllib/regression/RidgeRegressionModel$.html    |   520 +
 .../mllib/regression/RidgeRegressionModel.html     |   807 +
 .../mllib/regression/RidgeRegressionWithSGD$.html  |   602 +
 .../mllib/regression/RidgeRegressionWithSGD.html   |  1090 +
 .../mllib/regression/StreamingLinearAlgorithm.html |   991 +
 .../StreamingLinearRegressionWithSGD.html          |  1145 +
 .../org/apache/spark/mllib/regression/package.html |   700 +
 .../org/apache/spark/mllib/stat/KernelDensity.html |   613 +
 .../mllib/stat/MultivariateOnlineSummarizer.html   |   761 +
 .../mllib/stat/MultivariateStatisticalSummary.html |   689 +
 .../org/apache/spark/mllib/stat/Statistics$.html   |   895 +
 .../stat/distribution/MultivariateGaussian.html    |   622 +
 .../spark/mllib/stat/distribution/package.html     |   133 +
 .../scala/org/apache/spark/mllib/stat/package.html |   254 +
 .../apache/spark/mllib/stat/test/BinarySample.html |   537 +
 .../spark/mllib/stat/test/ChiSqTestResult.html     |   610 +
 .../stat/test/KolmogorovSmirnovTestResult.html     |   593 +
 .../spark/mllib/stat/test/StreamingTest.html       |   909 +
 .../apache/spark/mllib/stat/test/TestResult.html   |   596 +
 .../org/apache/spark/mllib/stat/test/package.html  |   232 +
 .../org/apache/spark/mllib/tree/DecisionTree$.html |   986 +
 .../org/apache/spark/mllib/tree/DecisionTree.html  |   806 +
 .../spark/mllib/tree/GradientBoostedTrees$.html    |   802 +
 .../spark/mllib/tree/GradientBoostedTrees.html     |   885 +
 .../org/apache/spark/mllib/tree/RandomForest$.html |   951 +
 .../spark/mllib/tree/configuration/Algo$.html      |   811 +
 .../tree/configuration/BoostingStrategy$.html      |   542 +
 .../mllib/tree/configuration/BoostingStrategy.html |   859 +
 .../mllib/tree/configuration/FeatureType$.html     |   811 +
 .../tree/configuration/QuantileStrategy$.html      |   834 +
 .../spark/mllib/tree/configuration/Strategy$.html  |   540 +
 .../spark/mllib/tree/configuration/Strategy.html   |  1601 +
 .../spark/mllib/tree/configuration/package.html    |   285 +
 .../apache/spark/mllib/tree/impurity/Entropy$.html |   574 +
 .../apache/spark/mllib/tree/impurity/Gini$.html    |   576 +
 .../apache/spark/mllib/tree/impurity/Impurity.html |   556 +
 .../spark/mllib/tree/impurity/Variance$.html       |   574 +
 .../apache/spark/mllib/tree/impurity/package.html  |   208 +
 .../spark/mllib/tree/loss/AbsoluteError$.html      |   551 +
 .../org/apache/spark/mllib/tree/loss/LogLoss$.html |   555 +
 .../org/apache/spark/mllib/tree/loss/Loss.html     |   550 +
 .../org/apache/spark/mllib/tree/loss/Losses$.html  |   511 +
 .../spark/mllib/tree/loss/SquaredError$.html       |   551 +
 .../org/apache/spark/mllib/tree/loss/package.html  |   246 +
 .../spark/mllib/tree/model/DecisionTreeModel$.html |   776 +
 .../spark/mllib/tree/model/DecisionTreeModel.html  |   756 +
 .../tree/model/GradientBoostedTreesModel$.html     |   579 +
 .../tree/model/GradientBoostedTreesModel.html      |   785 +
 .../mllib/tree/model/InformationGainStats.html     |   617 +
 .../org/apache/spark/mllib/tree/model/Node.html    |   988 +
 .../org/apache/spark/mllib/tree/model/Predict.html |   567 +
 .../spark/mllib/tree/model/RandomForestModel$.html |   519 +
 .../spark/mllib/tree/model/RandomForestModel.html  |   755 +
 .../org/apache/spark/mllib/tree/model/Split.html   |   580 +
 .../org/apache/spark/mllib/tree/model/package.html |   357 +
 .../scala/org/apache/spark/mllib/tree/package.html |   325 +
 .../apache/spark/mllib/util/DataValidators$.html   |   799 +
 .../spark/mllib/util/KMeansDataGenerator$.html     |   541 +
 .../spark/mllib/util/LinearDataGenerator$.html     |   650 +
 .../scala/org/apache/spark/mllib/util/Loader.html  |   522 +
 .../util/LogisticRegressionDataGenerator$.html     |   540 +
 .../apache/spark/mllib/util/MFDataGenerator$.html  |   529 +
 .../org/apache/spark/mllib/util/MLUtils$.html      |  1136 +
 .../apache/spark/mllib/util/SVMDataGenerator$.html |   516 +
 .../org/apache/spark/mllib/util/Saveable.html      |   540 +
 .../scala/org/apache/spark/mllib/util/package.html |   370 +
 .../2.4.3/api/scala/org/apache/spark/package.html  |  1839 +
 .../org/apache/spark/partial/BoundedDouble.html    |   571 +
 .../org/apache/spark/partial/PartialResult.html    |   608 +
 .../scala/org/apache/spark/partial/package.html    |   163 +
 .../org/apache/spark/rdd/AsyncRDDActions.html      |   849 +
 .../scala/org/apache/spark/rdd/CoGroupedRDD.html   |  2730 +
 .../org/apache/spark/rdd/DoubleRDDFunctions.html   |  1022 +
 .../api/scala/org/apache/spark/rdd/HadoopRDD.html  |  2821 +
 .../spark/rdd/JdbcRDD$$ConnectionFactory.html      |   512 +
 .../api/scala/org/apache/spark/rdd/JdbcRDD$.html   |   577 +
 .../api/scala/org/apache/spark/rdd/JdbcRDD.html    |  2701 +
 .../scala/org/apache/spark/rdd/NewHadoopRDD.html   |  2750 +
 .../org/apache/spark/rdd/OrderedRDDFunctions.html  |   841 +
 .../org/apache/spark/rdd/PairRDDFunctions.html     |  2175 +
 .../org/apache/spark/rdd/PartitionCoalescer.html   |   509 +
 .../scala/org/apache/spark/rdd/PartitionGroup.html |   557 +
 .../org/apache/spark/rdd/PartitionPruningRDD$.html |   510 +
 .../org/apache/spark/rdd/PartitionPruningRDD.html  |  2699 +
 .../2.4.3/api/scala/org/apache/spark/rdd/RDD$.html |   592 +
 .../2.4.3/api/scala/org/apache/spark/rdd/RDD.html  |  2697 +
 .../api/scala/org/apache/spark/rdd/RDDBarrier.html |   525 +
 .../apache/spark/rdd/SequenceFileRDDFunctions.html |   789 +
 .../scala/org/apache/spark/rdd/ShuffledRDD.html    |  2778 +
 .../api/scala/org/apache/spark/rdd/UnionRDD$.html  |   488 +
 .../api/scala/org/apache/spark/rdd/UnionRDD.html   |  2711 +
 .../api/scala/org/apache/spark/rdd/package.html    |   579 +
 .../apache/spark/scheduler/AccumulableInfo$.html   |   552 +
 .../apache/spark/scheduler/AccumulableInfo.html    |   517 +
 .../apache/spark/scheduler/InputFormatInfo$.html   |   509 +
 .../apache/spark/scheduler/InputFormatInfo.html    |   851 +
 .../org/apache/spark/scheduler/JobResult.html      |   490 +
 .../org/apache/spark/scheduler/JobSucceeded$.html  |   461 +
 .../apache/spark/scheduler/SchedulingMode$.html    |   806 +
 .../org/apache/spark/scheduler/SparkListener.html  |   977 +
 .../scheduler/SparkListenerApplicationEnd.html     |   498 +
 .../scheduler/SparkListenerApplicationStart.html   |   583 +
 .../scheduler/SparkListenerBlockManagerAdded.html  |   566 +
 .../SparkListenerBlockManagerRemoved.html          |   515 +
 .../spark/scheduler/SparkListenerBlockUpdated.html |   498 +
 .../scheduler/SparkListenerEnvironmentUpdate.html  |   498 +
 .../apache/spark/scheduler/SparkListenerEvent.html |   507 +
 .../scheduler/SparkListenerExecutorAdded.html      |   532 +
 .../SparkListenerExecutorBlacklisted.html          |   532 +
 .../SparkListenerExecutorBlacklistedForStage.html  |   566 +
 .../SparkListenerExecutorMetricsUpdate.html        |   515 +
 .../scheduler/SparkListenerExecutorRemoved.html    |   532 +
 .../SparkListenerExecutorUnblacklisted.html        |   515 +
 .../spark/scheduler/SparkListenerJobEnd.html       |   532 +
 .../spark/scheduler/SparkListenerJobStart.html     |   566 +
 .../spark/scheduler/SparkListenerLogStart.html     |   499 +
 .../scheduler/SparkListenerNodeBlacklisted.html    |   532 +
 .../SparkListenerNodeBlacklistedForStage.html      |   566 +
 .../scheduler/SparkListenerNodeUnblacklisted.html  |   515 +
 .../SparkListenerSpeculativeTaskSubmitted.html     |   498 +
 .../scheduler/SparkListenerStageCompleted.html     |   498 +
 .../scheduler/SparkListenerStageSubmitted.html     |   515 +
 .../spark/scheduler/SparkListenerTaskEnd.html      |   583 +
 .../scheduler/SparkListenerTaskGettingResult.html  |   498 +
 .../spark/scheduler/SparkListenerTaskStart.html    |   532 +
 .../spark/scheduler/SparkListenerUnpersistRDD.html |   498 +
 .../org/apache/spark/scheduler/SplitInfo$.html     |   518 +
 .../org/apache/spark/scheduler/SplitInfo.html      |   592 +
 .../org/apache/spark/scheduler/StageInfo.html      |   752 +
 .../spark/scheduler/StatsReportListener.html       |  1232 +
 .../scala/org/apache/spark/scheduler/TaskInfo.html |   854 +
 .../org/apache/spark/scheduler/TaskLocality$.html  |   857 +
 .../spark/scheduler/cluster/ExecutorInfo.html      |   575 +
 .../apache/spark/scheduler/cluster/package.html    |   124 +
 .../scala/org/apache/spark/scheduler/package.html  |   969 +
 .../security/GroupMappingServiceProvider.html      |   508 +
 .../scala/org/apache/spark/security/package.html   |   124 +
 .../spark/serializer/DeserializationStream.html    |   620 +
 .../spark/serializer/DummySerializerInstance.html  |   623 +
 .../apache/spark/serializer/JavaSerializer.html    |   620 +
 .../apache/spark/serializer/KryoRegistrator.html   |   504 +
 .../apache/spark/serializer/KryoSerializer.html    |   872 +
 .../spark/serializer/SerializationStream.html      |   616 +
 .../org/apache/spark/serializer/Serializer.html    |   571 +
 .../spark/serializer/SerializerInstance.html       |   601 +
 .../scala/org/apache/spark/serializer/package.html |   309 +
 .../org/apache/spark/sql/AnalysisException.html    |   837 +
 .../api/scala/org/apache/spark/sql/Column.html     |  2338 +
 .../api/scala/org/apache/spark/sql/ColumnName.html |  2621 +
 .../org/apache/spark/sql/DataFrameNaFunctions.html |  1043 +
 .../org/apache/spark/sql/DataFrameReader.html      |  1473 +
 .../apache/spark/sql/DataFrameStatFunctions.html   |   965 +
 .../org/apache/spark/sql/DataFrameWriter.html      |   987 +
 .../api/scala/org/apache/spark/sql/Dataset.html    |  4006 ++
 .../scala/org/apache/spark/sql/DatasetHolder.html  |   494 +
 .../api/scala/org/apache/spark/sql/Encoder.html    |   542 +
 .../api/scala/org/apache/spark/sql/Encoders$.html  |  1008 +
 .../org/apache/spark/sql/ExperimentalMethods.html  |   519 +
 .../scala/org/apache/spark/sql/ForeachWriter.html  |   622 +
 .../apache/spark/sql/KeyValueGroupedDataset.html   |  1120 +
 .../apache/spark/sql/LowPrioritySQLImplicits.html  |   505 +
 .../apache/spark/sql/RelationalGroupedDataset.html |   875 +
 .../2.4.3/api/scala/org/apache/spark/sql/Row$.html |   598 +
 .../2.4.3/api/scala/org/apache/spark/sql/Row.html  |  1132 +
 .../api/scala/org/apache/spark/sql/RowFactory.html |   502 +
 .../scala/org/apache/spark/sql/RuntimeConfig.html  |   736 +
 .../scala/org/apache/spark/sql/SQLContext$.html    |   564 +
 .../apache/spark/sql/SQLContext$implicits$.html    |  1292 +
 .../api/scala/org/apache/spark/sql/SQLContext.html |  2437 +
 .../spark/sql/SQLImplicits$StringToColumn.html     |   537 +
 .../scala/org/apache/spark/sql/SQLImplicits.html   |  1308 +
 .../api/scala/org/apache/spark/sql/SaveMode.html   |   570 +
 .../apache/spark/sql/SparkSession$$Builder.html    |   960 +
 .../scala/org/apache/spark/sql/SparkSession$.html  |   921 +
 .../apache/spark/sql/SparkSession$implicits$.html  |  1292 +
 .../scala/org/apache/spark/sql/SparkSession.html   |  1672 +
 .../apache/spark/sql/SparkSessionExtensions.html   |   716 +
 .../scala/org/apache/spark/sql/TypedColumn.html    |  2317 +
 .../org/apache/spark/sql/UDFRegistration.html      |  1584 +
 .../scala/org/apache/spark/sql/api/java/UDF0.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF1.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF10.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF11.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF12.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF13.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF14.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF15.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF16.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF17.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF18.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF19.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF2.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF20.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF21.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF22.html |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF3.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF4.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF5.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF6.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF7.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF8.html  |   504 +
 .../scala/org/apache/spark/sql/api/java/UDF9.html  |   504 +
 .../org/apache/spark/sql/api/java/package.html     |   492 +
 .../scala/org/apache/spark/sql/api/package.html    |   145 +
 .../org/apache/spark/sql/catalog/Catalog.html      |  1461 +
 .../scala/org/apache/spark/sql/catalog/Column.html |   610 +
 .../org/apache/spark/sql/catalog/Database.html     |   559 +
 .../org/apache/spark/sql/catalog/Function.html     |   593 +
 .../scala/org/apache/spark/sql/catalog/Table.html  |   593 +
 .../org/apache/spark/sql/catalog/package.html      |   206 +
 .../apache/spark/sql/expressions/Aggregator.html   |   648 +
 .../sql/expressions/MutableAggregationBuffer.html  |  1143 +
 .../expressions/UserDefinedAggregateFunction.html  |   721 +
 .../spark/sql/expressions/UserDefinedFunction.html |   629 +
 .../org/apache/spark/sql/expressions/Window$.html  |   743 +
 .../org/apache/spark/sql/expressions/Window.html   |   492 +
 .../apache/spark/sql/expressions/WindowSpec.html   |   678 +
 .../spark/sql/expressions/javalang/package.html    |   118 +
 .../spark/sql/expressions/javalang/typed.html      |   502 +
 .../org/apache/spark/sql/expressions/package.html  |   314 +
 .../spark/sql/expressions/scalalang/package.html   |   126 +
 .../spark/sql/expressions/scalalang/typed$.html    |   561 +
 .../api/scala/org/apache/spark/sql/functions$.html |  7551 +++
 .../apache/spark/sql/hive/DetermineTableStats.html |   795 +
 .../org/apache/spark/sql/hive/HiveAnalysis$.html   |   777 +
 .../org/apache/spark/sql/hive/HiveContext.html     |  2449 +
 .../spark/sql/hive/HiveExternalCatalog$.html       |   873 +
 .../spark/sql/hive/HiveSessionResourceLoader.html  |   540 +
 .../spark/sql/hive/HiveSessionStateBuilder.html    |   959 +
 .../org/apache/spark/sql/hive/HiveUDAFBuffer.html  |   493 +
 .../apache/spark/sql/hive/RelationConversions.html |   789 +
 .../spark/sql/hive/ResolveHiveSerdeTable.html      |   797 +
 .../execution/CreateHiveTableAsSelectCommand.html  |  2350 +
 .../spark/sql/hive/execution/HiveFileFormat.html   |   935 +
 .../spark/sql/hive/execution/HiveOptions$.html     |   590 +
 .../spark/sql/hive/execution/HiveOptions.html      |   646 +
 .../spark/sql/hive/execution/HiveOutputWriter.html |   751 +
 .../sql/hive/execution/HiveScriptIOSchema$.html    |   505 +
 .../sql/hive/execution/HiveScriptIOSchema.html     |   930 +
 .../hive/execution/InsertIntoHiveDirCommand.html   |  2440 +
 .../sql/hive/execution/InsertIntoHiveTable.html    |  2472 +
 .../hive/execution/ScriptTransformationExec.html   |  2323 +
 .../apache/spark/sql/hive/execution/package.html   |   292 +
 .../apache/spark/sql/hive/orc/OrcFileFormat.html   |   666 +
 .../org/apache/spark/sql/hive/orc/package.html     |   120 +
 .../scala/org/apache/spark/sql/hive/package.html   |   337 +
 .../org/apache/spark/sql/jdbc/JdbcDialect.html     |   779 +
 .../org/apache/spark/sql/jdbc/JdbcDialects$.html   |   546 +
 .../scala/org/apache/spark/sql/jdbc/JdbcType.html  |   503 +
 .../scala/org/apache/spark/sql/jdbc/package.html   |   198 +
 .../api/scala/org/apache/spark/sql/package.html    |  1160 +
 .../scala/org/apache/spark/sql/sources/And.html    |   533 +
 .../org/apache/spark/sql/sources/BaseRelation.html |   616 +
 .../org/apache/spark/sql/sources/CatalystScan.html |   513 +
 .../sql/sources/CreatableRelationProvider.html     |   507 +
 .../spark/sql/sources/DataSourceRegister.html      |   512 +
 .../apache/spark/sql/sources/EqualNullSafe.html    |   535 +
 .../org/apache/spark/sql/sources/EqualTo.html      |   534 +
 .../scala/org/apache/spark/sql/sources/Filter.html |   546 +
 .../org/apache/spark/sql/sources/GreaterThan.html  |   534 +
 .../spark/sql/sources/GreaterThanOrEqual.html      |   534 +
 .../api/scala/org/apache/spark/sql/sources/In.html |   584 +
 .../spark/sql/sources/InsertableRelation.html      |   516 +
 .../org/apache/spark/sql/sources/IsNotNull.html    |   516 +
 .../scala/org/apache/spark/sql/sources/IsNull.html |   516 +
 .../org/apache/spark/sql/sources/LessThan.html     |   534 +
 .../apache/spark/sql/sources/LessThanOrEqual.html  |   534 +
 .../scala/org/apache/spark/sql/sources/Not.html    |   516 +
 .../api/scala/org/apache/spark/sql/sources/Or.html |   533 +
 .../spark/sql/sources/PrunedFilteredScan.html      |   510 +
 .../org/apache/spark/sql/sources/PrunedScan.html   |   507 +
 .../apache/spark/sql/sources/RelationProvider.html |   513 +
 .../spark/sql/sources/SchemaRelationProvider.html  |   517 +
 .../spark/sql/sources/StreamSinkProvider.html      |   509 +
 .../spark/sql/sources/StreamSourceProvider.html    |   526 +
 .../apache/spark/sql/sources/StringContains.html   |   534 +
 .../apache/spark/sql/sources/StringEndsWith.html   |   534 +
 .../apache/spark/sql/sources/StringStartsWith.html |   534 +
 .../org/apache/spark/sql/sources/TableScan.html    |   506 +
 .../org/apache/spark/sql/sources/package.html      |   808 +
 .../sql/sources/v2/ContinuousReadSupport.html      |   504 +
 .../spark/sql/sources/v2/DataSourceOptions.html    |   655 +
 .../apache/spark/sql/sources/v2/DataSourceV2.html  |   485 +
 .../sql/sources/v2/MicroBatchReadSupport.html      |   504 +
 .../apache/spark/sql/sources/v2/ReadSupport.html   |   521 +
 .../spark/sql/sources/v2/SessionConfigSupport.html |   504 +
 .../spark/sql/sources/v2/StreamWriteSupport.html   |   506 +
 .../apache/spark/sql/sources/v2/WriteSupport.html  |   504 +
 .../org/apache/spark/sql/sources/v2/package.html   |   274 +
 .../v2/reader/ContinuousInputPartition.html        |   540 +
 .../sql/sources/v2/reader/DataSourceReader.html    |   522 +
 .../sql/sources/v2/reader/InputPartition.html      |   524 +
 .../sources/v2/reader/InputPartitionReader.html    |   549 +
 .../spark/sql/sources/v2/reader/Statistics.html    |   519 +
 .../sources/v2/reader/SupportsPushDownFilters.html |   555 +
 .../v2/reader/SupportsPushDownRequiredColumns.html |   538 +
 .../v2/reader/SupportsReportPartitioning.html      |   538 +
 .../v2/reader/SupportsReportStatistics.html        |   538 +
 .../v2/reader/SupportsScanColumnarBatch.html       |   555 +
 .../spark/sql/sources/v2/reader/package.html       |   308 +
 .../reader/partitioning/ClusteredDistribution.html |   504 +
 .../v2/reader/partitioning/Distribution.html       |   485 +
 .../v2/reader/partitioning/Partitioning.html       |   519 +
 .../sources/v2/reader/partitioning/package.html    |   152 +
 .../streaming/ContinuousInputPartitionReader.html  |   565 +
 .../v2/reader/streaming/ContinuousReader.html      |   642 +
 .../v2/reader/streaming/MicroBatchReader.html      |   625 +
 .../sql/sources/v2/reader/streaming/Offset.html    |   524 +
 .../v2/reader/streaming/PartitionOffset.html       |   484 +
 .../sql/sources/v2/reader/streaming/package.html   |   186 +
 .../sql/sources/v2/writer/DataSourceWriter.html    |   573 +
 .../spark/sql/sources/v2/writer/DataWriter.html    |   536 +
 .../sql/sources/v2/writer/DataWriterFactory.html   |   504 +
 .../sql/sources/v2/writer/WriterCommitMessage.html |   484 +
 .../spark/sql/sources/v2/writer/package.html       |   189 +
 .../sources/v2/writer/streaming/StreamWriter.html  |   606 +
 .../sql/sources/v2/writer/streaming/package.html   |   118 +
 .../spark/sql/streaming/DataStreamReader.html      |  1128 +
 .../spark/sql/streaming/DataStreamWriter.html      |   840 +
 .../org/apache/spark/sql/streaming/GroupState.html |   944 +
 .../spark/sql/streaming/GroupStateTimeout.html     |   502 +
 .../org/apache/spark/sql/streaming/OutputMode.html |   502 +
 .../spark/sql/streaming/ProcessingTime$.html       |   579 +
 .../apache/spark/sql/streaming/ProcessingTime.html |   492 +
 .../apache/spark/sql/streaming/SinkProgress.html   |   562 +
 .../apache/spark/sql/streaming/SourceProgress.html |   649 +
 .../spark/sql/streaming/StateOperatorProgress.html |   592 +
 .../apache/spark/sql/streaming/StreamingQuery.html |   789 +
 .../sql/streaming/StreamingQueryException.html     |   781 +
 .../streaming/StreamingQueryListener$$Event.html   |   507 +
 ...StreamingQueryListener$$QueryProgressEvent.html |   523 +
 .../StreamingQueryListener$$QueryStartedEvent.html |   557 +
 ...reamingQueryListener$$QueryTerminatedEvent.html |   560 +
 .../sql/streaming/StreamingQueryListener$.html     |   571 +
 .../sql/streaming/StreamingQueryListener.html      |   570 +
 .../spark/sql/streaming/StreamingQueryManager.html |   925 +
 .../sql/streaming/StreamingQueryProgress.html      |   753 +
 .../spark/sql/streaming/StreamingQueryStatus.html  |   597 +
 .../org/apache/spark/sql/streaming/Trigger.html    |   505 +
 .../org/apache/spark/sql/streaming/package.html    |   607 +
 .../org/apache/spark/sql/types/AnyDataType$.html   |   485 +
 .../org/apache/spark/sql/types/ArrayType$.html     |   512 +
 .../org/apache/spark/sql/types/ArrayType.html      |   644 +
 .../org/apache/spark/sql/types/AtomicType$.html    |   502 +
 .../org/apache/spark/sql/types/AtomicType.html     |   635 +
 .../org/apache/spark/sql/types/BinaryType$.html    |   589 +
 .../org/apache/spark/sql/types/BinaryType.html     |   618 +
 .../org/apache/spark/sql/types/BooleanType$.html   |   589 +
 .../org/apache/spark/sql/types/BooleanType.html    |   617 +
 .../org/apache/spark/sql/types/ByteType$.html      |   593 +
 .../scala/org/apache/spark/sql/types/ByteType.html |   621 +
 .../spark/sql/types/CalendarIntervalType$.html     |   587 +
 .../spark/sql/types/CalendarIntervalType.html      |   616 +
 .../scala/org/apache/spark/sql/types/CharType.html |   607 +
 .../org/apache/spark/sql/types/DataType$.html      |   585 +
 .../scala/org/apache/spark/sql/types/DataType.html |   635 +
 .../org/apache/spark/sql/types/DataTypes.html      |   502 +
 .../org/apache/spark/sql/types/DateType$.html      |   589 +
 .../scala/org/apache/spark/sql/types/DateType.html |   617 +
 .../scala/org/apache/spark/sql/types/Decimal$.html |   848 +
 .../scala/org/apache/spark/sql/types/Decimal.html  |  1200 +
 .../org/apache/spark/sql/types/DecimalType$.html   |   667 +
 .../org/apache/spark/sql/types/DecimalType.html    |   684 +
 .../org/apache/spark/sql/types/DoubleType$.html    |   593 +
 .../org/apache/spark/sql/types/DoubleType.html     |   621 +
 .../org/apache/spark/sql/types/FloatType$.html     |   593 +
 .../org/apache/spark/sql/types/FloatType.html      |   621 +
 .../apache/spark/sql/types/HiveStringType$.html    |   501 +
 .../org/apache/spark/sql/types/HiveStringType.html |   636 +
 .../org/apache/spark/sql/types/IntegerType$.html   |   593 +
 .../org/apache/spark/sql/types/IntegerType.html    |   621 +
 .../org/apache/spark/sql/types/LongType$.html      |   593 +
 .../scala/org/apache/spark/sql/types/LongType.html |   621 +
 .../scala/org/apache/spark/sql/types/MapType$.html |   512 +
 .../scala/org/apache/spark/sql/types/MapType.html  |   660 +
 .../org/apache/spark/sql/types/Metadata$.html      |   525 +
 .../scala/org/apache/spark/sql/types/Metadata.html |   719 +
 .../apache/spark/sql/types/MetadataBuilder.html    |   761 +
 .../org/apache/spark/sql/types/NullType$.html      |   587 +
 .../scala/org/apache/spark/sql/types/NullType.html |   615 +
 .../org/apache/spark/sql/types/NumericType.html    |   635 +
 .../org/apache/spark/sql/types/ObjectType$.html    |   493 +
 .../org/apache/spark/sql/types/ObjectType.html     |   649 +
 .../apache/spark/sql/types/SQLUserDefinedType.html |   547 +
 .../org/apache/spark/sql/types/ShortType$.html     |   593 +
 .../org/apache/spark/sql/types/ShortType.html      |   621 +
 .../org/apache/spark/sql/types/StringType$.html    |   589 +
 .../org/apache/spark/sql/types/StringType.html     |   617 +
 .../org/apache/spark/sql/types/StructField.html    |   620 +
 .../org/apache/spark/sql/types/StructType$.html    |   547 +
 .../org/apache/spark/sql/types/StructType.html     |  3843 ++
 .../org/apache/spark/sql/types/TimestampType$.html |   589 +
 .../org/apache/spark/sql/types/TimestampType.html  |   618 +
 .../org/apache/spark/sql/types/VarcharType.html    |   607 +
 .../scala/org/apache/spark/sql/types/package.html  |  1302 +
 .../spark/sql/util/ExecutionListenerManager.html   |   806 +
 .../spark/sql/util/QueryExecutionListener.html     |   537 +
 .../scala/org/apache/spark/sql/util/package.html   |   150 +
 .../spark/sql/vectorized/ArrowColumnVector.html    |   965 +
 .../apache/spark/sql/vectorized/ColumnVector.html  |   969 +
 .../apache/spark/sql/vectorized/ColumnarArray.html |  1173 +
 .../apache/spark/sql/vectorized/ColumnarBatch.html |   621 +
 .../apache/spark/sql/vectorized/ColumnarMap.html   |   593 +
 .../apache/spark/sql/vectorized/ColumnarRow.html   |  1054 +
 .../org/apache/spark/sql/vectorized/package.html   |   203 +
 .../scala/org/apache/spark/status/api/package.html |   118 +
 .../spark/status/api/v1/AccumulableInfo.html       |   550 +
 .../status/api/v1/ApplicationAttemptInfo.html      |   629 +
 .../status/api/v1/ApplicationEnvironmentInfo.html  |   550 +
 .../spark/status/api/v1/ApplicationInfo.html       |   558 +
 .../spark/status/api/v1/ApplicationStatus.html     |   570 +
 .../spark/status/api/v1/ExecutorStageSummary.html  |   737 +
 .../spark/status/api/v1/ExecutorSummary.html       |   907 +
 .../status/api/v1/InputMetricDistributions.html    |   516 +
 .../apache/spark/status/api/v1/InputMetrics.html   |   516 +
 .../org/apache/spark/status/api/v1/JobData.html    |   822 +
 .../apache/spark/status/api/v1/MemoryMetrics.html  |   550 +
 .../status/api/v1/OutputMetricDistributions.html   |   516 +
 .../apache/spark/status/api/v1/OutputMetrics.html  |   516 +
 .../spark/status/api/v1/RDDDataDistribution.html   |   618 +
 .../spark/status/api/v1/RDDPartitionInfo.html      |   567 +
 .../apache/spark/status/api/v1/RDDStorageInfo.html |   635 +
 .../apache/spark/status/api/v1/RuntimeInfo.html    |   533 +
 .../api/v1/ShuffleReadMetricDistributions.html     |   618 +
 .../spark/status/api/v1/ShuffleReadMetrics.html    |   601 +
 .../api/v1/ShuffleWriteMetricDistributions.html    |   533 +
 .../spark/status/api/v1/ShuffleWriteMetrics.html   |   533 +
 .../org/apache/spark/status/api/v1/StackTrace.html |   527 +
 .../org/apache/spark/status/api/v1/StageData.html  |  1060 +
 .../apache/spark/status/api/v1/StageStatus.html    |   570 +
 .../org/apache/spark/status/api/v1/TaskData.html   |   720 +
 .../status/api/v1/TaskMetricDistributions.html     |   771 +
 .../apache/spark/status/api/v1/TaskMetrics.html    |   720 +
 .../apache/spark/status/api/v1/TaskSorting.html    |   550 +
 .../spark/status/api/v1/ThreadStackTrace.html      |   578 +
 .../apache/spark/status/api/v1/VersionInfo.html    |   499 +
 .../org/apache/spark/status/api/v1/package.html    |   634 +
 .../spark/status/api/v1/streaming/BatchInfo.html   |   703 +
 .../spark/status/api/v1/streaming/BatchStatus.html |   570 +
 .../api/v1/streaming/OutputOperationInfo.html      |   618 +
 .../status/api/v1/streaming/ReceiverInfo.html      |   652 +
 .../api/v1/streaming/StreamingStatistics.html      |   720 +
 .../spark/status/api/v1/streaming/package.html     |   186 +
 .../api/scala/org/apache/spark/status/package.html |   118 +
 .../spark/storage/BasicBlockReplicationPolicy.html |   787 +
 .../scala/org/apache/spark/storage/BlockId$.html   |   674 +
 .../scala/org/apache/spark/storage/BlockId.html    |   582 +
 .../org/apache/spark/storage/BlockManagerId.html   |   630 +
 .../spark/storage/BlockNotFoundException.html      |   712 +
 .../spark/storage/BlockReplicationPolicy.html      |   517 +
 .../spark/storage/BlockReplicationUtils$.html      |   502 +
 .../org/apache/spark/storage/BlockStatus$.html     |   508 +
 .../org/apache/spark/storage/BlockStatus.html      |   532 +
 .../org/apache/spark/storage/BlockUpdatedInfo.html |   549 +
 .../org/apache/spark/storage/BroadcastBlockId.html |   600 +
 .../spark/storage/DefaultTopologyMapper.html       |   792 +
 .../spark/storage/FileBasedTopologyMapper.html     |   829 +
 .../scala/org/apache/spark/storage/RDDBlockId.html |   600 +
 .../scala/org/apache/spark/storage/RDDInfo.html    |   815 +
 .../storage/RandomBlockReplicationPolicy.html      |   784 +
 .../org/apache/spark/storage/ShuffleBlockId.html   |   617 +
 .../apache/spark/storage/ShuffleDataBlockId.html   |   617 +
 .../apache/spark/storage/ShuffleIndexBlockId.html  |   617 +
 .../org/apache/spark/storage/StorageLevel$.html    |   809 +
 .../org/apache/spark/storage/StorageLevel.html     |   682 +
 .../org/apache/spark/storage/StreamBlockId.html    |   600 +
 .../apache/spark/storage/TaskResultBlockId.html    |   583 +
 .../spark/storage/TimeTrackingOutputStream.html    |   595 +
 .../org/apache/spark/storage/TopologyMapper.html   |   539 +
 .../apache/spark/storage/UnrecognizedBlockId.html  |   717 +
 .../scala/org/apache/spark/storage/package.html    |   650 +
 .../scala/org/apache/spark/streaming/Duration.html |   867 +
 .../org/apache/spark/streaming/Durations$.html     |   533 +
 .../org/apache/spark/streaming/Milliseconds$.html  |   501 +
 .../scala/org/apache/spark/streaming/Minutes$.html |   501 +
 .../scala/org/apache/spark/streaming/Seconds$.html |   501 +
 .../scala/org/apache/spark/streaming/State.html    |   649 +
 .../org/apache/spark/streaming/StateSpec$.html     |   608 +
 .../org/apache/spark/streaming/StateSpec.html      |   614 +
 .../apache/spark/streaming/StreamingContext$.html  |   854 +
 .../apache/spark/streaming/StreamingContext.html   |  1326 +
 .../spark/streaming/StreamingContextState.html     |   570 +
 .../scala/org/apache/spark/streaming/Time$.html    |   505 +
 .../api/scala/org/apache/spark/streaming/Time.html |   856 +
 .../spark/streaming/api/java/JavaDStream$.html     |   506 +
 .../spark/streaming/api/java/JavaDStream.html      |  1377 +
 .../spark/streaming/api/java/JavaDStreamLike.html  |  1157 +
 .../streaming/api/java/JavaInputDStream$.html      |   506 +
 .../spark/streaming/api/java/JavaInputDStream.html |  1391 +
 .../api/java/JavaMapWithStateDStream.html          |  1372 +
 .../spark/streaming/api/java/JavaPairDStream$.html |   539 +
 .../spark/streaming/api/java/JavaPairDStream.html  |  2411 +
 .../streaming/api/java/JavaPairInputDStream$.html  |   506 +
 .../streaming/api/java/JavaPairInputDStream.html   |  2468 +
 .../api/java/JavaPairReceiverInputDStream$.html    |   506 +
 .../api/java/JavaPairReceiverInputDStream.html     |  2484 +
 .../api/java/JavaReceiverInputDStream$.html        |   506 +
 .../api/java/JavaReceiverInputDStream.html         |  1408 +
 .../streaming/api/java/JavaStreamingContext$.html  |   569 +
 .../streaming/api/java/JavaStreamingContext.html   |  1284 +
 .../apache/spark/streaming/api/java/package.html   |   433 +
 .../org/apache/spark/streaming/api/package.html    |   118 +
 .../streaming/dstream/ConstantInputDStream.html    |  1580 +
 .../apache/spark/streaming/dstream/DStream$.html   |   505 +
 .../apache/spark/streaming/dstream/DStream.html    |  1513 +
 .../spark/streaming/dstream/InputDStream.html      |  1593 +
 .../streaming/dstream/MapWithStateDStream.html     |  1518 +
 .../streaming/dstream/PairDStreamFunctions.html    |  1484 +
 .../streaming/dstream/ReceiverInputDStream.html    |  1609 +
 .../apache/spark/streaming/dstream/package.html    |   291 +
 .../streaming/kinesis/KinesisInitialPositions.html |   502 +
 .../kinesis/KinesisInputDStream$$Builder.html      |   807 +
 .../streaming/kinesis/KinesisInputDStream$.html    |   531 +
 .../spark/streaming/kinesis/KinesisUtils$.html     |   831 +
 .../kinesis/SparkAWSCredentials$$Builder.html      |   590 +
 .../streaming/kinesis/SparkAWSCredentials$.html    |   533 +
 .../apache/spark/streaming/kinesis/package.html    |   178 +
 .../scala/org/apache/spark/streaming/package.html  |   593 +
 .../apache/spark/streaming/receiver/Receiver.html  |   977 +
 .../apache/spark/streaming/receiver/package.html   |   164 +
 .../spark/streaming/scheduler/BatchInfo.html       |   646 +
 .../streaming/scheduler/OutputOperationInfo.html   |   599 +
 .../spark/streaming/scheduler/RateController$.html |   503 +
 .../spark/streaming/scheduler/ReceiverInfo.html    |   600 +
 .../streaming/scheduler/StatsReportListener.html   |   729 +
 .../streaming/scheduler/StreamInputInfo$.html      |   508 +
 .../spark/streaming/scheduler/StreamInputInfo.html |   537 +
 .../streaming/scheduler/StreamingListener.html     |   644 +
 .../scheduler/StreamingListenerBatchCompleted.html |   481 +
 .../scheduler/StreamingListenerBatchStarted.html   |   481 +
 .../scheduler/StreamingListenerBatchSubmitted.html |   481 +
 .../scheduler/StreamingListenerEvent.html          |   490 +
 .../StreamingListenerOutputOperationCompleted.html |   481 +
 .../StreamingListenerOutputOperationStarted.html   |   481 +
 .../scheduler/StreamingListenerReceiverError.html  |   481 +
 .../StreamingListenerReceiverStarted.html          |   481 +
 .../StreamingListenerReceiverStopped.html          |   481 +
 .../StreamingListenerStreamingStarted.html         |   481 +
 .../apache/spark/streaming/scheduler/package.html  |   502 +
 .../streaming/scheduler/rate/RateEstimator$.html   |   506 +
 .../spark/streaming/scheduler/rate/package.html    |   118 +
 .../apache/spark/streaming/util/WriteAheadLog.html |   590 +
 .../streaming/util/WriteAheadLogRecordHandle.html  |   504 +
 .../org/apache/spark/streaming/util/package.html   |   135 +
 .../scala/org/apache/spark/util/AccumulatorV2.html |   712 +
 .../spark/util/ChildFirstURLClassLoader.html       |  1151 +
 .../apache/spark/util/CollectionAccumulator.html   |   710 +
 .../org/apache/spark/util/DoubleAccumulator.html   |   778 +
 .../api/scala/org/apache/spark/util/EnumUtil.html  |   502 +
 .../spark/util/LegacyAccumulatorWrapper.html       |   710 +
 .../org/apache/spark/util/LongAccumulator.html     |   777 +
 .../scala/org/apache/spark/util/MutablePair.html   |   609 +
 .../apache/spark/util/MutableURLClassLoader.html   |  1164 +
 .../org/apache/spark/util/ParentClassLoader.html   |  1010 +
 .../org/apache/spark/util/SizeEstimator$.html      |   769 +
 .../scala/org/apache/spark/util/StatCounter$.html  |   522 +
 .../scala/org/apache/spark/util/StatCounter.html   |   800 +
 .../apache/spark/util/TaskCompletionListener.html  |   508 +
 .../org/apache/spark/util/TaskFailureListener.html |   509 +
 .../api/scala/org/apache/spark/util/package.html   |   459 +
 .../spark/util/random/BernoulliCellSampler.html    |   583 +
 .../apache/spark/util/random/BernoulliSampler.html |   566 +
 .../apache/spark/util/random/PoissonSampler.html   |   583 +
 .../org/apache/spark/util/random/Pseudorandom.html |   510 +
 .../apache/spark/util/random/RandomSampler.html    |   552 +
 .../org/apache/spark/util/random/package.html      |   245 +
 .../org/apache/spark/util/sketch/BloomFilter.html  |   726 +
 .../apache/spark/util/sketch/CountMinSketch.html   |   794 +
 .../util/sketch/IncompatibleMergeException.html    |   712 +
 .../org/apache/spark/util/sketch/package.html      |   152 +
 site/docs/2.4.3/api/scala/org/package.html         |   118 +
 site/docs/2.4.3/api/scala/package.html             |   118 +
 site/docs/2.4.3/api/sql/404.html                   |   119 +
 site/docs/2.4.3/api/sql/css/theme.css              |    12 +
 site/docs/2.4.3/api/sql/css/theme_extra.css        |   197 +
 .../2.4.3/api/sql/fonts/fontawesome-webfont.eot    |   Bin 0 -> 37405 bytes
 .../2.4.3/api/sql/fonts/fontawesome-webfont.svg    |   399 +
 .../2.4.3/api/sql/fonts/fontawesome-webfont.ttf    |   Bin 0 -> 79076 bytes
 .../2.4.3/api/sql/fonts/fontawesome-webfont.woff   |   Bin 0 -> 43572 bytes
 site/docs/2.4.3/api/sql/img/favicon.ico            |   Bin 0 -> 1150 bytes
 site/docs/2.4.3/api/sql/index.html                 |  3648 ++
 site/docs/2.4.3/api/sql/js/jquery-2.1.1.min.js     |     4 +
 site/docs/2.4.3/api/sql/js/modernizr-2.8.3.min.js  |     1 +
 site/docs/2.4.3/api/sql/js/theme.js                |   105 +
 site/docs/2.4.3/api/sql/search.html                |   126 +
 site/docs/2.4.3/api/sql/search/lunr.js             |  2986 ++
 site/docs/2.4.3/api/sql/search/main.js             |    96 +
 site/docs/2.4.3/api/sql/search/search_index.json   |     1 +
 site/docs/2.4.3/api/sql/search/worker.js           |   128 +
 site/docs/2.4.3/api/sql/sitemap.xml                |     8 +
 site/docs/2.4.3/api/sql/sitemap.xml.gz             |   Bin 0 -> 190 bytes
 site/docs/2.4.3/building-spark.html                |   507 +
 site/docs/2.4.3/building-with-maven.html           |    10 +
 site/docs/2.4.3/cloud-integration.html             |   389 +
 site/docs/2.4.3/cluster-overview.html              |   308 +
 site/docs/2.4.3/configuration.html                 |  2497 +
 site/docs/2.4.3/contributing-to-spark.html         |   175 +
 site/docs/2.4.3/css/api-docs.css                   |    35 +
 site/docs/2.4.3/css/api-javadocs.css               |    52 +
 site/docs/2.4.3/css/bootstrap-responsive.css       |  1040 +
 site/docs/2.4.3/css/bootstrap-responsive.min.css   |     9 +
 site/docs/2.4.3/css/bootstrap.css                  |  5624 ++
 site/docs/2.4.3/css/bootstrap.min.css              |     9 +
 site/docs/2.4.3/css/main.css                       |   289 +
 site/docs/2.4.3/css/pygments-default.css           |    76 +
 site/docs/2.4.3/graphx-programming-guide.html      |  1208 +
 site/docs/2.4.3/hadoop-provided.html               |   190 +
 site/docs/2.4.3/hardware-provisioning.html         |   242 +
 site/docs/2.4.3/img/cluster-overview.png           |   Bin 0 -> 22912 bytes
 site/docs/2.4.3/img/cluster-overview.pptx          |   Bin 0 -> 28133 bytes
 site/docs/2.4.3/img/edge_cut_vs_vertex_cut.png     |   Bin 0 -> 51015 bytes
 site/docs/2.4.3/img/glyphicons-halflings-white.png |   Bin 0 -> 8777 bytes
 site/docs/2.4.3/img/glyphicons-halflings.png       |   Bin 0 -> 12799 bytes
 site/docs/2.4.3/img/graphx_figures.pptx            |   Bin 0 -> 1123363 bytes
 site/docs/2.4.3/img/graphx_logo.png                |   Bin 0 -> 22875 bytes
 site/docs/2.4.3/img/java-sm.png                    |   Bin 0 -> 670 bytes
 site/docs/2.4.3/img/k8s-cluster-mode.png           |   Bin 0 -> 55538 bytes
 site/docs/2.4.3/img/ml-Pipeline.png                |   Bin 0 -> 38536 bytes
 site/docs/2.4.3/img/ml-PipelineModel.png           |   Bin 0 -> 39228 bytes
 site/docs/2.4.3/img/ml-Pipelines.pptx              |   Bin 0 -> 56777 bytes
 site/docs/2.4.3/img/property_graph.png             |   Bin 0 -> 135699 bytes
 site/docs/2.4.3/img/python-sm.png                  |   Bin 0 -> 1455 bytes
 site/docs/2.4.3/img/scala-sm.png                   |   Bin 0 -> 2241 bytes
 site/docs/2.4.3/img/spark-logo-hd.png              |   Bin 0 -> 11306 bytes
 site/docs/2.4.3/img/spark-webui-accumulators.png   |   Bin 0 -> 160167 bytes
 site/docs/2.4.3/img/streaming-arch.png             |   Bin 0 -> 51972 bytes
 site/docs/2.4.3/img/streaming-dstream-ops.png      |   Bin 0 -> 33495 bytes
 site/docs/2.4.3/img/streaming-dstream-window.png   |   Bin 0 -> 26622 bytes
 site/docs/2.4.3/img/streaming-dstream.png          |   Bin 0 -> 17843 bytes
 site/docs/2.4.3/img/streaming-figures.pptx         |   Bin 0 -> 887551 bytes
 site/docs/2.4.3/img/streaming-flow.png             |   Bin 0 -> 20425 bytes
 site/docs/2.4.3/img/streaming-kinesis-arch.png     |   Bin 0 -> 86336 bytes
 .../img/structured-streaming-example-model.png     |   Bin 0 -> 79409 bytes
 .../2.4.3/img/structured-streaming-late-data.png   |   Bin 0 -> 91513 bytes
 site/docs/2.4.3/img/structured-streaming-model.png |   Bin 0 -> 37321 bytes
 .../img/structured-streaming-stream-as-a-table.png |   Bin 0 -> 47791 bytes
 .../structured-streaming-watermark-append-mode.png |   Bin 0 -> 249196 bytes
 .../structured-streaming-watermark-update-mode.png |   Bin 0 -> 299141 bytes
 .../docs/2.4.3/img/structured-streaming-window.png |   Bin 0 -> 88102 bytes
 site/docs/2.4.3/img/structured-streaming.pptx      |   Bin 0 -> 1126657 bytes
 site/docs/2.4.3/img/triplet.png                    |   Bin 0 -> 19255 bytes
 site/docs/2.4.3/img/vertex_routing_edge_tables.png |   Bin 0 -> 323162 bytes
 site/docs/2.4.3/index.html                         |   341 +
 site/docs/2.4.3/job-scheduling.html                |   455 +
 site/docs/2.4.3/js/api-docs.js                     |    64 +
 site/docs/2.4.3/js/api-javadocs.js                 |    60 +
 site/docs/2.4.3/js/main.js                         |    97 +
 site/docs/2.4.3/js/vendor/anchor.min.js            |     6 +
 site/docs/2.4.3/js/vendor/bootstrap.js             |  2027 +
 site/docs/2.4.3/js/vendor/bootstrap.min.js         |     6 +
 site/docs/2.4.3/js/vendor/jquery-1.12.4.min.js     |     5 +
 .../js/vendor/modernizr-2.6.1-respond-1.1.0.min.js |    11 +
 site/docs/2.4.3/ml-advanced.html                   |   502 +
 site/docs/2.4.3/ml-ann.html                        |   406 +
 site/docs/2.4.3/ml-classification-regression.html  |  3980 ++
 site/docs/2.4.3/ml-clustering.html                 |  1004 +
 site/docs/2.4.3/ml-collaborative-filtering.html    |   782 +
 site/docs/2.4.3/ml-datasource.html                 |   501 +
 site/docs/2.4.3/ml-decision-tree.html              |   406 +
 site/docs/2.4.3/ml-ensembles.html                  |   406 +
 site/docs/2.4.3/ml-features.html                   |  4795 ++
 site/docs/2.4.3/ml-frequent-pattern-mining.html    |   691 +
 site/docs/2.4.3/ml-guide.html                      |   569 +
 site/docs/2.4.3/ml-linear-methods.html             |   406 +
 site/docs/2.4.3/ml-migration-guides.html           |   804 +
 site/docs/2.4.3/ml-pipeline.html                   |  1071 +
 site/docs/2.4.3/ml-statistics.html                 |   726 +
 site/docs/2.4.3/ml-survival-regression.html        |   406 +
 site/docs/2.4.3/ml-tuning.html                     |   888 +
 .../2.4.3/mllib-classification-regression.html     |   501 +
 site/docs/2.4.3/mllib-clustering.html              |  1376 +
 site/docs/2.4.3/mllib-collaborative-filtering.html |   648 +
 site/docs/2.4.3/mllib-data-types.html              |  1140 +
 site/docs/2.4.3/mllib-decision-tree.html           |   912 +
 .../docs/2.4.3/mllib-dimensionality-reduction.html |   723 +
 site/docs/2.4.3/mllib-ensembles.html               |  1205 +
 site/docs/2.4.3/mllib-evaluation-metrics.html      |  1808 +
 site/docs/2.4.3/mllib-feature-extraction.html      |  1047 +
 site/docs/2.4.3/mllib-frequent-pattern-mining.html |   756 +
 site/docs/2.4.3/mllib-guide.html                   |   466 +
 site/docs/2.4.3/mllib-isotonic-regression.html     |   592 +
 site/docs/2.4.3/mllib-linear-methods.html          |  1229 +
 site/docs/2.4.3/mllib-migration-guides.html        |   405 +
 site/docs/2.4.3/mllib-naive-bayes.html             |   539 +
 site/docs/2.4.3/mllib-optimization.html            |   807 +
 site/docs/2.4.3/mllib-pmml-model-export.html       |   481 +
 site/docs/2.4.3/mllib-statistics.html              |  1270 +
 site/docs/2.4.3/monitoring.html                    |   842 +
 site/docs/2.4.3/programming-guide.html             |   176 +
 site/docs/2.4.3/quick-start.html                   |   585 +
 site/docs/2.4.3/rdd-programming-guide.html         |  1764 +
 site/docs/2.4.3/running-on-kubernetes.html         |  1025 +
 site/docs/2.4.3/running-on-mesos.html              |  1015 +
 site/docs/2.4.3/running-on-yarn.html               |   825 +
 site/docs/2.4.3/security.html                      |   940 +
 site/docs/2.4.3/spark-standalone.html              |   619 +
 site/docs/2.4.3/sparkr.html                        |   931 +
 site/docs/2.4.3/sql-data-sources-avro.html         |   721 +
 site/docs/2.4.3/sql-data-sources-hive-tables.html  |   793 +
 site/docs/2.4.3/sql-data-sources-jdbc.html         |   671 +
 site/docs/2.4.3/sql-data-sources-json.html         |   549 +
 .../sql-data-sources-load-save-functions.html      |   759 +
 site/docs/2.4.3/sql-data-sources-orc.html          |   362 +
 site/docs/2.4.3/sql-data-sources-parquet.html      |   874 +
 .../2.4.3/sql-data-sources-troubleshooting.html    |   347 +
 site/docs/2.4.3/sql-data-sources.html              |   390 +
 site/docs/2.4.3/sql-distributed-sql-engine.html    |   363 +
 site/docs/2.4.3/sql-getting-started.html           |  1738 +
 .../sql-migration-guide-hive-compatibility.html    |   448 +
 site/docs/2.4.3/sql-migration-guide-upgrade.html   |   976 +
 site/docs/2.4.3/sql-migration-guide.html           |   306 +
 site/docs/2.4.3/sql-performance-tuning.html        |   430 +
 site/docs/2.4.3/sql-programming-guide.html         |   299 +
 site/docs/2.4.3/sql-pyspark-pandas-with-arrow.html |   587 +
 site/docs/2.4.3/sql-reference.html                 |   956 +
 site/docs/2.4.3/storage-openstack-swift.html       |   300 +
 site/docs/2.4.3/streaming-custom-receivers.html    |   416 +
 site/docs/2.4.3/streaming-flume-integration.html   |   371 +
 .../2.4.3/streaming-kafka-0-10-integration.html    |   480 +
 .../2.4.3/streaming-kafka-0-8-integration.html     |   393 +
 site/docs/2.4.3/streaming-kafka-integration.html   |   221 +
 site/docs/2.4.3/streaming-kinesis-integration.html |   475 +
 site/docs/2.4.3/streaming-programming-guide.html   |  2675 +
 .../structured-streaming-kafka-integration.html    |   766 +
 .../structured-streaming-programming-guide.html    |  3363 ++
 site/docs/2.4.3/submitting-applications.html       |   389 +
 site/docs/2.4.3/tuning.html                        |   519 +
 site/docs/latest                                   |     2 +-
 3325 files changed, 2057081 insertions(+), 1 deletion(-)

diff --git a/site/docs/2.4.3/README.md b/site/docs/2.4.3/README.md
new file mode 100644
index 0000000..fb67c4b
--- /dev/null
+++ b/site/docs/2.4.3/README.md
@@ -0,0 +1,87 @@
+Welcome to the Spark documentation!
+
+This readme will walk you through navigating and building the Spark documentation, which is included
+here with the Spark source code. You can also find documentation specific to release versions of
+Spark at https://spark.apache.org/documentation.html.
+
+Read on to learn more about viewing documentation in plain text (i.e., markdown) or building the
+documentation yourself. Why build it yourself? So that you have the docs that correspond to
+whichever version of Spark you currently have checked out of revision control.
+
+## Prerequisites
+
+The Spark documentation build uses a number of tools to build HTML docs and API docs in Scala, Java,
+Python, R and SQL.
+
+You need to have [Ruby](https://www.ruby-lang.org/en/documentation/installation/) and
+[Python](https://docs.python.org/2/using/unix.html#getting-and-installing-the-latest-version-of-python)
+installed. Also install the following libraries:
+
+```sh
+$ sudo gem install jekyll jekyll-redirect-from pygments.rb
+$ sudo pip install Pygments
+# Following is needed only for generating API docs
+$ sudo pip install sphinx pypandoc mkdocs
+$ sudo Rscript -e 'install.packages(c("knitr", "devtools", "rmarkdown"), repos="http://cran.stat.ucla.edu/")'
+$ sudo Rscript -e 'devtools::install_version("roxygen2", version = "5.0.1", repos="http://cran.stat.ucla.edu/")'
+$ sudo Rscript -e 'devtools::install_version("testthat", version = "1.0.2", repos="http://cran.stat.ucla.edu/")'
+```
+
+Note: If you are on a system with both Ruby 1.9 and Ruby 2.0 you may need to replace gem with gem2.0.
+
+Note: Other versions of roxygen2 might work in SparkR documentation generation but `RoxygenNote` field in `$SPARK_HOME/R/pkg/DESCRIPTION` is 5.0.1, which is updated if the version is mismatched.
+
+## Generating the Documentation HTML
+
+We include the Spark documentation as part of the source (as opposed to using a hosted wiki, such as
+the github wiki, as the definitive documentation) to enable the documentation to evolve along with
+the source code and be captured by revision control (currently git). This way the code automatically
+includes the version of the documentation that is relevant regardless of which version or release
+you have checked out or downloaded.
+
+In this directory you will find text files formatted using Markdown, with an ".md" suffix. You can
+read those text files directly if you want. Start with `index.md`.
+
+Execute `jekyll build` from the `docs/` directory to compile the site. Compiling the site with
+Jekyll will create a directory called `_site` containing `index.html` as well as the rest of the
+compiled files.
+
+```sh
+$ cd docs
+$ jekyll build
+```
+
+You can modify the default Jekyll build as follows:
+
+```sh
+# Skip generating API docs (which takes a while)
+$ SKIP_API=1 jekyll build
+
+# Serve content locally on port 4000
+$ jekyll serve --watch
+
+# Build the site with extra features used on the live page
+$ PRODUCTION=1 jekyll build
+```
+
+## API Docs (Scaladoc, Javadoc, Sphinx, roxygen2, MkDocs)
+
+You can build just the Spark scaladoc and javadoc by running `build/sbt unidoc` from the `$SPARK_HOME` directory.
+
+Similarly, you can build just the PySpark docs by running `make html` from the
+`$SPARK_HOME/python/docs` directory. Documentation is only generated for classes that are listed as
+public in `__init__.py`. The SparkR docs can be built by running `$SPARK_HOME/R/create-docs.sh`, and
+the SQL docs can be built by running `$SPARK_HOME/sql/create-docs.sh`
+after [building Spark](https://github.com/apache/spark#building-spark) first.
+
+When you run `jekyll build` in the `docs` directory, it will also copy over the scaladoc and javadoc for the various
+Spark subprojects into the `docs` directory (and then also into the `_site` directory). We use a
+jekyll plugin to run `build/sbt unidoc` before building the site so if you haven't run it (recently) it
+may take some time as it generates all of the scaladoc and javadoc using [Unidoc](https://github.com/sbt/sbt-unidoc).
+The jekyll plugin also generates the PySpark docs using [Sphinx](http://sphinx-doc.org/), SparkR docs
+using [roxygen2](https://cran.r-project.org/web/packages/roxygen2/index.html) and SQL docs
+using [MkDocs](https://www.mkdocs.org/).
+
+NOTE: To skip the step of building and copying over the Scala, Java, Python, R and SQL API docs, run `SKIP_API=1
+jekyll build`. In addition, `SKIP_SCALADOC=1`, `SKIP_PYTHONDOC=1`, `SKIP_RDOC=1` and `SKIP_SQLDOC=1` can be used
+to skip a single step of the corresponding language. `SKIP_SCALADOC` indicates skipping both the Scala and Java docs.
diff --git a/site/docs/2.4.3/api.html b/site/docs/2.4.3/api.html
new file mode 100644
index 0000000..d559852
--- /dev/null
+++ b/site/docs/2.4.3/api.html
@@ -0,0 +1,181 @@
+
+<!DOCTYPE html>
+<!--[if lt IE 7]>      <html class="no-js lt-ie9 lt-ie8 lt-ie7"> <![endif]-->
+<!--[if IE 7]>         <html class="no-js lt-ie9 lt-ie8"> <![endif]-->
+<!--[if IE 8]>         <html class="no-js lt-ie9"> <![endif]-->
+<!--[if gt IE 8]><!--> <html class="no-js"> <!--<![endif]-->
+    <head>
+        <meta charset="utf-8">
+        <meta http-equiv="X-UA-Compatible" content="IE=edge,chrome=1">
+        <title>Spark API Documentation - Spark 2.4.3 Documentation</title>
+        
+
+        
+
+        <link rel="stylesheet" href="css/bootstrap.min.css">
+        <style>
+            body {
+                padding-top: 60px;
+                padding-bottom: 40px;
+            }
+        </style>
+        <meta name="viewport" content="width=device-width">
+        <link rel="stylesheet" href="css/bootstrap-responsive.min.css">
+        <link rel="stylesheet" href="css/main.css">
+
+        <script src="js/vendor/modernizr-2.6.1-respond-1.1.0.min.js"></script>
+
+        <link rel="stylesheet" href="css/pygments-default.css">
+
+        
+        <!-- Google analytics script -->
+        <script type="text/javascript">
+          var _gaq = _gaq || [];
+          _gaq.push(['_setAccount', 'UA-32518208-2']);
+          _gaq.push(['_trackPageview']);
+
+          (function() {
+            var ga = document.createElement('script'); ga.type = 'text/javascript'; ga.async = true;
+            ga.src = ('https:' == document.location.protocol ? 'https://ssl' : 'http://www') + '.google-analytics.com/ga.js';
+            var s = document.getElementsByTagName('script')[0]; s.parentNode.insertBefore(ga, s);
+          })();
+        </script>
+        
+
+    </head>
+    <body>
+        <!--[if lt IE 7]>
+            <p class="chromeframe">You are using an outdated browser. <a href="https://browsehappy.com/">Upgrade your browser today</a> or <a href="http://www.google.com/chromeframe/?redirect=true">install Google Chrome Frame</a> to better experience this site.</p>
+        <![endif]-->
+
+        <!-- This code is taken from http://twitter.github.com/bootstrap/examples/hero.html -->
+
+        <div class="navbar navbar-fixed-top" id="topbar">
+            <div class="navbar-inner">
+                <div class="container">
+                    <div class="brand"><a href="index.html">
+                      <img src="img/spark-logo-hd.png" style="height:50px;"/></a><span class="version">2.4.3</span>
+                    </div>
+                    <ul class="nav">
+                        <!--TODO(andyk): Add class="active" attribute to li some how.-->
+                        <li><a href="index.html">Overview</a></li>
+
+                        <li class="dropdown">
+                            <a href="#" class="dropdown-toggle" data-toggle="dropdown">Programming Guides<b class="caret"></b></a>
+                            <ul class="dropdown-menu">
+                                <li><a href="quick-start.html">Quick Start</a></li>
+                                <li><a href="rdd-programming-guide.html">RDDs, Accumulators, Broadcasts Vars</a></li>
+                                <li><a href="sql-programming-guide.html">SQL, DataFrames, and Datasets</a></li>
+                                <li><a href="structured-streaming-programming-guide.html">Structured Streaming</a></li>
+                                <li><a href="streaming-programming-guide.html">Spark Streaming (DStreams)</a></li>
+                                <li><a href="ml-guide.html">MLlib (Machine Learning)</a></li>
+                                <li><a href="graphx-programming-guide.html">GraphX (Graph Processing)</a></li>
+                                <li><a href="sparkr.html">SparkR (R on Spark)</a></li>
+                            </ul>
+                        </li>
+
+                        <li class="dropdown">
+                            <a href="#" class="dropdown-toggle" data-toggle="dropdown">API Docs<b class="caret"></b></a>
+                            <ul class="dropdown-menu">
+                                <li><a href="api/scala/index.html#org.apache.spark.package">Scala</a></li>
+                                <li><a href="api/java/index.html">Java</a></li>
+                                <li><a href="api/python/index.html">Python</a></li>
+                                <li><a href="api/R/index.html">R</a></li>
+                                <li><a href="api/sql/index.html">SQL, Built-in Functions</a></li>
+                            </ul>
+                        </li>
+
+                        <li class="dropdown">
+                            <a href="#" class="dropdown-toggle" data-toggle="dropdown">Deploying<b class="caret"></b></a>
+                            <ul class="dropdown-menu">
+                                <li><a href="cluster-overview.html">Overview</a></li>
+                                <li><a href="submitting-applications.html">Submitting Applications</a></li>
+                                <li class="divider"></li>
+                                <li><a href="spark-standalone.html">Spark Standalone</a></li>
+                                <li><a href="running-on-mesos.html">Mesos</a></li>
+                                <li><a href="running-on-yarn.html">YARN</a></li>
+                                <li><a href="running-on-kubernetes.html">Kubernetes</a></li>
+                            </ul>
+                        </li>
+
+                        <li class="dropdown">
+                            <a href="api.html" class="dropdown-toggle" data-toggle="dropdown">More<b class="caret"></b></a>
+                            <ul class="dropdown-menu">
+                                <li><a href="configuration.html">Configuration</a></li>
+                                <li><a href="monitoring.html">Monitoring</a></li>
+                                <li><a href="tuning.html">Tuning Guide</a></li>
+                                <li><a href="job-scheduling.html">Job Scheduling</a></li>
+                                <li><a href="security.html">Security</a></li>
+                                <li><a href="hardware-provisioning.html">Hardware Provisioning</a></li>
+                                <li class="divider"></li>
+                                <li><a href="building-spark.html">Building Spark</a></li>
+                                <li><a href="https://spark.apache.org/contributing.html">Contributing to Spark</a></li>
+                                <li><a href="https://spark.apache.org/third-party-projects.html">Third Party Projects</a></li>
+                            </ul>
+                        </li>
+                    </ul>
+                    <!--<p class="navbar-text pull-right"><span class="version-text">v2.4.3</span></p>-->
+                </div>
+            </div>
+        </div>
+
+        <div class="container-wrapper">
+
+            
+                <div class="content" id="content">
+                    
+                        <h1 class="title">Spark API Documentation</h1>
+                    
+
+                    <p>Here you can read API docs for Spark and its submodules.</p>
+
+<ul>
+  <li><a href="api/scala/index.html">Spark Scala API (Scaladoc)</a></li>
+  <li><a href="api/java/index.html">Spark Java API (Javadoc)</a></li>
+  <li><a href="api/python/index.html">Spark Python API (Sphinx)</a></li>
+  <li><a href="api/R/index.html">Spark R API (Roxygen2)</a></li>
+  <li><a href="api/sql/index.html">Spark SQL, Built-in Functions (MkDocs)</a></li>
+</ul>
+
+
+                </div>
+            
+             <!-- /container -->
+        </div>
+
+        <script src="js/vendor/jquery-1.12.4.min.js"></script>
+        <script src="js/vendor/bootstrap.min.js"></script>
+        <script src="js/vendor/anchor.min.js"></script>
+        <script src="js/main.js"></script>
+
+        <!-- MathJax Section -->
+        <script type="text/x-mathjax-config">
+            MathJax.Hub.Config({
+                TeX: { equationNumbers: { autoNumber: "AMS" } }
+            });
+        </script>
+        <script>
+            // Note that we load MathJax this way to work with local file (file://), HTTP and HTTPS.
+            // We could use "//cdn.mathjax...", but that won't support "file://".
+            (function(d, script) {
+                script = d.createElement('script');
+                script.type = 'text/javascript';
+                script.async = true;
+                script.onload = function(){
+                    MathJax.Hub.Config({
+                        tex2jax: {
+                            inlineMath: [ ["$", "$"], ["\\\\(","\\\\)"] ],
+                            displayMath: [ ["$$","$$"], ["\\[", "\\]"] ],
+                            processEscapes: true,
+                            skipTags: ['script', 'noscript', 'style', 'textarea', 'pre']
+                        }
+                    });
+                };
+                script.src = ('https:' == document.location.protocol ? 'https://' : 'http://') +
+                    'cdnjs.cloudflare.com/ajax/libs/mathjax/2.7.1/MathJax.js' +
+                    '?config=TeX-AMS-MML_HTMLorMML';
+                d.getElementsByTagName('head')[0].appendChild(script);
+            }(document));
+        </script>
+    </body>
+</html>
diff --git a/site/docs/2.4.3/api/DESCRIPTION b/site/docs/2.4.3/api/DESCRIPTION
new file mode 100644
index 0000000..6e19a45
--- /dev/null
+++ b/site/docs/2.4.3/api/DESCRIPTION
@@ -0,0 +1,63 @@
+Package: SparkR
+Type: Package
+Version: 2.4.3
+Title: R Front End for 'Apache Spark'
+Description: Provides an R Front end for 'Apache Spark' <https://spark.apache.org>.
+Authors@R: c(person("Shivaram", "Venkataraman", role = c("aut", "cre"),
+                    email = "shivaram@cs.berkeley.edu"),
+             person("Xiangrui", "Meng", role = "aut",
+                    email = "meng@databricks.com"),
+             person("Felix", "Cheung", role = "aut",
+                    email = "felixcheung@apache.org"),
+             person(family = "The Apache Software Foundation", role = c("aut", "cph")))
+License: Apache License (== 2.0)
+URL: https://www.apache.org/ https://spark.apache.org/
+BugReports: https://spark.apache.org/contributing.html
+SystemRequirements: Java (== 8)
+Depends:
+    R (>= 3.0),
+    methods
+Suggests:
+    knitr,
+    rmarkdown,
+    testthat,
+    e1071,
+    survival
+Collate:
+    'schema.R'
+    'generics.R'
+    'jobj.R'
+    'column.R'
+    'group.R'
+    'RDD.R'
+    'pairRDD.R'
+    'DataFrame.R'
+    'SQLContext.R'
+    'WindowSpec.R'
+    'backend.R'
+    'broadcast.R'
+    'catalog.R'
+    'client.R'
+    'context.R'
+    'deserialize.R'
+    'functions.R'
+    'install.R'
+    'jvm.R'
+    'mllib_classification.R'
+    'mllib_clustering.R'
+    'mllib_fpm.R'
+    'mllib_recommendation.R'
+    'mllib_regression.R'
+    'mllib_stat.R'
+    'mllib_tree.R'
+    'mllib_utils.R'
+    'serialize.R'
+    'sparkR.R'
+    'stats.R'
+    'streaming.R'
+    'types.R'
+    'utils.R'
+    'window.R'
+RoxygenNote: 5.0.1
+VignetteBuilder: knitr
+NeedsCompilation: no
diff --git a/site/docs/2.4.3/api/R/00Index.html b/site/docs/2.4.3/api/R/00Index.html
new file mode 100644
index 0000000..3d07dea
--- /dev/null
+++ b/site/docs/2.4.3/api/R/00Index.html
@@ -0,0 +1,23 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
+<html xmlns="http://www.w3.org/1999/xhtml">
+<head><title>R: R Front End for 'Apache Spark'</title>
+<meta http-equiv="Content-Type" content="text/html; charset=utf-8" />
+<link rel="stylesheet" type="text/css" href="R.css" />
+</head><body>
+<h1> R Front End for 'Apache Spark'
+<img class="toplogo" src="http://stat.ethz.ch/R-manual/R-devel/doc/html/Rlogo.svg" alt="[R logo]" />
+</h1>
+<hr/>
+<div style="text-align: center;">
+<a href="http://stat.ethz.ch/R-manual/R-devel/doc/html/packages.html"><img class="arrow" src="http://stat.ethz.ch/R-manual/R-devel/doc/html/left.jpg" alt="[Up]" /></a>
+<a href="http://stat.ethz.ch/R-manual/R-devel/doc/html/index.html"><img class="arrow" src="http://stat.ethz.ch/R-manual/R-devel/doc/html/up.jpg" alt="[Top]" /></a>
+</div><h2>Documentation for package &lsquo;SparkR&rsquo; version 2.4.3</h2>
+
+<ul><li><a href="../DESCRIPTION">DESCRIPTION file</a>.</li>
+</ul>
+
+<h2>Help Pages</h2>
+
+
+There are no help pages in this package
+</body></html>
diff --git a/site/docs/2.4.3/api/R/00frame_toc.html b/site/docs/2.4.3/api/R/00frame_toc.html
new file mode 100644
index 0000000..a8be285
--- /dev/null
+++ b/site/docs/2.4.3/api/R/00frame_toc.html
@@ -0,0 +1,93 @@
+<!DOCTYPE html>
+<html>
+<head>
+<meta http-equiv="Content-Type" content="text/html; charset=utf-8"/>
+
+<title>R Documentation of SparkR</title>
+
+<script type="text/javascript">
+window.onload = function() {
+  var imgs = document.getElementsByTagName('img'), i, img;
+  for (i = 0; i < imgs.length; i++) {
+    img = imgs[i];
+    // center an image if it is the only element of its parent
+    if (img.parentElement.childElementCount === 1)
+      img.parentElement.style.textAlign = 'center';
+  }
+};
+</script>
+
+
+
+
+
+<style type="text/css">
+* {
+	font-family: "Trebuchet MS", "Lucida Grande", "Lucida Sans Unicode", "Lucida Sans", Arial, sans-serif;
+	font-size: 14px;
+}
+body {
+  padding: 0 5px; 
+  margin: 0 auto; 
+  width: 80%;
+  max-width: 60em; /* 960px */
+}
+
+h1, h2, h3, h4, h5, h6 {
+	color: #666;
+}
+h1, h2 {
+	text-align: center;
+}
+h1 {
+	font-size: x-large;
+}
+h2, h3 {
+	font-size: large;
+}
+h4, h6 {
+	font-style: italic;
+}
+h3 {
+	border-left: solid 5px #ddd;
+	padding-left: 5px;
+	font-variant: small-caps;
+}
+
+p img {
+	display: block;
+	margin: auto;
+}
+
+span, code, pre {
+	font-family: Monaco, "Lucida Console", "Courier New", Courier, monospace;
+}
+span.acronym {}
+span.env {
+	font-style: italic;
+}
+span.file {}
+span.option {}
+span.pkg {
+	font-weight: bold;
+}
+span.samp{}
+
+dt, p code {
+	background-color: #F7F7F7;
+}
+
+</style>
+
+
+
+</head>
+
+<body>
+<h1>SparkR</h1>
+
+<p>Generated with <a href="https://yihui.name/knitr">knitr</a>  1.22</p>
+
+</body>
+
+</html>
diff --git a/site/docs/2.4.3/api/R/R.css b/site/docs/2.4.3/api/R/R.css
new file mode 100644
index 0000000..212cf4c
--- /dev/null
+++ b/site/docs/2.4.3/api/R/R.css
@@ -0,0 +1,55 @@
+* {
+	font-family: "Trebuchet MS", "Lucida Grande", "Lucida Sans Unicode", "Lucida Sans", Arial, sans-serif;
+	font-size: 14px;
+}
+body {
+  padding: 0 5px; 
+  margin: 0 auto; 
+  width: 80%;
+  max-width: 60em; /* 960px */
+}
+
+h1, h2, h3, h4, h5, h6 {
+	color: #666;
+}
+h1, h2 {
+	text-align: center;
+}
+h1 {
+	font-size: x-large;
+}
+h2, h3 {
+	font-size: large;
+}
+h4, h6 {
+	font-style: italic;
+}
+h3 {
+	border-left: solid 5px #ddd;
+	padding-left: 5px;
+	font-variant: small-caps;
+}
+
+p img {
+	display: block;
+	margin: auto;
+}
+
+span, code, pre {
+	font-family: Monaco, "Lucida Console", "Courier New", Courier, monospace;
+}
+span.acronym {}
+span.env {
+	font-style: italic;
+}
+span.file {}
+span.option {}
+span.pkg {
+	font-weight: bold;
+}
+span.samp{}
+
+dt, p code {
+	background-color: #F7F7F7;
+}
+
diff --git a/site/docs/2.4.3/api/R/index.html b/site/docs/2.4.3/api/R/index.html
new file mode 100644
index 0000000..11d4c8d
--- /dev/null
+++ b/site/docs/2.4.3/api/R/index.html
@@ -0,0 +1,9 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Frameset//EN" "http://www.w3.org/TR/html4/frameset.dtd">
+<html>
+<head><title>Documentation of the SparkR package</title></head>
+<frameset cols="15%,*">
+  <frame src="00frame_toc.html">
+  <frame src="00Index.html" name="content">
+</frameset>
+</html>
+
diff --git a/site/docs/2.4.3/api/java/allclasses-frame.html b/site/docs/2.4.3/api/java/allclasses-frame.html
new file mode 100644
index 0000000..efc623d
--- /dev/null
+++ b/site/docs/2.4.3/api/java/allclasses-frame.html
@@ -0,0 +1,1322 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (1.8.0_121) on Tue May 07 14:11:42 PDT 2019 -->
+<title>All Classes (Spark 2.4.3 JavaDoc)</title>
+<meta name="date" content="2019-05-07">
+<link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
+<script type="text/javascript" src="script.js"></script>
+</head>
+<body>
+<h1 class="bar">All&nbsp;Classes</h1>
+<div class="indexContainer">
+<ul>
+<li><a href="org/apache/spark/mllib/tree/loss/AbsoluteError.html" title="class in org.apache.spark.mllib.tree.loss" target="classFrame">AbsoluteError</a></li>
+<li><a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher" target="classFrame">AbstractLauncher</a></li>
+<li><a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark" target="classFrame">Accumulable</a></li>
+<li><a href="org/apache/spark/scheduler/AccumulableInfo.html" title="class in org.apache.spark.scheduler" target="classFrame">AccumulableInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/AccumulableInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">AccumulableInfo</a></li>
+<li><a href="org/apache/spark/AccumulableParam.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">AccumulableParam</span></a></li>
+<li><a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark" target="classFrame">Accumulator</a></li>
+<li><a href="org/apache/spark/util/AccumulatorContext.html" title="class in org.apache.spark.util" target="classFrame">AccumulatorContext</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">AccumulatorParam</span></a></li>
+<li><a href="org/apache/spark/AccumulatorParam.DoubleAccumulatorParam$.html" title="class in org.apache.spark" target="classFrame">AccumulatorParam.DoubleAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.FloatAccumulatorParam$.html" title="class in org.apache.spark" target="classFrame">AccumulatorParam.FloatAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.IntAccumulatorParam$.html" title="class in org.apache.spark" target="classFrame">AccumulatorParam.IntAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.LongAccumulatorParam$.html" title="class in org.apache.spark" target="classFrame">AccumulatorParam.LongAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.StringAccumulatorParam$.html" title="class in org.apache.spark" target="classFrame">AccumulatorParam.StringAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/util/AccumulatorV2.html" title="class in org.apache.spark.util" target="classFrame">AccumulatorV2</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTAggregator.html" title="class in org.apache.spark.ml.regression" target="classFrame">AFTAggregator</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTCostFun.html" title="class in org.apache.spark.ml.regression" target="classFrame">AFTCostFun</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression" target="classFrame">AFTSurvivalRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTSurvivalRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">AFTSurvivalRegressionModel</a></li>
+<li><a href="org/apache/spark/sql/jdbc/AggregatedDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">AggregatedDialect</a></li>
+<li><a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html" title="class in org.apache.spark.graphx.impl" target="classFrame">AggregatingEdgeContext</a></li>
+<li><a href="org/apache/spark/Aggregator.html" title="class in org.apache.spark" target="classFrame">Aggregator</a></li>
+<li><a href="org/apache/spark/sql/expressions/Aggregator.html" title="class in org.apache.spark.sql.expressions" target="classFrame">Aggregator</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/Algo.html" title="class in org.apache.spark.mllib.tree.configuration" target="classFrame">Algo</a></li>
+<li><a href="org/apache/spark/scheduler/AllJobsCancelled.html" title="class in org.apache.spark.scheduler" target="classFrame">AllJobsCancelled</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/AllReceiverIds.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">AllReceiverIds</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.html" title="class in org.apache.spark.ml.recommendation" target="classFrame">ALS</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/ALS.html" title="class in org.apache.spark.mllib.recommendation" target="classFrame">ALS</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.InBlock$.html" title="class in org.apache.spark.ml.recommendation" target="classFrame">ALS.InBlock$</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.Rating.html" title="class in org.apache.spark.ml.recommendation" target="classFrame">ALS.Rating</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.Rating$.html" title="class in org.apache.spark.ml.recommendation" target="classFrame">ALS.Rating$</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.RatingBlock$.html" title="class in org.apache.spark.ml.recommendation" target="classFrame">ALS.RatingBlock$</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALSModel.html" title="class in org.apache.spark.ml.recommendation" target="classFrame">ALSModel</a></li>
+<li><a href="org/apache/spark/sql/AnalysisException.html" title="class in org.apache.spark.sql" target="classFrame">AnalysisException</a></li>
+<li><a href="org/apache/spark/sql/sources/And.html" title="class in org.apache.spark.sql.sources" target="classFrame">And</a></li>
+<li><a href="org/apache/spark/sql/types/AnyDataType.html" title="class in org.apache.spark.sql.types" target="classFrame">AnyDataType</a></li>
+<li><a href="org/apache/spark/ui/jobs/ApiHelper.html" title="class in org.apache.spark.ui.jobs" target="classFrame">ApiHelper</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ApplicationAttemptInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationEnvironmentInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ApplicationEnvironmentInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ApplicationInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationStatus.html" title="enum in org.apache.spark.status.api.v1" target="classFrame">ApplicationStatus</a></li>
+<li><a href="org/apache/spark/ml/ann/ApplyInPlace.html" title="class in org.apache.spark.ml.ann" target="classFrame">ApplyInPlace</a></li>
+<li><a href="org/apache/spark/status/AppStatusUtils.html" title="class in org.apache.spark.status" target="classFrame">AppStatusUtils</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/AreaUnderCurve.html" title="class in org.apache.spark.mllib.evaluation" target="classFrame">AreaUnderCurve</a></li>
+<li><a href="org/apache/spark/sql/types/ArrayType.html" title="class in org.apache.spark.sql.types" target="classFrame">ArrayType</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ArrowColumnVector.html" title="class in org.apache.spark.sql.vectorized" target="classFrame">ArrowColumnVector</a></li>
+<li><a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html" title="class in org.apache.spark.scheduler" target="classFrame">AskPermissionToCommitOutput</a></li>
+<li><a href="org/apache/spark/ml/fpm/AssociationRules.html" title="class in org.apache.spark.ml.fpm" target="classFrame">AssociationRules</a></li>
+<li><a href="org/apache/spark/mllib/fpm/AssociationRules.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">AssociationRules</a></li>
+<li><a href="org/apache/spark/mllib/fpm/AssociationRules.Rule.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">AssociationRules.Rule</a></li>
+<li><a href="org/apache/spark/scheduler/AsyncEventQueue.html" title="class in org.apache.spark.scheduler" target="classFrame">AsyncEventQueue</a></li>
+<li><a href="org/apache/spark/rdd/AsyncRDDActions.html" title="class in org.apache.spark.rdd" target="classFrame">AsyncRDDActions</a></li>
+<li><a href="org/apache/spark/ml/attribute/Attribute.html" title="class in org.apache.spark.ml.attribute" target="classFrame">Attribute</a></li>
+<li><a href="org/apache/spark/ml/attribute/AttributeGroup.html" title="class in org.apache.spark.ml.attribute" target="classFrame">AttributeGroup</a></li>
+<li><a href="org/apache/spark/ml/attribute/AttributeKeys.html" title="class in org.apache.spark.ml.attribute" target="classFrame">AttributeKeys</a></li>
+<li><a href="org/apache/spark/ml/attribute/AttributeType.html" title="class in org.apache.spark.ml.attribute" target="classFrame">AttributeType</a></li>
+<li><a href="org/apache/spark/BarrierTaskContext.html" title="class in org.apache.spark" target="classFrame">BarrierTaskContext</a></li>
+<li><a href="org/apache/spark/BarrierTaskInfo.html" title="class in org.apache.spark" target="classFrame">BarrierTaskInfo</a></li>
+<li><a href="org/apache/spark/sql/sources/BaseRelation.html" title="class in org.apache.spark.sql.sources" target="classFrame">BaseRelation</a></li>
+<li><a href="org/apache/spark/api/r/BaseRRDD.html" title="class in org.apache.spark.api.r" target="classFrame">BaseRRDD</a></li>
+<li><a href="org/apache/spark/storage/BasicBlockReplicationPolicy.html" title="class in org.apache.spark.storage" target="classFrame">BasicBlockReplicationPolicy</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/BatchInfo.html" title="class in org.apache.spark.status.api.v1.streaming" target="classFrame">BatchInfo</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/BatchInfo.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">BatchInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/BatchStatus.html" title="enum in org.apache.spark.status.api.v1.streaming" target="classFrame">BatchStatus</a></li>
+<li><a href="org/apache/spark/util/random/BernoulliCellSampler.html" title="class in org.apache.spark.util.random" target="classFrame">BernoulliCellSampler</a></li>
+<li><a href="org/apache/spark/util/random/BernoulliSampler.html" title="class in org.apache.spark.util.random" target="classFrame">BernoulliSampler</a></li>
+<li><a href="org/apache/spark/ml/feature/Binarizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">Binarizer</a></li>
+<li><a href="org/apache/spark/ml/attribute/BinaryAttribute.html" title="class in org.apache.spark.ml.attribute" target="classFrame">BinaryAttribute</a></li>
+<li><a href="org/apache/spark/ml/evaluation/BinaryClassificationEvaluator.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">BinaryClassificationEvaluator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/BinaryClassificationMetrics.html" title="class in org.apache.spark.mllib.evaluation" target="classFrame">BinaryClassificationMetrics</a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification" target="classFrame"><span class="interfaceName">BinaryLogisticRegressionSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionSummaryImpl.html" title="class in org.apache.spark.ml.classification" target="classFrame">BinaryLogisticRegressionSummaryImpl</a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionTrainingSummary.html" title="interface in org.apache.spark.ml.classification" target="classFrame"><span class="interfaceName">BinaryLogisticRegressionTrainingSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionTrainingSummaryImpl.html" title="class in org.apache.spark.ml.classification" target="classFrame">BinaryLogisticRegressionTrainingSummaryImpl</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/BinarySample.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">BinarySample</a></li>
+<li><a href="org/apache/spark/sql/types/BinaryType.html" title="class in org.apache.spark.sql.types" target="classFrame">BinaryType</a></li>
+<li><a href="org/apache/spark/util/random/BinomialBounds.html" title="class in org.apache.spark.util.random" target="classFrame">BinomialBounds</a></li>
+<li><a href="org/apache/spark/ml/clustering/BisectingKMeans.html" title="class in org.apache.spark.ml.clustering" target="classFrame">BisectingKMeans</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeans.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">BisectingKMeans</a></li>
+<li><a href="org/apache/spark/ml/clustering/BisectingKMeansModel.html" title="class in org.apache.spark.ml.clustering" target="classFrame">BisectingKMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeansModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">BisectingKMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeansModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">BisectingKMeansModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeansModel.SaveLoadV2_0$.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">BisectingKMeansModel.SaveLoadV2_0$</a></li>
+<li><a href="org/apache/spark/ml/clustering/BisectingKMeansSummary.html" title="class in org.apache.spark.ml.clustering" target="classFrame">BisectingKMeansSummary</a></li>
+<li><a href="org/apache/spark/scheduler/BlacklistedExecutor.html" title="class in org.apache.spark.scheduler" target="classFrame">BlacklistedExecutor</a></li>
+<li><a href="org/apache/spark/ml/linalg/BLAS.html" title="class in org.apache.spark.ml.linalg" target="classFrame">BLAS</a></li>
+<li><a href="org/apache/spark/mllib/linalg/BLAS.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">BLAS</a></li>
+<li><a href="org/apache/spark/storage/BlockId.html" title="class in org.apache.spark.storage" target="classFrame">BlockId</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerId.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerId</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockLocationsAndStatus.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.BlockLocationsAndStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockLocationsAndStatus$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.BlockLocationsAndStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockManagerHeartbeat.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.BlockManagerHeartbeat</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockManagerHeartbeat$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.BlockManagerHeartbeat$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetBlockStatus.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetBlockStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetBlockStatus$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetBlockStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetExecutorEndpointRef.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetExecutorEndpointRef</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetExecutorEndpointRef$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetExecutorEndpointRef$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocations.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetLocations</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocations$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetLocations$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsAndStatus.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetLocationsAndStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsAndStatus$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetLocationsAndStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsMultipleBlockIds.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetLocationsMultipleBlockIds</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsMultipleBlockIds$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetLocationsMultipleBlockIds$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetMatchingBlockIds.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetMatchingBlockIds</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetMatchingBlockIds$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetMatchingBlockIds$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetMemoryStatus$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetMemoryStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetPeers.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetPeers</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetPeers$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetPeers$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetStorageStatus$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.GetStorageStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.HasCachedBlocks.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.HasCachedBlocks</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.HasCachedBlocks$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.HasCachedBlocks$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RegisterBlockManager.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RegisterBlockManager</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RegisterBlockManager$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RegisterBlockManager$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBlock.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveBlock</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBlock$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveBlock$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBroadcast.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveBroadcast</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBroadcast$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveBroadcast$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveExecutor.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveExecutor</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveExecutor$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveExecutor$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveRdd.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveRdd</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveRdd$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveRdd$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveShuffle.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveShuffle</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveShuffle$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.RemoveShuffle$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ReplicateBlock.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.ReplicateBlock</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ReplicateBlock$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.ReplicateBlock$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.StopBlockManagerMaster$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.StopBlockManagerMaster$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ToBlockManagerMaster.html" title="interface in org.apache.spark.storage" target="classFrame"><span class="interfaceName">BlockManagerMessages.ToBlockManagerMaster</span></a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ToBlockManagerSlave.html" title="interface in org.apache.spark.storage" target="classFrame"><span class="interfaceName">BlockManagerMessages.ToBlockManagerSlave</span></a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.TriggerThreadDump$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.TriggerThreadDump$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.UpdateBlockInfo.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.UpdateBlockInfo</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.UpdateBlockInfo$.html" title="class in org.apache.spark.storage" target="classFrame">BlockManagerMessages.UpdateBlockInfo$</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/BlockMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed" target="classFrame">BlockMatrix</a></li>
+<li><a href="org/apache/spark/storage/BlockNotFoundException.html" title="class in org.apache.spark.storage" target="classFrame">BlockNotFoundException</a></li>
+<li><a href="org/apache/spark/storage/BlockReplicationPolicy.html" title="interface in org.apache.spark.storage" target="classFrame"><span class="interfaceName">BlockReplicationPolicy</span></a></li>
+<li><a href="org/apache/spark/storage/BlockReplicationUtils.html" title="class in org.apache.spark.storage" target="classFrame">BlockReplicationUtils</a></li>
+<li><a href="org/apache/spark/storage/BlockStatus.html" title="class in org.apache.spark.storage" target="classFrame">BlockStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockUpdatedInfo.html" title="class in org.apache.spark.storage" target="classFrame">BlockUpdatedInfo</a></li>
+<li><a href="org/apache/spark/util/sketch/BloomFilter.html" title="class in org.apache.spark.util.sketch" target="classFrame">BloomFilter</a></li>
+<li><a href="org/apache/spark/util/sketch/BloomFilter.Version.html" title="enum in org.apache.spark.util.sketch" target="classFrame">BloomFilter.Version</a></li>
+<li><a href="org/apache/spark/ml/param/BooleanParam.html" title="class in org.apache.spark.ml.param" target="classFrame">BooleanParam</a></li>
+<li><a href="org/apache/spark/sql/types/BooleanType.html" title="class in org.apache.spark.sql.types" target="classFrame">BooleanType</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/BoostingStrategy.html" title="class in org.apache.spark.mllib.tree.configuration" target="classFrame">BoostingStrategy</a></li>
+<li><a href="org/apache/spark/partial/BoundedDouble.html" title="class in org.apache.spark.partial" target="classFrame">BoundedDouble</a></li>
+<li><a href="org/apache/spark/ml/ann/BreezeUtil.html" title="class in org.apache.spark.ml.ann" target="classFrame">BreezeUtil</a></li>
+<li><a href="org/apache/spark/broadcast/Broadcast.html" title="class in org.apache.spark.broadcast" target="classFrame">Broadcast</a></li>
+<li><a href="org/apache/spark/storage/BroadcastBlockId.html" title="class in org.apache.spark.storage" target="classFrame">BroadcastBlockId</a></li>
+<li><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSH.html" title="class in org.apache.spark.ml.feature" target="classFrame">BucketedRandomProjectionLSH</a></li>
+<li><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">BucketedRandomProjectionLSHModel</a></li>
+<li><a href="org/apache/spark/ml/feature/Bucketizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">Bucketizer</a></li>
+<li><a href="org/apache/spark/storage/BufferReleasingInputStream.html" title="class in org.apache.spark.storage" target="classFrame">BufferReleasingInputStream</a></li>
+<li><a href="org/apache/spark/graphx/util/BytecodeUtils.html" title="class in org.apache.spark.graphx.util" target="classFrame">BytecodeUtils</a></li>
+<li><a href="org/apache/spark/sql/types/ByteType.html" title="class in org.apache.spark.sql.types" target="classFrame">ByteType</a></li>
+<li><a href="org/apache/spark/sql/types/CalendarIntervalType.html" title="class in org.apache.spark.sql.types" target="classFrame">CalendarIntervalType</a></li>
+<li><a href="org/apache/spark/sql/catalog/Catalog.html" title="class in org.apache.spark.sql.catalog" target="classFrame">Catalog</a></li>
+<li><a href="org/apache/spark/sql/sources/CatalystScan.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">CatalystScan</span></a></li>
+<li><a href="org/apache/spark/ml/tree/CategoricalSplit.html" title="class in org.apache.spark.ml.tree" target="classFrame">CategoricalSplit</a></li>
+<li><a href="org/apache/spark/util/CausedBy.html" title="class in org.apache.spark.util" target="classFrame">CausedBy</a></li>
+<li><a href="org/apache/spark/sql/types/CharType.html" title="class in org.apache.spark.sql.types" target="classFrame">CharType</a></li>
+<li><a href="org/apache/spark/streaming/CheckpointReader.html" title="class in org.apache.spark.streaming" target="classFrame">CheckpointReader</a></li>
+<li><a href="org/apache/spark/rdd/CheckpointState.html" title="class in org.apache.spark.rdd" target="classFrame">CheckpointState</a></li>
+<li><a href="org/apache/spark/util/ChildFirstURLClassLoader.html" title="class in org.apache.spark.util" target="classFrame">ChildFirstURLClassLoader</a></li>
+<li><a href="org/apache/spark/ml/feature/ChiSqSelector.html" title="class in org.apache.spark.ml.feature" target="classFrame">ChiSqSelector</a></li>
+<li><a href="org/apache/spark/mllib/feature/ChiSqSelector.html" title="class in org.apache.spark.mllib.feature" target="classFrame">ChiSqSelector</a></li>
+<li><a href="org/apache/spark/ml/feature/ChiSqSelectorModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">ChiSqSelectorModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/ChiSqSelectorModel.html" title="class in org.apache.spark.mllib.feature" target="classFrame">ChiSqSelectorModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/ChiSqSelectorModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.feature" target="classFrame">ChiSqSelectorModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">ChiSqTest</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.Method.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">ChiSqTest.Method</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.Method$.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">ChiSqTest.Method$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.NullHypothesis$.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">ChiSqTest.NullHypothesis$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTestResult.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">ChiSqTestResult</a></li>
+<li><a href="org/apache/spark/ml/stat/ChiSquareTest.html" title="class in org.apache.spark.ml.stat" target="classFrame">ChiSquareTest</a></li>
+<li><a href="org/apache/spark/mllib/linalg/CholeskyDecomposition.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">CholeskyDecomposition</a></li>
+<li><a href="org/apache/spark/ml/classification/ClassificationModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">ClassificationModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/ClassificationModel.html" title="interface in org.apache.spark.mllib.classification" target="classFrame"><span class="interfaceName">ClassificationModel</span></a></li>
+<li><a href="org/apache/spark/ml/classification/Classifier.html" title="class in org.apache.spark.ml.classification" target="classFrame">Classifier</a></li>
+<li><a href="org/apache/spark/CleanAccum.html" title="class in org.apache.spark" target="classFrame">CleanAccum</a></li>
+<li><a href="org/apache/spark/CleanBroadcast.html" title="class in org.apache.spark" target="classFrame">CleanBroadcast</a></li>
+<li><a href="org/apache/spark/CleanCheckpoint.html" title="class in org.apache.spark" target="classFrame">CleanCheckpoint</a></li>
+<li><a href="org/apache/spark/CleanRDD.html" title="class in org.apache.spark" target="classFrame">CleanRDD</a></li>
+<li><a href="org/apache/spark/CleanShuffle.html" title="class in org.apache.spark" target="classFrame">CleanShuffle</a></li>
+<li><a href="org/apache/spark/CleanupTask.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">CleanupTask</span></a></li>
+<li><a href="org/apache/spark/CleanupTaskWeakReference.html" title="class in org.apache.spark" target="classFrame">CleanupTaskWeakReference</a></li>
+<li><a href="org/apache/spark/util/ClosureCleaner.html" title="class in org.apache.spark.util" target="classFrame">ClosureCleaner</a></li>
+<li><a href="org/apache/spark/ml/clustering/ClusterData.html" title="class in org.apache.spark.ml.clustering" target="classFrame">ClusterData</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/partitioning/ClusteredDistribution.html" title="class in org.apache.spark.sql.sources.v2.reader.partitioning" target="classFrame">ClusteredDistribution</a></li>
+<li><a href="org/apache/spark/ml/evaluation/ClusteringEvaluator.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">ClusteringEvaluator</a></li>
+<li><a href="org/apache/spark/ml/clustering/ClusteringSummary.html" title="class in org.apache.spark.ml.clustering" target="classFrame">ClusteringSummary</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.AddWebUIFilter</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.AddWebUIFilter$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.GetExecutorLossReason.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.GetExecutorLossReason</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.GetExecutorLossReason$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.GetExecutorLossReason$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutors.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.KillExecutors</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutors$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.KillExecutors$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutorsOnHost.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.KillExecutorsOnHost</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutorsOnHost$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.KillExecutorsOnHost$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillTask.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.KillTask</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillTask$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.KillTask$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.LaunchTask.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.LaunchTask</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.LaunchTask$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.LaunchTask$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterClusterManager.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisterClusterManager</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterClusterManager$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisterClusterManager$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisteredExecutor$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisteredExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutor.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisterExecutor</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutor$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisterExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutorFailed.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisterExecutorFailed</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutorFailed$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RegisterExecutorFailed$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutorResponse.html" title="interface in org.apache.spark.scheduler.cluster" target="classFrame"><span class="interfaceName">CoarseGrainedClusterMessages.RegisterExecutorResponse</span></a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveExecutor.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RemoveExecutor</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveExecutor$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RemoveExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveWorker.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RemoveWorker</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveWorker$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RemoveWorker$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RequestExecutors.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RequestExecutors</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RequestExecutors$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RequestExecutors$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RetrieveLastAllocatedExecutorId$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RetrieveLastAllocatedExecutorId$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RetrieveSparkAppConfig$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.RetrieveSparkAppConfig$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.ReviveOffers$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.ReviveOffers$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SetupDriver.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.SetupDriver</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SetupDriver$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.SetupDriver$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.Shutdown$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.Shutdown$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SparkAppConfig.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.SparkAppConfig</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SparkAppConfig$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.SparkAppConfig$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StatusUpdate.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.StatusUpdate</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StatusUpdate$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.StatusUpdate$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StopDriver$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.StopDriver$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StopExecutor$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.StopExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StopExecutors$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.StopExecutors$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.UpdateDelegationTokens.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.UpdateDelegationTokens</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.UpdateDelegationTokens$.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">CoarseGrainedClusterMessages.UpdateDelegationTokens$</a></li>
+<li><a href="org/apache/spark/metrics/source/CodegenMetrics.html" title="class in org.apache.spark.metrics.source" target="classFrame">CodegenMetrics</a></li>
+<li><a href="org/apache/spark/rdd/CoGroupedRDD.html" title="class in org.apache.spark.rdd" target="classFrame">CoGroupedRDD</a></li>
+<li><a href="org/apache/spark/api/java/function/CoGroupFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">CoGroupFunction</span></a></li>
+<li><a href="org/apache/spark/util/CollectionAccumulator.html" title="class in org.apache.spark.util" target="classFrame">CollectionAccumulator</a></li>
+<li><a href="org/apache/spark/util/CollectionsUtils.html" title="class in org.apache.spark.util" target="classFrame">CollectionsUtils</a></li>
+<li><a href="org/apache/spark/sql/catalog/Column.html" title="class in org.apache.spark.sql.catalog" target="classFrame">Column</a></li>
+<li><a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql" target="classFrame">Column</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarArray.html" title="class in org.apache.spark.sql.vectorized" target="classFrame">ColumnarArray</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarBatch.html" title="class in org.apache.spark.sql.vectorized" target="classFrame">ColumnarBatch</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarMap.html" title="class in org.apache.spark.sql.vectorized" target="classFrame">ColumnarMap</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarRow.html" title="class in org.apache.spark.sql.vectorized" target="classFrame">ColumnarRow</a></li>
+<li><a href="org/apache/spark/sql/ColumnName.html" title="class in org.apache.spark.sql" target="classFrame">ColumnName</a></li>
+<li><a href="org/apache/spark/ml/feature/ColumnPruner.html" title="class in org.apache.spark.ml.feature" target="classFrame">ColumnPruner</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnVector.html" title="class in org.apache.spark.sql.vectorized" target="classFrame">ColumnVector</a></li>
+<li><a href="org/apache/spark/ComplexFutureAction.html" title="class in org.apache.spark" target="classFrame">ComplexFutureAction</a></li>
+<li><a href="org/apache/spark/io/CompressionCodec.html" title="interface in org.apache.spark.io" target="classFrame"><span class="interfaceName">CompressionCodec</span></a></li>
+<li><a href="org/apache/spark/status/config.html" title="class in org.apache.spark.status" target="classFrame">config</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigEntryWithDefault.html" title="class in org.apache.spark.internal.config" target="classFrame">ConfigEntryWithDefault</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigEntryWithDefaultFunction.html" title="class in org.apache.spark.internal.config" target="classFrame">ConfigEntryWithDefaultFunction</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigEntryWithDefaultString.html" title="class in org.apache.spark.internal.config" target="classFrame">ConfigEntryWithDefaultString</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigHelpers.html" title="class in org.apache.spark.internal.config" target="classFrame">ConfigHelpers</a></li>
+<li><a href="org/apache/spark/graphx/lib/ConnectedComponents.html" title="class in org.apache.spark.graphx.lib" target="classFrame">ConnectedComponents</a></li>
+<li><a href="org/apache/spark/streaming/dstream/ConstantInputDStream.html" title="class in org.apache.spark.streaming.dstream" target="classFrame">ConstantInputDStream</a></li>
+<li><a href="org/apache/spark/ContextBarrierId.html" title="class in org.apache.spark" target="classFrame">ContextBarrierId</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/ContinuousInputPartition.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">ContinuousInputPartition</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/ContinuousInputPartitionReader.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming" target="classFrame"><span class="interfaceName">ContinuousInputPartitionReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/ContinuousReader.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming" target="classFrame"><span class="interfaceName">ContinuousReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/ContinuousReadSupport.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">ContinuousReadSupport</span></a></li>
+<li><a href="org/apache/spark/ml/tree/ContinuousSplit.html" title="class in org.apache.spark.ml.tree" target="classFrame">ContinuousSplit</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/CoordinateMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed" target="classFrame">CoordinateMatrix</a></li>
+<li><a href="org/apache/spark/ml/stat/Correlation.html" title="class in org.apache.spark.ml.stat" target="classFrame">Correlation</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/CorrelationNames.html" title="class in org.apache.spark.mllib.stat.correlation" target="classFrame">CorrelationNames</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/Correlations.html" title="class in org.apache.spark.mllib.stat.correlation" target="classFrame">Correlations</a></li>
+<li><a href="org/apache/spark/ml/evaluation/CosineSilhouette.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">CosineSilhouette</a></li>
+<li><a href="org/apache/spark/storage/CountingWritableChannel.html" title="class in org.apache.spark.storage" target="classFrame">CountingWritableChannel</a></li>
+<li><a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch" target="classFrame">CountMinSketch</a></li>
+<li><a href="org/apache/spark/util/sketch/CountMinSketch.Version.html" title="enum in org.apache.spark.util.sketch" target="classFrame">CountMinSketch.Version</a></li>
+<li><a href="org/apache/spark/ml/feature/CountVectorizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">CountVectorizer</a></li>
+<li><a href="org/apache/spark/ml/feature/CountVectorizerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">CountVectorizerModel</a></li>
+<li><a href="org/apache/spark/sql/sources/CreatableRelationProvider.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">CreatableRelationProvider</span></a></li>
+<li><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">CreateHiveTableAsSelectCommand</a></li>
+<li><a href="org/apache/spark/ml/tuning/CrossValidator.html" title="class in org.apache.spark.ml.tuning" target="classFrame">CrossValidator</a></li>
+<li><a href="org/apache/spark/ml/tuning/CrossValidatorModel.html" title="class in org.apache.spark.ml.tuning" target="classFrame">CrossValidatorModel</a></li>
+<li><a href="org/apache/spark/ml/tuning/CrossValidatorModel.CrossValidatorModelWriter.html" title="class in org.apache.spark.ml.tuning" target="classFrame">CrossValidatorModel.CrossValidatorModelWriter</a></li>
+<li><a href="org/apache/spark/security/CryptoStreamUtils.html" title="class in org.apache.spark.security" target="classFrame">CryptoStreamUtils</a></li>
+<li><a href="org/apache/spark/security/CryptoStreamUtils.BaseErrorHandler.html" title="interface in org.apache.spark.security" target="classFrame"><span class="interfaceName">CryptoStreamUtils.BaseErrorHandler</span></a></li>
+<li><a href="org/apache/spark/security/CryptoStreamUtils.ErrorHandlingReadableChannel.html" title="class in org.apache.spark.security" target="classFrame">CryptoStreamUtils.ErrorHandlingReadableChannel</a></li>
+<li><a href="org/apache/spark/sql/catalog/Database.html" title="class in org.apache.spark.sql.catalog" target="classFrame">Database</a></li>
+<li><a href="org/apache/spark/sql/DataFrameNaFunctions.html" title="class in org.apache.spark.sql" target="classFrame">DataFrameNaFunctions</a></li>
+<li><a href="org/apache/spark/sql/DataFrameReader.html" title="class in org.apache.spark.sql" target="classFrame">DataFrameReader</a></li>
+<li><a href="org/apache/spark/sql/DataFrameStatFunctions.html" title="class in org.apache.spark.sql" target="classFrame">DataFrameStatFunctions</a></li>
+<li><a href="org/apache/spark/sql/DataFrameWriter.html" title="class in org.apache.spark.sql" target="classFrame">DataFrameWriter</a></li>
+<li><a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql" target="classFrame">Dataset</a></li>
+<li><a href="org/apache/spark/sql/DatasetHolder.html" title="class in org.apache.spark.sql" target="classFrame">DatasetHolder</a></li>
+<li><a href="org/apache/spark/ml/util/DatasetUtils.html" title="class in org.apache.spark.ml.util" target="classFrame">DatasetUtils</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html" title="class in org.apache.spark.sql.sources.v2" target="classFrame">DataSourceOptions</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/DataSourceReader.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">DataSourceReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/DataSourceRegister.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">DataSourceRegister</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/DataSourceV2.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">DataSourceV2</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/DataSourceWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer" target="classFrame"><span class="interfaceName">DataSourceWriter</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/DataStreamReader.html" title="class in org.apache.spark.sql.streaming" target="classFrame">DataStreamReader</a></li>
+<li><a href="org/apache/spark/sql/streaming/DataStreamWriter.html" title="class in org.apache.spark.sql.streaming" target="classFrame">DataStreamWriter</a></li>
+<li><a href="org/apache/spark/sql/types/DataType.html" title="class in org.apache.spark.sql.types" target="classFrame">DataType</a></li>
+<li><a href="org/apache/spark/sql/types/DataTypes.html" title="class in org.apache.spark.sql.types" target="classFrame">DataTypes</a></li>
+<li><a href="org/apache/spark/mllib/util/DataValidators.html" title="class in org.apache.spark.mllib.util" target="classFrame">DataValidators</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/DataWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer" target="classFrame"><span class="interfaceName">DataWriter</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/DataWriterFactory.html" title="interface in org.apache.spark.sql.sources.v2.writer" target="classFrame"><span class="interfaceName">DataWriterFactory</span></a></li>
+<li><a href="org/apache/spark/sql/types/DateType.html" title="class in org.apache.spark.sql.types" target="classFrame">DateType</a></li>
+<li><a href="org/apache/spark/sql/jdbc/DB2Dialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">DB2Dialect</a></li>
+<li><a href="org/apache/spark/ml/feature/DCT.html" title="class in org.apache.spark.ml.feature" target="classFrame">DCT</a></li>
+<li><a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types" target="classFrame">Decimal</a></li>
+<li><a href="org/apache/spark/sql/types/Decimal.DecimalAsIfIntegral$.html" title="class in org.apache.spark.sql.types" target="classFrame">Decimal.DecimalAsIfIntegral$</a></li>
+<li><a href="org/apache/spark/sql/types/Decimal.DecimalIsFractional$.html" title="class in org.apache.spark.sql.types" target="classFrame">Decimal.DecimalIsFractional$</a></li>
+<li><a href="org/apache/spark/sql/types/DecimalType.html" title="class in org.apache.spark.sql.types" target="classFrame">DecimalType</a></li>
+<li><a href="org/apache/spark/sql/types/DecimalType.Expression$.html" title="class in org.apache.spark.sql.types" target="classFrame">DecimalType.Expression$</a></li>
+<li><a href="org/apache/spark/sql/types/DecimalType.Fixed$.html" title="class in org.apache.spark.sql.types" target="classFrame">DecimalType.Fixed$</a></li>
+<li><a href="org/apache/spark/mllib/tree/DecisionTree.html" title="class in org.apache.spark.mllib.tree" target="classFrame">DecisionTree</a></li>
+<li><a href="org/apache/spark/ml/classification/DecisionTreeClassificationModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">DecisionTreeClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/DecisionTreeClassifier.html" title="class in org.apache.spark.ml.classification" target="classFrame">DecisionTreeClassifier</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">DecisionTreeModel</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">DecisionTreeModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.html" title="class in org.apache.spark.ml.tree" target="classFrame">DecisionTreeModelReadWrite</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.NodeData.html" title="class in org.apache.spark.ml.tree" target="classFrame">DecisionTreeModelReadWrite.NodeData</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.NodeData$.html" title="class in org.apache.spark.ml.tree" target="classFrame">DecisionTreeModelReadWrite.NodeData$</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.SplitData.html" title="class in org.apache.spark.ml.tree" target="classFrame">DecisionTreeModelReadWrite.SplitData</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.SplitData$.html" title="class in org.apache.spark.ml.tree" target="classFrame">DecisionTreeModelReadWrite.SplitData$</a></li>
+<li><a href="org/apache/spark/ml/regression/DecisionTreeRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">DecisionTreeRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/DecisionTreeRegressor.html" title="class in org.apache.spark.ml.regression" target="classFrame">DecisionTreeRegressor</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/DefaultCredentials.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">DefaultCredentials</a></li>
+<li><a href="org/apache/spark/ml/util/DefaultParamsReadable.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">DefaultParamsReadable</span></a></li>
+<li><a href="org/apache/spark/ml/util/DefaultParamsWritable.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">DefaultParamsWritable</span></a></li>
+<li><a href="org/apache/spark/rdd/DefaultPartitionCoalescer.html" title="class in org.apache.spark.rdd" target="classFrame">DefaultPartitionCoalescer</a></li>
+<li><a href="org/apache/spark/storage/DefaultTopologyMapper.html" title="class in org.apache.spark.storage" target="classFrame">DefaultTopologyMapper</a></li>
+<li><a href="org/apache/spark/ml/linalg/DenseMatrix.html" title="class in org.apache.spark.ml.linalg" target="classFrame">DenseMatrix</a></li>
+<li><a href="org/apache/spark/mllib/linalg/DenseMatrix.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">DenseMatrix</a></li>
+<li><a href="org/apache/spark/ml/linalg/DenseVector.html" title="class in org.apache.spark.ml.linalg" target="classFrame">DenseVector</a></li>
+<li><a href="org/apache/spark/mllib/linalg/DenseVector.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">DenseVector</a></li>
+<li><a href="org/apache/spark/Dependency.html" title="class in org.apache.spark" target="classFrame">Dependency</a></li>
+<li><a href="org/apache/spark/sql/jdbc/DerbyDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">DerbyDialect</a></li>
+<li><a href="org/apache/spark/serializer/DeserializationStream.html" title="class in org.apache.spark.serializer" target="classFrame">DeserializationStream</a></li>
+<li><a href="org/apache/spark/storage/memory/DeserializedMemoryEntry.html" title="class in org.apache.spark.storage.memory" target="classFrame">DeserializedMemoryEntry</a></li>
+<li><a href="org/apache/spark/storage/memory/DeserializedValuesHolder.html" title="class in org.apache.spark.storage.memory" target="classFrame">DeserializedValuesHolder</a></li>
+<li><a href="org/apache/spark/sql/hive/DetermineTableStats.html" title="class in org.apache.spark.sql.hive" target="classFrame">DetermineTableStats</a></li>
+<li><a href="org/apache/spark/rdd/DeterministicLevel.html" title="class in org.apache.spark.rdd" target="classFrame">DeterministicLevel</a></li>
+<li><a href="org/apache/spark/storage/DiskBlockData.html" title="class in org.apache.spark.storage" target="classFrame">DiskBlockData</a></li>
+<li><a href="org/apache/spark/ml/clustering/DistributedLDAModel.html" title="class in org.apache.spark.ml.clustering" target="classFrame">DistributedLDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/DistributedLDAModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">DistributedLDAModel</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/DistributedMatrix.html" title="interface in org.apache.spark.mllib.linalg.distributed" target="classFrame"><span class="interfaceName">DistributedMatrix</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/partitioning/Distribution.html" title="interface in org.apache.spark.sql.sources.v2.reader.partitioning" target="classFrame"><span class="interfaceName">Distribution</span></a></li>
+<li><a href="org/apache/spark/ml/feature/Dot.html" title="class in org.apache.spark.ml.feature" target="classFrame">Dot</a></li>
+<li><a href="org/apache/spark/util/DoubleAccumulator.html" title="class in org.apache.spark.util" target="classFrame">DoubleAccumulator</a></li>
+<li><a href="org/apache/spark/ml/param/DoubleArrayArrayParam.html" title="class in org.apache.spark.ml.param" target="classFrame">DoubleArrayArrayParam</a></li>
+<li><a href="org/apache/spark/ml/param/DoubleArrayParam.html" title="class in org.apache.spark.ml.param" target="classFrame">DoubleArrayParam</a></li>
+<li><a href="org/apache/spark/api/java/function/DoubleFlatMapFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">DoubleFlatMapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/DoubleFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">DoubleFunction</span></a></li>
+<li><a href="org/apache/spark/ml/param/DoubleParam.html" title="class in org.apache.spark.ml.param" target="classFrame">DoubleParam</a></li>
+<li><a href="org/apache/spark/rdd/DoubleRDDFunctions.html" title="class in org.apache.spark.rdd" target="classFrame">DoubleRDDFunctions</a></li>
+<li><a href="org/apache/spark/sql/types/DoubleType.html" title="class in org.apache.spark.sql.types" target="classFrame">DoubleType</a></li>
+<li><a href="org/apache/spark/streaming/dstream/DStream.html" title="class in org.apache.spark.streaming.dstream" target="classFrame">DStream</a></li>
+<li><a href="org/apache/spark/serializer/DummySerializerInstance.html" title="class in org.apache.spark.serializer" target="classFrame">DummySerializerInstance</a></li>
+<li><a href="org/apache/spark/streaming/Duration.html" title="class in org.apache.spark.streaming" target="classFrame">Duration</a></li>
+<li><a href="org/apache/spark/streaming/Durations.html" title="class in org.apache.spark.streaming" target="classFrame">Durations</a></li>
+<li><a href="org/apache/spark/graphx/Edge.html" title="class in org.apache.spark.graphx" target="classFrame">Edge</a></li>
+<li><a href="org/apache/spark/graphx/impl/EdgeActiveness.html" title="enum in org.apache.spark.graphx.impl" target="classFrame">EdgeActiveness</a></li>
+<li><a href="org/apache/spark/graphx/EdgeContext.html" title="class in org.apache.spark.graphx" target="classFrame">EdgeContext</a></li>
+<li><a href="org/apache/spark/graphx/EdgeDirection.html" title="class in org.apache.spark.graphx" target="classFrame">EdgeDirection</a></li>
+<li><a href="org/apache/spark/graphx/EdgeRDD.html" title="class in org.apache.spark.graphx" target="classFrame">EdgeRDD</a></li>
+<li><a href="org/apache/spark/graphx/impl/EdgeRDDImpl.html" title="class in org.apache.spark.graphx.impl" target="classFrame">EdgeRDDImpl</a></li>
+<li><a href="org/apache/spark/graphx/EdgeTriplet.html" title="class in org.apache.spark.graphx" target="classFrame">EdgeTriplet</a></li>
+<li><a href="org/apache/spark/mllib/linalg/EigenValueDecomposition.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">EigenValueDecomposition</a></li>
+<li><a href="org/apache/spark/ml/feature/ElementwiseProduct.html" title="class in org.apache.spark.ml.feature" target="classFrame">ElementwiseProduct</a></li>
+<li><a href="org/apache/spark/mllib/feature/ElementwiseProduct.html" title="class in org.apache.spark.mllib.feature" target="classFrame">ElementwiseProduct</a></li>
+<li><a href="org/apache/spark/mllib/clustering/EMLDAOptimizer.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">EMLDAOptimizer</a></li>
+<li><a href="org/apache/spark/sql/Encoder.html" title="interface in org.apache.spark.sql" target="classFrame"><span class="interfaceName">Encoder</span></a></li>
+<li><a href="org/apache/spark/sql/Encoders.html" title="class in org.apache.spark.sql" target="classFrame">Encoders</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/EnsembleCombiningStrategy.html" title="class in org.apache.spark.mllib.tree.configuration" target="classFrame">EnsembleCombiningStrategy</a></li>
+<li><a href="org/apache/spark/ml/tree/EnsembleModelReadWrite.html" title="class in org.apache.spark.ml.tree" target="classFrame">EnsembleModelReadWrite</a></li>
+<li><a href="org/apache/spark/ml/tree/EnsembleModelReadWrite.EnsembleNodeData.html" title="class in org.apache.spark.ml.tree" target="classFrame">EnsembleModelReadWrite.EnsembleNodeData</a></li>
+<li><a href="org/apache/spark/ml/tree/EnsembleModelReadWrite.EnsembleNodeData$.html" title="class in org.apache.spark.ml.tree" target="classFrame">EnsembleModelReadWrite.EnsembleNodeData$</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Entropy.html" title="class in org.apache.spark.mllib.tree.impurity" target="classFrame">Entropy</a></li>
+<li><a href="org/apache/spark/util/EnumUtil.html" title="class in org.apache.spark.util" target="classFrame">EnumUtil</a></li>
+<li><a href="org/apache/spark/sql/sources/EqualNullSafe.html" title="class in org.apache.spark.sql.sources" target="classFrame">EqualNullSafe</a></li>
+<li><a href="org/apache/spark/sql/sources/EqualTo.html" title="class in org.apache.spark.sql.sources" target="classFrame">EqualTo</a></li>
+<li><a href="org/apache/spark/ml/Estimator.html" title="class in org.apache.spark.ml" target="classFrame">Estimator</a></li>
+<li><a href="org/apache/spark/ml/evaluation/Evaluator.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">Evaluator</a></li>
+<li><a href="org/apache/spark/ExceptionFailure.html" title="class in org.apache.spark" target="classFrame">ExceptionFailure</a></li>
+<li><a href="org/apache/spark/sql/util/ExecutionListenerManager.html" title="class in org.apache.spark.sql.util" target="classFrame">ExecutionListenerManager</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/ExecutorInfo.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">ExecutorInfo</a></li>
+<li><a href="org/apache/spark/scheduler/ExecutorKilled.html" title="class in org.apache.spark.scheduler" target="classFrame">ExecutorKilled</a></li>
+<li><a href="org/apache/spark/ExecutorLostFailure.html" title="class in org.apache.spark" target="classFrame">ExecutorLostFailure</a></li>
+<li><a href="org/apache/spark/ExecutorPlugin.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">ExecutorPlugin</span></a></li>
+<li><a href="org/apache/spark/ExecutorRegistered.html" title="class in org.apache.spark" target="classFrame">ExecutorRegistered</a></li>
+<li><a href="org/apache/spark/ExecutorRemoved.html" title="class in org.apache.spark" target="classFrame">ExecutorRemoved</a></li>
+<li><a href="org/apache/spark/status/api/v1/ExecutorStageSummary.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ExecutorStageSummary</a></li>
+<li><a href="org/apache/spark/ui/storage/ExecutorStreamSummary.html" title="class in org.apache.spark.ui.storage" target="classFrame">ExecutorStreamSummary</a></li>
+<li><a href="org/apache/spark/status/api/v1/ExecutorSummary.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ExecutorSummary</a></li>
+<li><a href="org/apache/spark/ml/clustering/ExpectationAggregator.html" title="class in org.apache.spark.ml.clustering" target="classFrame">ExpectationAggregator</a></li>
+<li><a href="org/apache/spark/mllib/clustering/ExpectationSum.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">ExpectationSum</a></li>
+<li><a href="org/apache/spark/sql/ExperimentalMethods.html" title="class in org.apache.spark.sql" target="classFrame">ExperimentalMethods</a></li>
+<li><a href="org/apache/spark/ExpireDeadHosts.html" title="class in org.apache.spark" target="classFrame">ExpireDeadHosts</a></li>
+<li><a href="org/apache/spark/mllib/random/ExponentialGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">ExponentialGenerator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/binary/FalsePositiveRate.html" title="class in org.apache.spark.mllib.evaluation.binary" target="classFrame">FalsePositiveRate</a></li>
+<li><a href="org/apache/spark/ml/feature/FeatureHasher.html" title="class in org.apache.spark.ml.feature" target="classFrame">FeatureHasher</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/FeatureType.html" title="class in org.apache.spark.mllib.tree.configuration" target="classFrame">FeatureType</a></li>
+<li><a href="org/apache/spark/FetchFailed.html" title="class in org.apache.spark" target="classFrame">FetchFailed</a></li>
+<li><a href="org/apache/spark/storage/FileBasedTopologyMapper.html" title="class in org.apache.spark.storage" target="classFrame">FileBasedTopologyMapper</a></li>
+<li><a href="org/apache/spark/internal/io/FileCommitProtocol.html" title="class in org.apache.spark.internal.io" target="classFrame">FileCommitProtocol</a></li>
+<li><a href="org/apache/spark/internal/io/FileCommitProtocol.EmptyTaskCommitMessage$.html" title="class in org.apache.spark.internal.io" target="classFrame">FileCommitProtocol.EmptyTaskCommitMessage$</a></li>
+<li><a href="org/apache/spark/internal/io/FileCommitProtocol.TaskCommitMessage.html" title="class in org.apache.spark.internal.io" target="classFrame">FileCommitProtocol.TaskCommitMessage</a></li>
+<li><a href="org/apache/spark/sql/sources/Filter.html" title="class in org.apache.spark.sql.sources" target="classFrame">Filter</a></li>
+<li><a href="org/apache/spark/api/java/function/FilterFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">FilterFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">FlatMapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapFunction2.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">FlatMapFunction2</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapGroupsFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">FlatMapGroupsFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapGroupsWithStateFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">FlatMapGroupsWithStateFunction</span></a></li>
+<li><a href="org/apache/spark/ml/param/FloatParam.html" title="class in org.apache.spark.ml.param" target="classFrame">FloatParam</a></li>
+<li><a href="org/apache/spark/sql/types/FloatType.html" title="class in org.apache.spark.sql.types" target="classFrame">FloatType</a></li>
+<li><a href="org/apache/spark/api/java/function/ForeachFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">ForeachFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/ForeachPartitionFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">ForeachPartitionFunction</span></a></li>
+<li><a href="org/apache/spark/sql/ForeachWriter.html" title="class in org.apache.spark.sql" target="classFrame">ForeachWriter</a></li>
+<li><a href="org/apache/spark/ml/fpm/FPGrowth.html" title="class in org.apache.spark.ml.fpm" target="classFrame">FPGrowth</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowth.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">FPGrowth</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowth.FreqItemset.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">FPGrowth.FreqItemset</a></li>
+<li><a href="org/apache/spark/ml/fpm/FPGrowthModel.html" title="class in org.apache.spark.ml.fpm" target="classFrame">FPGrowthModel</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowthModel.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">FPGrowthModel</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowthModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">FPGrowthModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/api/java/function/Function.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">Function</span></a></li>
+<li><a href="org/apache/spark/sql/catalog/Function.html" title="class in org.apache.spark.sql.catalog" target="classFrame">Function</a></li>
+<li><a href="org/apache/spark/api/java/function/Function0.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">Function0</span></a></li>
+<li><a href="org/apache/spark/api/java/function/Function2.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">Function2</span></a></li>
+<li><a href="org/apache/spark/api/java/function/Function3.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">Function3</span></a></li>
+<li><a href="org/apache/spark/api/java/function/Function4.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">Function4</span></a></li>
+<li><a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql" target="classFrame">functions</a></li>
+<li><a href="org/apache/spark/FutureAction.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">FutureAction</span></a></li>
+<li><a href="org/apache/spark/mllib/random/GammaGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">GammaGenerator</a></li>
+<li><a href="org/apache/spark/ml/clustering/GaussianMixture.html" title="class in org.apache.spark.ml.clustering" target="classFrame">GaussianMixture</a></li>
+<li><a href="org/apache/spark/mllib/clustering/GaussianMixture.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">GaussianMixture</a></li>
+<li><a href="org/apache/spark/ml/clustering/GaussianMixtureModel.html" title="class in org.apache.spark.ml.clustering" target="classFrame">GaussianMixtureModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/GaussianMixtureModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">GaussianMixtureModel</a></li>
+<li><a href="org/apache/spark/ml/clustering/GaussianMixtureSummary.html" title="class in org.apache.spark.ml.clustering" target="classFrame">GaussianMixtureSummary</a></li>
+<li><a href="org/apache/spark/ml/classification/GBTClassificationModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">GBTClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/GBTClassifier.html" title="class in org.apache.spark.ml.classification" target="classFrame">GBTClassifier</a></li>
+<li><a href="org/apache/spark/ml/regression/GBTRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">GBTRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/GBTRegressor.html" title="class in org.apache.spark.ml.regression" target="classFrame">GBTRegressor</a></li>
+<li><a href="org/apache/spark/mllib/regression/GeneralizedLinearAlgorithm.html" title="class in org.apache.spark.mllib.regression" target="classFrame">GeneralizedLinearAlgorithm</a></li>
+<li><a href="org/apache/spark/mllib/regression/GeneralizedLinearModel.html" title="class in org.apache.spark.mllib.regression" target="classFrame">GeneralizedLinearModel</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Binomial$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Binomial$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.CLogLog$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.CLogLog$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Family$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Family$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.FamilyAndLink$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.FamilyAndLink$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gamma$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Gamma$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gaussian$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Gaussian$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Identity$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Identity$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Inverse$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Inverse$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Link$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Link$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Log$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Log$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Logit$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Logit$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Poisson$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Poisson$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Probit$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Probit$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Sqrt$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Sqrt$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Tweedie$.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegression.Tweedie$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionSummary.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegressionSummary</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionTrainingSummary.html" title="class in org.apache.spark.ml.regression" target="classFrame">GeneralizedLinearRegressionTrainingSummary</a></li>
+<li><a href="org/apache/spark/ml/util/GeneralMLWritable.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">GeneralMLWritable</span></a></li>
+<li><a href="org/apache/spark/ml/util/GeneralMLWriter.html" title="class in org.apache.spark.ml.util" target="classFrame">GeneralMLWriter</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/GetAllReceiverInfo.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">GetAllReceiverInfo</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Gini.html" title="class in org.apache.spark.mllib.tree.impurity" target="classFrame">Gini</a></li>
+<li><a href="org/apache/spark/mllib/classification/impl/GLMClassificationModel.html" title="class in org.apache.spark.mllib.classification.impl" target="classFrame">GLMClassificationModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/impl/GLMClassificationModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.classification.impl" target="classFrame">GLMClassificationModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/regression/impl/GLMRegressionModel.html" title="class in org.apache.spark.mllib.regression.impl" target="classFrame">GLMRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/impl/GLMRegressionModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.regression.impl" target="classFrame">GLMRegressionModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/optimization/Gradient.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">Gradient</a></li>
+<li><a href="org/apache/spark/ml/tree/impl/GradientBoostedTrees.html" title="class in org.apache.spark.ml.tree.impl" target="classFrame">GradientBoostedTrees</a></li>
+<li><a href="org/apache/spark/mllib/tree/GradientBoostedTrees.html" title="class in org.apache.spark.mllib.tree" target="classFrame">GradientBoostedTrees</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/GradientBoostedTreesModel.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">GradientBoostedTreesModel</a></li>
+<li><a href="org/apache/spark/mllib/optimization/GradientDescent.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">GradientDescent</a></li>
+<li><a href="org/apache/spark/graphx/Graph.html" title="class in org.apache.spark.graphx" target="classFrame">Graph</a></li>
+<li><a href="org/apache/spark/graphx/util/GraphGenerators.html" title="class in org.apache.spark.graphx.util" target="classFrame">GraphGenerators</a></li>
+<li><a href="org/apache/spark/graphx/impl/GraphImpl.html" title="class in org.apache.spark.graphx.impl" target="classFrame">GraphImpl</a></li>
+<li><a href="org/apache/spark/graphx/GraphLoader.html" title="class in org.apache.spark.graphx" target="classFrame">GraphLoader</a></li>
+<li><a href="org/apache/spark/graphx/GraphOps.html" title="class in org.apache.spark.graphx" target="classFrame">GraphOps</a></li>
+<li><a href="org/apache/spark/graphx/GraphXUtils.html" title="class in org.apache.spark.graphx" target="classFrame">GraphXUtils</a></li>
+<li><a href="org/apache/spark/sql/sources/GreaterThan.html" title="class in org.apache.spark.sql.sources" target="classFrame">GreaterThan</a></li>
+<li><a href="org/apache/spark/sql/sources/GreaterThanOrEqual.html" title="class in org.apache.spark.sql.sources" target="classFrame">GreaterThanOrEqual</a></li>
+<li><a href="org/apache/spark/security/GroupMappingServiceProvider.html" title="interface in org.apache.spark.security" target="classFrame"><span class="interfaceName">GroupMappingServiceProvider</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/GroupState.html" title="interface in org.apache.spark.sql.streaming" target="classFrame"><span class="interfaceName">GroupState</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/GroupStateTimeout.html" title="class in org.apache.spark.sql.streaming" target="classFrame">GroupStateTimeout</a></li>
+<li><a href="org/apache/spark/internal/io/HadoopMapRedCommitProtocol.html" title="class in org.apache.spark.internal.io" target="classFrame">HadoopMapRedCommitProtocol</a></li>
+<li><a href="org/apache/spark/internal/io/HadoopMapReduceCommitProtocol.html" title="class in org.apache.spark.internal.io" target="classFrame">HadoopMapReduceCommitProtocol</a></li>
+<li><a href="org/apache/spark/rdd/HadoopRDD.html" title="class in org.apache.spark.rdd" target="classFrame">HadoopRDD</a></li>
+<li><a href="org/apache/spark/rdd/HadoopRDD.HadoopMapPartitionsWithSplitRDD$.html" title="class in org.apache.spark.rdd" target="classFrame">HadoopRDD.HadoopMapPartitionsWithSplitRDD$</a></li>
+<li><a href="org/apache/spark/internal/io/HadoopWriteConfigUtil.html" title="class in org.apache.spark.internal.io" target="classFrame">HadoopWriteConfigUtil</a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasAggregationDepth.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasAggregationDepth</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasCheckpointInterval.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasCheckpointInterval</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasCollectSubModels.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasCollectSubModels</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasDistanceMeasure.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasDistanceMeasure</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasElasticNetParam.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasElasticNetParam</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasFeaturesCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasFeaturesCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasFitIntercept.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasFitIntercept</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasHandleInvalid.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasHandleInvalid</span></a></li>
+<li><a href="org/apache/spark/ml/feature/HashingTF.html" title="class in org.apache.spark.ml.feature" target="classFrame">HashingTF</a></li>
+<li><a href="org/apache/spark/mllib/feature/HashingTF.html" title="class in org.apache.spark.mllib.feature" target="classFrame">HashingTF</a></li>
+<li><a href="org/apache/spark/HashPartitioner.html" title="class in org.apache.spark" target="classFrame">HashPartitioner</a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasInputCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasInputCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasInputCols.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasInputCols</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasLabelCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasLabelCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasLoss.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasLoss</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasMaxIter.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasMaxIter</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasOutputCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasOutputCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasOutputCols.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasOutputCols</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasPredictionCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasPredictionCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasProbabilityCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasProbabilityCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasRawPredictionCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasRawPredictionCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasRegParam.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasRegParam</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasSeed.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasSeed</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasSolver.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasSolver</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasStandardization.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasStandardization</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasStepSize.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasStepSize</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasThreshold.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasThreshold</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasThresholds.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasThresholds</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasTol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasTol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasValidationIndicatorCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasValidationIndicatorCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasVarianceCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasVarianceCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasWeightCol.html" title="interface in org.apache.spark.ml.param.shared" target="classFrame"><span class="interfaceName">HasWeightCol</span></a></li>
+<li><a href="org/apache/spark/streaming/util/HdfsUtils.html" title="class in org.apache.spark.streaming.util" target="classFrame">HdfsUtils</a></li>
+<li><a href="org/apache/spark/mllib/optimization/HingeGradient.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">HingeGradient</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveAnalysis.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveAnalysis</a></li>
+<li><a href="org/apache/spark/metrics/source/HiveCatalogMetrics.html" title="class in org.apache.spark.metrics.source" target="classFrame">HiveCatalogMetrics</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveContext.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveContext</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveFileFormat.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">HiveFileFormat</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveOptions.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">HiveOptions</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveOutputWriter.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">HiveOutputWriter</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveScriptIOSchema.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">HiveScriptIOSchema</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveSessionResourceLoader.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveSessionResourceLoader</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveSessionStateBuilder.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveSessionStateBuilder</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveShim.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveShim</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveShim.HiveFunctionWrapper$.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveShim.HiveFunctionWrapper$</a></li>
+<li><a href="org/apache/spark/sql/types/HiveStringType.html" title="class in org.apache.spark.sql.types" target="classFrame">HiveStringType</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveTableUtil.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveTableUtil</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveUDAFBuffer.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveUDAFBuffer</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveUtils.html" title="class in org.apache.spark.sql.hive" target="classFrame">HiveUtils</a></li>
+<li><a href="org/apache/spark/ml/util/Identifiable.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">Identifiable</span></a></li>
+<li><a href="org/apache/spark/ml/feature/IDF.html" title="class in org.apache.spark.ml.feature" target="classFrame">IDF</a></li>
+<li><a href="org/apache/spark/mllib/feature/IDF.html" title="class in org.apache.spark.mllib.feature" target="classFrame">IDF</a></li>
+<li><a href="org/apache/spark/mllib/feature/IDF.DocumentFrequencyAggregator.html" title="class in org.apache.spark.mllib.feature" target="classFrame">IDF.DocumentFrequencyAggregator</a></li>
+<li><a href="org/apache/spark/ml/feature/IDFModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">IDFModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/IDFModel.html" title="class in org.apache.spark.mllib.feature" target="classFrame">IDFModel</a></li>
+<li><a href="org/apache/spark/ml/source/image/ImageDataSource.html" title="class in org.apache.spark.ml.source.image" target="classFrame">ImageDataSource</a></li>
+<li><a href="org/apache/spark/ml/image/ImageSchema.html" title="class in org.apache.spark.ml.image" target="classFrame">ImageSchema</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Impurities.html" title="class in org.apache.spark.mllib.tree.impurity" target="classFrame">Impurities</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Impurity.html" title="interface in org.apache.spark.mllib.tree.impurity" target="classFrame"><span class="interfaceName">Impurity</span></a></li>
+<li><a href="org/apache/spark/ml/feature/Imputer.html" title="class in org.apache.spark.ml.feature" target="classFrame">Imputer</a></li>
+<li><a href="org/apache/spark/ml/feature/ImputerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">ImputerModel</a></li>
+<li><a href="org/apache/spark/sql/sources/In.html" title="class in org.apache.spark.sql.sources" target="classFrame">In</a></li>
+<li><a href="org/apache/spark/util/sketch/IncompatibleMergeException.html" title="class in org.apache.spark.util.sketch" target="classFrame">IncompatibleMergeException</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/IndexedRow.html" title="class in org.apache.spark.mllib.linalg.distributed" target="classFrame">IndexedRow</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/IndexedRowMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed" target="classFrame">IndexedRowMatrix</a></li>
+<li><a href="org/apache/spark/ml/feature/IndexToString.html" title="class in org.apache.spark.ml.feature" target="classFrame">IndexToString</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/InformationGainStats.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">InformationGainStats</a></li>
+<li><a href="org/apache/spark/util/InnerClosureFinder.html" title="class in org.apache.spark.util" target="classFrame">InnerClosureFinder</a></li>
+<li><a href="org/apache/spark/launcher/InProcessLauncher.html" title="class in org.apache.spark.launcher" target="classFrame">InProcessLauncher</a></li>
+<li><a href="org/apache/spark/streaming/dstream/InputDStream.html" title="class in org.apache.spark.streaming.dstream" target="classFrame">InputDStream</a></li>
+<li><a href="org/apache/spark/rdd/InputFileBlockHolder.html" title="class in org.apache.spark.rdd" target="classFrame">InputFileBlockHolder</a></li>
+<li><a href="org/apache/spark/scheduler/InputFormatInfo.html" title="class in org.apache.spark.scheduler" target="classFrame">InputFormatInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/InputMetricDistributions.html" title="class in org.apache.spark.status.api.v1" target="classFrame">InputMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/InputMetrics.html" title="class in org.apache.spark.status.api.v1" target="classFrame">InputMetrics</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/InputPartition.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">InputPartition</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/InputPartitionReader.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">InputPartitionReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/InsertableRelation.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">InsertableRelation</span></a></li>
+<li><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">InsertIntoHiveDirCommand</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">InsertIntoHiveTable</a></li>
+<li><a href="org/apache/spark/ml/param/IntArrayParam.html" title="class in org.apache.spark.ml.param" target="classFrame">IntArrayParam</a></li>
+<li><a href="org/apache/spark/sql/types/IntegerType.html" title="class in org.apache.spark.sql.types" target="classFrame">IntegerType</a></li>
+<li><a href="org/apache/spark/ml/feature/Interaction.html" title="class in org.apache.spark.ml.feature" target="classFrame">Interaction</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.html" title="class in org.apache.spark" target="classFrame">InternalAccumulator</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.input$.html" title="class in org.apache.spark" target="classFrame">InternalAccumulator.input$</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.output$.html" title="class in org.apache.spark" target="classFrame">InternalAccumulator.output$</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.shuffleRead$.html" title="class in org.apache.spark" target="classFrame">InternalAccumulator.shuffleRead$</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.shuffleWrite$.html" title="class in org.apache.spark" target="classFrame">InternalAccumulator.shuffleWrite$</a></li>
+<li><a href="org/apache/spark/ml/clustering/InternalKMeansModelWriter.html" title="class in org.apache.spark.ml.clustering" target="classFrame">InternalKMeansModelWriter</a></li>
+<li><a href="org/apache/spark/ml/regression/InternalLinearRegressionModelWriter.html" title="class in org.apache.spark.ml.regression" target="classFrame">InternalLinearRegressionModelWriter</a></li>
+<li><a href="org/apache/spark/ml/tree/InternalNode.html" title="class in org.apache.spark.ml.tree" target="classFrame">InternalNode</a></li>
+<li><a href="org/apache/spark/InterruptibleIterator.html" title="class in org.apache.spark" target="classFrame">InterruptibleIterator</a></li>
+<li><a href="org/apache/spark/ml/param/IntParam.html" title="class in org.apache.spark.ml.param" target="classFrame">IntParam</a></li>
+<li><a href="org/apache/spark/util/IntParam.html" title="class in org.apache.spark.util" target="classFrame">IntParam</a></li>
+<li><a href="org/apache/spark/sql/sources/IsNotNull.html" title="class in org.apache.spark.sql.sources" target="classFrame">IsNotNull</a></li>
+<li><a href="org/apache/spark/sql/sources/IsNull.html" title="class in org.apache.spark.sql.sources" target="classFrame">IsNull</a></li>
+<li><a href="org/apache/spark/ml/regression/IsotonicRegression.html" title="class in org.apache.spark.ml.regression" target="classFrame">IsotonicRegression</a></li>
+<li><a href="org/apache/spark/mllib/regression/IsotonicRegression.html" title="class in org.apache.spark.mllib.regression" target="classFrame">IsotonicRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/IsotonicRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">IsotonicRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/IsotonicRegressionModel.html" title="class in org.apache.spark.mllib.regression" target="classFrame">IsotonicRegressionModel</a></li>
+<li><a href="org/apache/spark/api/java/JavaDoubleRDD.html" title="class in org.apache.spark.api.java" target="classFrame">JavaDoubleRDD</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaDStream</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaDStreamLike.html" title="interface in org.apache.spark.streaming.api.java" target="classFrame"><span class="interfaceName">JavaDStreamLike</span></a></li>
+<li><a href="org/apache/spark/api/java/JavaFutureAction.html" title="interface in org.apache.spark.api.java" target="classFrame"><span class="interfaceName">JavaFutureAction</span></a></li>
+<li><a href="org/apache/spark/api/java/JavaHadoopRDD.html" title="class in org.apache.spark.api.java" target="classFrame">JavaHadoopRDD</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaInputDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaInputDStream</a></li>
+<li><a href="org/apache/spark/serializer/JavaIterableWrapperSerializer.html" title="class in org.apache.spark.serializer" target="classFrame">JavaIterableWrapperSerializer</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaMapWithStateDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaMapWithStateDStream</a></li>
+<li><a href="org/apache/spark/api/java/JavaNewHadoopRDD.html" title="class in org.apache.spark.api.java" target="classFrame">JavaNewHadoopRDD</a></li>
+<li><a href="org/apache/spark/mllib/JavaPackage.html" title="class in org.apache.spark.mllib" target="classFrame">JavaPackage</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaPairDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaPairDStream</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaPairInputDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaPairInputDStream</a></li>
+<li><a href="org/apache/spark/api/java/JavaPairRDD.html" title="class in org.apache.spark.api.java" target="classFrame">JavaPairRDD</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaPairReceiverInputDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaPairReceiverInputDStream</a></li>
+<li><a href="org/apache/spark/ml/param/JavaParams.html" title="class in org.apache.spark.ml.param" target="classFrame">JavaParams</a></li>
+<li><a href="org/apache/spark/api/java/JavaRDD.html" title="class in org.apache.spark.api.java" target="classFrame">JavaRDD</a></li>
+<li><a href="org/apache/spark/api/java/JavaRDDLike.html" title="interface in org.apache.spark.api.java" target="classFrame"><span class="interfaceName">JavaRDDLike</span></a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaReceiverInputDStream.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaReceiverInputDStream</a></li>
+<li><a href="org/apache/spark/serializer/JavaSerializer.html" title="class in org.apache.spark.serializer" target="classFrame">JavaSerializer</a></li>
+<li><a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java" target="classFrame">JavaSparkContext</a></li>
+<li><a href="org/apache/spark/api/java/JavaSparkStatusTracker.html" title="class in org.apache.spark.api.java" target="classFrame">JavaSparkStatusTracker</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaStreamingContext.html" title="class in org.apache.spark.streaming.api.java" target="classFrame">JavaStreamingContext</a></li>
+<li><a href="org/apache/spark/api/java/JavaUtils.html" title="class in org.apache.spark.api.java" target="classFrame">JavaUtils</a></li>
+<li><a href="org/apache/spark/api/java/JavaUtils.SerializableMapWrapper.html" title="class in org.apache.spark.api.java" target="classFrame">JavaUtils.SerializableMapWrapper</a></li>
+<li><a href="org/apache/spark/sql/jdbc/JdbcDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">JdbcDialect</a></li>
+<li><a href="org/apache/spark/sql/jdbc/JdbcDialects.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">JdbcDialects</a></li>
+<li><a href="org/apache/spark/rdd/JdbcRDD.html" title="class in org.apache.spark.rdd" target="classFrame">JdbcRDD</a></li>
+<li><a href="org/apache/spark/rdd/JdbcRDD.ConnectionFactory.html" title="interface in org.apache.spark.rdd" target="classFrame"><span class="interfaceName">JdbcRDD.ConnectionFactory</span></a></li>
+<li><a href="org/apache/spark/sql/jdbc/JdbcType.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">JdbcType</a></li>
+<li><a href="org/apache/spark/ui/JettyUtils.html" title="class in org.apache.spark.ui" target="classFrame">JettyUtils</a></li>
+<li><a href="org/apache/spark/ui/JettyUtils.ServletParams.html" title="class in org.apache.spark.ui" target="classFrame">JettyUtils.ServletParams</a></li>
+<li><a href="org/apache/spark/ui/JettyUtils.ServletParams$.html" title="class in org.apache.spark.ui" target="classFrame">JettyUtils.ServletParams$</a></li>
+<li><a href="org/apache/spark/status/api/v1/JobData.html" title="class in org.apache.spark.status.api.v1" target="classFrame">JobData</a></li>
+<li><a href="org/apache/spark/JobExecutionStatus.html" title="enum in org.apache.spark" target="classFrame">JobExecutionStatus</a></li>
+<li><a href="org/apache/spark/scheduler/JobResult.html" title="interface in org.apache.spark.scheduler" target="classFrame"><span class="interfaceName">JobResult</span></a></li>
+<li><a href="org/apache/spark/JobSubmitter.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">JobSubmitter</span></a></li>
+<li><a href="org/apache/spark/scheduler/JobSucceeded.html" title="class in org.apache.spark.scheduler" target="classFrame">JobSucceeded</a></li>
+<li><a href="org/apache/spark/ml/linalg/JsonMatrixConverter.html" title="class in org.apache.spark.ml.linalg" target="classFrame">JsonMatrixConverter</a></li>
+<li><a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util" target="classFrame">JsonProtocol</a></li>
+<li><a href="org/apache/spark/ml/linalg/JsonVectorConverter.html" title="class in org.apache.spark.ml.linalg" target="classFrame">JsonVectorConverter</a></li>
+<li><a href="org/apache/spark/mllib/stat/KernelDensity.html" title="class in org.apache.spark.mllib.stat" target="classFrame">KernelDensity</a></li>
+<li><a href="org/apache/spark/sql/KeyValueGroupedDataset.html" title="class in org.apache.spark.sql" target="classFrame">KeyValueGroupedDataset</a></li>
+<li><a href="org/apache/spark/scheduler/local/KillTask.html" title="class in org.apache.spark.scheduler.local" target="classFrame">KillTask</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">KinesisInitialPositions</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.AtTimestamp.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">KinesisInitialPositions.AtTimestamp</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.Latest.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">KinesisInitialPositions.Latest</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.TrimHorizon.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">KinesisInitialPositions.TrimHorizon</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">KinesisUtils</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisUtilsPythonHelper.html" title="class in org.apache.spark.streaming.kinesis" target="classFrame">KinesisUtilsPythonHelper</a></li>
+<li><a href="org/apache/spark/ml/clustering/KMeans.html" title="class in org.apache.spark.ml.clustering" target="classFrame">KMeans</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeans.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">KMeans</a></li>
+<li><a href="org/apache/spark/mllib/util/KMeansDataGenerator.html" title="class in org.apache.spark.mllib.util" target="classFrame">KMeansDataGenerator</a></li>
+<li><a href="org/apache/spark/ml/clustering/KMeansModel.html" title="class in org.apache.spark.ml.clustering" target="classFrame">KMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeansModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">KMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeansModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">KMeansModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeansModel.SaveLoadV2_0$.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">KMeansModel.SaveLoadV2_0$</a></li>
+<li><a href="org/apache/spark/ml/clustering/KMeansSummary.html" title="class in org.apache.spark.ml.clustering" target="classFrame">KMeansSummary</a></li>
+<li><a href="org/apache/spark/ml/stat/KolmogorovSmirnovTest.html" title="class in org.apache.spark.ml.stat" target="classFrame">KolmogorovSmirnovTest</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/KolmogorovSmirnovTest.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">KolmogorovSmirnovTest</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/KolmogorovSmirnovTest.NullHypothesis$.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">KolmogorovSmirnovTest.NullHypothesis$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/KolmogorovSmirnovTestResult.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">KolmogorovSmirnovTestResult</a></li>
+<li><a href="org/apache/spark/serializer/KryoRegistrator.html" title="interface in org.apache.spark.serializer" target="classFrame"><span class="interfaceName">KryoRegistrator</span></a></li>
+<li><a href="org/apache/spark/serializer/KryoSerializer.html" title="class in org.apache.spark.serializer" target="classFrame">KryoSerializer</a></li>
+<li><a href="org/apache/spark/status/KVUtils.html" title="class in org.apache.spark.status" target="classFrame">KVUtils</a></li>
+<li><a href="org/apache/spark/mllib/optimization/L1Updater.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">L1Updater</a></li>
+<li><a href="org/apache/spark/ml/feature/LabeledPoint.html" title="class in org.apache.spark.ml.feature" target="classFrame">LabeledPoint</a></li>
+<li><a href="org/apache/spark/mllib/regression/LabeledPoint.html" title="class in org.apache.spark.mllib.regression" target="classFrame">LabeledPoint</a></li>
+<li><a href="org/apache/spark/graphx/lib/LabelPropagation.html" title="class in org.apache.spark.graphx.lib" target="classFrame">LabelPropagation</a></li>
+<li><a href="org/apache/spark/mllib/regression/LassoModel.html" title="class in org.apache.spark.mllib.regression" target="classFrame">LassoModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/LassoWithSGD.html" title="class in org.apache.spark.mllib.regression" target="classFrame">LassoWithSGD</a></li>
+<li><a href="org/apache/spark/mllib/optimization/LBFGS.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">LBFGS</a></li>
+<li><a href="org/apache/spark/ml/clustering/LDA.html" title="class in org.apache.spark.ml.clustering" target="classFrame">LDA</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDA.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">LDA</a></li>
+<li><a href="org/apache/spark/ml/clustering/LDAModel.html" title="class in org.apache.spark.ml.clustering" target="classFrame">LDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDAModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">LDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDAOptimizer.html" title="interface in org.apache.spark.mllib.clustering" target="classFrame"><span class="interfaceName">LDAOptimizer</span></a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDAUtils.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">LDAUtils</a></li>
+<li><a href="org/apache/spark/ml/tree/LeafNode.html" title="class in org.apache.spark.ml.tree" target="classFrame">LeafNode</a></li>
+<li><a href="org/apache/spark/mllib/optimization/LeastSquaresGradient.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">LeastSquaresGradient</a></li>
+<li><a href="org/apache/spark/util/LegacyAccumulatorWrapper.html" title="class in org.apache.spark.util" target="classFrame">LegacyAccumulatorWrapper</a></li>
+<li><a href="org/apache/spark/sql/sources/LessThan.html" title="class in org.apache.spark.sql.sources" target="classFrame">LessThan</a></li>
+<li><a href="org/apache/spark/sql/sources/LessThanOrEqual.html" title="class in org.apache.spark.sql.sources" target="classFrame">LessThanOrEqual</a></li>
+<li><a href="org/apache/spark/ml/source/libsvm/LibSVMDataSource.html" title="class in org.apache.spark.ml.source.libsvm" target="classFrame">LibSVMDataSource</a></li>
+<li><a href="org/apache/spark/mllib/util/LinearDataGenerator.html" title="class in org.apache.spark.mllib.util" target="classFrame">LinearDataGenerator</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegression.html" title="class in org.apache.spark.ml.regression" target="classFrame">LinearRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">LinearRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/LinearRegressionModel.html" title="class in org.apache.spark.mllib.regression" target="classFrame">LinearRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegressionSummary.html" title="class in org.apache.spark.ml.regression" target="classFrame">LinearRegressionSummary</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegressionTrainingSummary.html" title="class in org.apache.spark.ml.regression" target="classFrame">LinearRegressionTrainingSummary</a></li>
+<li><a href="org/apache/spark/mllib/regression/LinearRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression" target="classFrame">LinearRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/ml/classification/LinearSVC.html" title="class in org.apache.spark.ml.classification" target="classFrame">LinearSVC</a></li>
+<li><a href="org/apache/spark/ml/classification/LinearSVCModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">LinearSVCModel</a></li>
+<li><a href="org/apache/spark/status/LiveEntityHelpers.html" title="class in org.apache.spark.status" target="classFrame">LiveEntityHelpers</a></li>
+<li><a href="org/apache/spark/status/LiveExecutor.html" title="class in org.apache.spark.status" target="classFrame">LiveExecutor</a></li>
+<li><a href="org/apache/spark/status/LiveExecutorStageSummary.html" title="class in org.apache.spark.status" target="classFrame">LiveExecutorStageSummary</a></li>
+<li><a href="org/apache/spark/status/LiveJob.html" title="class in org.apache.spark.status" target="classFrame">LiveJob</a></li>
+<li><a href="org/apache/spark/status/LiveRDD.html" title="class in org.apache.spark.status" target="classFrame">LiveRDD</a></li>
+<li><a href="org/apache/spark/status/LiveRDDDistribution.html" title="class in org.apache.spark.status" target="classFrame">LiveRDDDistribution</a></li>
+<li><a href="org/apache/spark/status/LiveRDDPartition.html" title="class in org.apache.spark.status" target="classFrame">LiveRDDPartition</a></li>
+<li><a href="org/apache/spark/status/LiveStage.html" title="class in org.apache.spark.status" target="classFrame">LiveStage</a></li>
+<li><a href="org/apache/spark/status/LiveTask.html" title="class in org.apache.spark.status" target="classFrame">LiveTask</a></li>
+<li><a href="org/apache/spark/mllib/util/Loader.html" title="interface in org.apache.spark.mllib.util" target="classFrame"><span class="interfaceName">Loader</span></a></li>
+<li><a href="org/apache/spark/mllib/clustering/LocalKMeans.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">LocalKMeans</a></li>
+<li><a href="org/apache/spark/ml/clustering/LocalLDAModel.html" title="class in org.apache.spark.ml.clustering" target="classFrame">LocalLDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LocalLDAModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">LocalLDAModel</a></li>
+<li><a href="org/apache/spark/internal/Logging.html" title="interface in org.apache.spark.internal" target="classFrame"><span class="interfaceName">Logging</span></a></li>
+<li><a href="org/apache/spark/mllib/optimization/LogisticGradient.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">LogisticGradient</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegression.html" title="class in org.apache.spark.ml.classification" target="classFrame">LogisticRegression</a></li>
+<li><a href="org/apache/spark/mllib/util/LogisticRegressionDataGenerator.html" title="class in org.apache.spark.mllib.util" target="classFrame">LogisticRegressionDataGenerator</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">LogisticRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/LogisticRegressionModel.html" title="class in org.apache.spark.mllib.classification" target="classFrame">LogisticRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification" target="classFrame"><span class="interfaceName">LogisticRegressionSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionSummaryImpl.html" title="class in org.apache.spark.ml.classification" target="classFrame">LogisticRegressionSummaryImpl</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionTrainingSummary.html" title="interface in org.apache.spark.ml.classification" target="classFrame"><span class="interfaceName">LogisticRegressionTrainingSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionTrainingSummaryImpl.html" title="class in org.apache.spark.ml.classification" target="classFrame">LogisticRegressionTrainingSummaryImpl</a></li>
+<li><a href="org/apache/spark/mllib/classification/LogisticRegressionWithLBFGS.html" title="class in org.apache.spark.mllib.classification" target="classFrame">LogisticRegressionWithLBFGS</a></li>
+<li><a href="org/apache/spark/mllib/classification/LogisticRegressionWithSGD.html" title="class in org.apache.spark.mllib.classification" target="classFrame">LogisticRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/LogLoss.html" title="class in org.apache.spark.mllib.tree.loss" target="classFrame">LogLoss</a></li>
+<li><a href="org/apache/spark/mllib/random/LogNormalGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">LogNormalGenerator</a></li>
+<li><a href="org/apache/spark/util/LongAccumulator.html" title="class in org.apache.spark.util" target="classFrame">LongAccumulator</a></li>
+<li><a href="org/apache/spark/ml/param/LongParam.html" title="class in org.apache.spark.ml.param" target="classFrame">LongParam</a></li>
+<li><a href="org/apache/spark/sql/types/LongType.html" title="class in org.apache.spark.sql.types" target="classFrame">LongType</a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/Loss.html" title="interface in org.apache.spark.mllib.tree.loss" target="classFrame"><span class="interfaceName">Loss</span></a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/Losses.html" title="class in org.apache.spark.mllib.tree.loss" target="classFrame">Losses</a></li>
+<li><a href="org/apache/spark/scheduler/LossReasonPending.html" title="class in org.apache.spark.scheduler" target="classFrame">LossReasonPending</a></li>
+<li><a href="org/apache/spark/sql/LowPrioritySQLImplicits.html" title="interface in org.apache.spark.sql" target="classFrame"><span class="interfaceName">LowPrioritySQLImplicits</span></a></li>
+<li><a href="org/apache/spark/io/LZ4CompressionCodec.html" title="class in org.apache.spark.io" target="classFrame">LZ4CompressionCodec</a></li>
+<li><a href="org/apache/spark/io/LZFCompressionCodec.html" title="class in org.apache.spark.io" target="classFrame">LZFCompressionCodec</a></li>
+<li><a href="org/apache/spark/api/java/function/MapFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">MapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/MapGroupsFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">MapGroupsFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/MapGroupsWithStateFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">MapGroupsWithStateFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/MapPartitionsFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">MapPartitionsFunction</span></a></li>
+<li><a href="org/apache/spark/sql/types/MapType.html" title="class in org.apache.spark.sql.types" target="classFrame">MapType</a></li>
+<li><a href="org/apache/spark/streaming/dstream/MapWithStateDStream.html" title="class in org.apache.spark.streaming.dstream" target="classFrame">MapWithStateDStream</a></li>
+<li><a href="org/apache/spark/ml/linalg/Matrices.html" title="class in org.apache.spark.ml.linalg" target="classFrame">Matrices</a></li>
+<li><a href="org/apache/spark/mllib/linalg/Matrices.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">Matrices</a></li>
+<li><a href="org/apache/spark/ml/linalg/Matrix.html" title="interface in org.apache.spark.ml.linalg" target="classFrame"><span class="interfaceName">Matrix</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/Matrix.html" title="interface in org.apache.spark.mllib.linalg" target="classFrame"><span class="interfaceName">Matrix</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/MatrixEntry.html" title="class in org.apache.spark.mllib.linalg.distributed" target="classFrame">MatrixEntry</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/MatrixFactorizationModel.html" title="class in org.apache.spark.mllib.recommendation" target="classFrame">MatrixFactorizationModel</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/MatrixFactorizationModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.recommendation" target="classFrame">MatrixFactorizationModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/linalg/MatrixImplicits.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">MatrixImplicits</a></li>
+<li><a href="org/apache/spark/ml/feature/MaxAbsScaler.html" title="class in org.apache.spark.ml.feature" target="classFrame">MaxAbsScaler</a></li>
+<li><a href="org/apache/spark/ml/feature/MaxAbsScalerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">MaxAbsScalerModel</a></li>
+<li><a href="org/apache/spark/storage/memory/MemoryEntry.html" title="interface in org.apache.spark.storage.memory" target="classFrame"><span class="interfaceName">MemoryEntry</span></a></li>
+<li><a href="org/apache/spark/storage/memory/MemoryEntryBuilder.html" title="interface in org.apache.spark.storage.memory" target="classFrame"><span class="interfaceName">MemoryEntryBuilder</span></a></li>
+<li><a href="org/apache/spark/status/api/v1/MemoryMetrics.html" title="class in org.apache.spark.status.api.v1" target="classFrame">MemoryMetrics</a></li>
+<li><a href="org/apache/spark/util/MemoryParam.html" title="class in org.apache.spark.util" target="classFrame">MemoryParam</a></li>
+<li><a href="org/apache/spark/ml/util/MetaAlgorithmReadWrite.html" title="class in org.apache.spark.ml.util" target="classFrame">MetaAlgorithmReadWrite</a></li>
+<li><a href="org/apache/spark/sql/types/Metadata.html" title="class in org.apache.spark.sql.types" target="classFrame">Metadata</a></li>
+<li><a href="org/apache/spark/sql/types/MetadataBuilder.html" title="class in org.apache.spark.sql.types" target="classFrame">MetadataBuilder</a></li>
+<li><a href="org/apache/spark/ml/util/MetadataUtils.html" title="class in org.apache.spark.ml.util" target="classFrame">MetadataUtils</a></li>
+<li><a href="org/apache/spark/util/MethodIdentifier.html" title="class in org.apache.spark.util" target="classFrame">MethodIdentifier</a></li>
+<li><a href="org/apache/spark/mllib/util/MFDataGenerator.html" title="class in org.apache.spark.mllib.util" target="classFrame">MFDataGenerator</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/MicroBatchReader.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming" target="classFrame"><span class="interfaceName">MicroBatchReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/MicroBatchReadSupport.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">MicroBatchReadSupport</span></a></li>
+<li><a href="org/apache/spark/streaming/Milliseconds.html" title="class in org.apache.spark.streaming" target="classFrame">Milliseconds</a></li>
+<li><a href="org/apache/spark/ml/feature/MinHashLSH.html" title="class in org.apache.spark.ml.feature" target="classFrame">MinHashLSH</a></li>
+<li><a href="org/apache/spark/ml/feature/MinHashLSHModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">MinHashLSHModel</a></li>
+<li><a href="org/apache/spark/ml/feature/MinMaxScaler.html" title="class in org.apache.spark.ml.feature" target="classFrame">MinMaxScaler</a></li>
+<li><a href="org/apache/spark/ml/feature/MinMaxScalerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">MinMaxScalerModel</a></li>
+<li><a href="org/apache/spark/streaming/Minutes.html" title="class in org.apache.spark.streaming" target="classFrame">Minutes</a></li>
+<li><a href="org/apache/spark/ml/util/MLFormatRegister.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">MLFormatRegister</span></a></li>
+<li><a href="org/apache/spark/mllib/rdd/MLPairRDDFunctions.html" title="class in org.apache.spark.mllib.rdd" target="classFrame">MLPairRDDFunctions</a></li>
+<li><a href="org/apache/spark/ml/util/MLReadable.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">MLReadable</span></a></li>
+<li><a href="org/apache/spark/ml/util/MLReader.html" title="class in org.apache.spark.ml.util" target="classFrame">MLReader</a></li>
+<li><a href="org/apache/spark/mllib/util/MLUtils.html" title="class in org.apache.spark.mllib.util" target="classFrame">MLUtils</a></li>
+<li><a href="org/apache/spark/ml/util/MLWritable.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">MLWritable</span></a></li>
+<li><a href="org/apache/spark/ml/util/MLWriter.html" title="class in org.apache.spark.ml.util" target="classFrame">MLWriter</a></li>
+<li><a href="org/apache/spark/ml/util/MLWriterFormat.html" title="interface in org.apache.spark.ml.util" target="classFrame"><span class="interfaceName">MLWriterFormat</span></a></li>
+<li><a href="org/apache/spark/ml/Model.html" title="class in org.apache.spark.ml" target="classFrame">Model</a></li>
+<li><a href="org/apache/spark/sql/jdbc/MsSqlServerDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">MsSqlServerDialect</a></li>
+<li><a href="org/apache/spark/ml/evaluation/MulticlassClassificationEvaluator.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">MulticlassClassificationEvaluator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html" title="class in org.apache.spark.mllib.evaluation" target="classFrame">MulticlassMetrics</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/MultilabelMetrics.html" title="class in org.apache.spark.mllib.evaluation" target="classFrame">MultilabelMetrics</a></li>
+<li><a href="org/apache/spark/ml/classification/MultilayerPerceptronClassificationModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">MultilayerPerceptronClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/MultilayerPerceptronClassifier.html" title="class in org.apache.spark.ml.classification" target="classFrame">MultilayerPerceptronClassifier</a></li>
+<li><a href="org/apache/spark/ml/stat/distribution/MultivariateGaussian.html" title="class in org.apache.spark.ml.stat.distribution" target="classFrame">MultivariateGaussian</a></li>
+<li><a href="org/apache/spark/mllib/stat/distribution/MultivariateGaussian.html" title="class in org.apache.spark.mllib.stat.distribution" target="classFrame">MultivariateGaussian</a></li>
+<li><a href="org/apache/spark/mllib/stat/MultivariateOnlineSummarizer.html" title="class in org.apache.spark.mllib.stat" target="classFrame">MultivariateOnlineSummarizer</a></li>
+<li><a href="org/apache/spark/mllib/stat/MultivariateStatisticalSummary.html" title="interface in org.apache.spark.mllib.stat" target="classFrame"><span class="interfaceName">MultivariateStatisticalSummary</span></a></li>
+<li><a href="org/apache/spark/sql/expressions/MutableAggregationBuffer.html" title="class in org.apache.spark.sql.expressions" target="classFrame">MutableAggregationBuffer</a></li>
+<li><a href="org/apache/spark/util/MutablePair.html" title="class in org.apache.spark.util" target="classFrame">MutablePair</a></li>
+<li><a href="org/apache/spark/util/MutableURLClassLoader.html" title="class in org.apache.spark.util" target="classFrame">MutableURLClassLoader</a></li>
+<li><a href="org/apache/spark/sql/jdbc/MySQLDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">MySQLDialect</a></li>
+<li><a href="org/apache/spark/ml/classification/NaiveBayes.html" title="class in org.apache.spark.ml.classification" target="classFrame">NaiveBayes</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayes.html" title="class in org.apache.spark.mllib.classification" target="classFrame">NaiveBayes</a></li>
+<li><a href="org/apache/spark/ml/classification/NaiveBayesModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">NaiveBayesModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayesModel.html" title="class in org.apache.spark.mllib.classification" target="classFrame">NaiveBayesModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayesModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.classification" target="classFrame">NaiveBayesModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayesModel.SaveLoadV2_0$.html" title="class in org.apache.spark.mllib.classification" target="classFrame">NaiveBayesModel.SaveLoadV2_0$</a></li>
+<li><a href="org/apache/spark/NarrowDependency.html" title="class in org.apache.spark" target="classFrame">NarrowDependency</a></li>
+<li><a href="org/apache/spark/rdd/NewHadoopRDD.html" title="class in org.apache.spark.rdd" target="classFrame">NewHadoopRDD</a></li>
+<li><a href="org/apache/spark/rdd/NewHadoopRDD.NewHadoopMapPartitionsWithSplitRDD$.html" title="class in org.apache.spark.rdd" target="classFrame">NewHadoopRDD.NewHadoopMapPartitionsWithSplitRDD$</a></li>
+<li><a href="org/apache/spark/ml/feature/NGram.html" title="class in org.apache.spark.ml.feature" target="classFrame">NGram</a></li>
+<li><a href="org/apache/spark/io/NioBufferedFileInputStream.html" title="class in org.apache.spark.io" target="classFrame">NioBufferedFileInputStream</a></li>
+<li><a href="org/apache/spark/mllib/optimization/NNLS.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">NNLS</a></li>
+<li><a href="org/apache/spark/mllib/optimization/NNLS.Workspace.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">NNLS.Workspace</a></li>
+<li><a href="org/apache/spark/ml/tree/Node.html" title="class in org.apache.spark.ml.tree" target="classFrame">Node</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/Node.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">Node</a></li>
+<li><a href="org/apache/spark/ml/attribute/NominalAttribute.html" title="class in org.apache.spark.ml.attribute" target="classFrame">NominalAttribute</a></li>
+<li><a href="org/apache/spark/sql/jdbc/NoopDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">NoopDialect</a></li>
+<li><a href="org/apache/spark/ml/feature/Normalizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">Normalizer</a></li>
+<li><a href="org/apache/spark/mllib/feature/Normalizer.html" title="class in org.apache.spark.mllib.feature" target="classFrame">Normalizer</a></li>
+<li><a href="org/apache/spark/sql/sources/Not.html" title="class in org.apache.spark.sql.sources" target="classFrame">Not</a></li>
+<li><a href="org/apache/spark/sql/types/NullType.html" title="class in org.apache.spark.sql.types" target="classFrame">NullType</a></li>
+<li><a href="org/apache/spark/ml/attribute/NumericAttribute.html" title="class in org.apache.spark.ml.attribute" target="classFrame">NumericAttribute</a></li>
+<li><a href="org/apache/spark/mllib/util/NumericParser.html" title="class in org.apache.spark.mllib.util" target="classFrame">NumericParser</a></li>
+<li><a href="org/apache/spark/sql/types/NumericType.html" title="class in org.apache.spark.sql.types" target="classFrame">NumericType</a></li>
+<li><a href="org/apache/spark/sql/types/ObjectType.html" title="class in org.apache.spark.sql.types" target="classFrame">ObjectType</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/Offset.html" title="class in org.apache.spark.sql.sources.v2.reader.streaming" target="classFrame">Offset</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoder.html" title="class in org.apache.spark.ml.feature" target="classFrame">OneHotEncoder</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoderCommon.html" title="class in org.apache.spark.ml.feature" target="classFrame">OneHotEncoderCommon</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoderEstimator.html" title="class in org.apache.spark.ml.feature" target="classFrame">OneHotEncoderEstimator</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoderModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">OneHotEncoderModel</a></li>
+<li><a href="org/apache/spark/OneToOneDependency.html" title="class in org.apache.spark" target="classFrame">OneToOneDependency</a></li>
+<li><a href="org/apache/spark/ml/classification/OneVsRest.html" title="class in org.apache.spark.ml.classification" target="classFrame">OneVsRest</a></li>
+<li><a href="org/apache/spark/ml/classification/OneVsRestModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">OneVsRestModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/OnlineLDAOptimizer.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">OnlineLDAOptimizer</a></li>
+<li><a href="org/apache/spark/rpc/netty/OnStart.html" title="class in org.apache.spark.rpc.netty" target="classFrame">OnStart</a></li>
+<li><a href="org/apache/spark/rpc/netty/OnStop.html" title="class in org.apache.spark.rpc.netty" target="classFrame">OnStop</a></li>
+<li><a href="org/apache/spark/mllib/optimization/Optimizer.html" title="interface in org.apache.spark.mllib.optimization" target="classFrame"><span class="interfaceName">Optimizer</span></a></li>
+<li><a href="org/apache/spark/api/java/Optional.html" title="class in org.apache.spark.api.java" target="classFrame">Optional</a></li>
+<li><a href="org/apache/spark/sql/sources/Or.html" title="class in org.apache.spark.sql.sources" target="classFrame">Or</a></li>
+<li><a href="org/apache/spark/sql/jdbc/OracleDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">OracleDialect</a></li>
+<li><a href="org/apache/spark/sql/hive/orc/OrcFileFormat.html" title="class in org.apache.spark.sql.hive.orc" target="classFrame">OrcFileFormat</a></li>
+<li><a href="org/apache/spark/sql/hive/orc/OrcFileOperator.html" title="class in org.apache.spark.sql.hive.orc" target="classFrame">OrcFileOperator</a></li>
+<li><a href="org/apache/spark/sql/hive/orc/OrcFilters.html" title="class in org.apache.spark.sql.hive.orc" target="classFrame">OrcFilters</a></li>
+<li><a href="org/apache/spark/rdd/OrderedRDDFunctions.html" title="class in org.apache.spark.rdd" target="classFrame">OrderedRDDFunctions</a></li>
+<li><a href="org/apache/spark/scheduler/OutputCommitCoordinationMessage.html" title="interface in org.apache.spark.scheduler" target="classFrame"><span class="interfaceName">OutputCommitCoordinationMessage</span></a></li>
+<li><a href="org/apache/spark/status/api/v1/OutputMetricDistributions.html" title="class in org.apache.spark.status.api.v1" target="classFrame">OutputMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/OutputMetrics.html" title="class in org.apache.spark.status.api.v1" target="classFrame">OutputMetrics</a></li>
+<li><a href="org/apache/spark/sql/streaming/OutputMode.html" title="class in org.apache.spark.sql.streaming" target="classFrame">OutputMode</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/OutputOperationInfo.html" title="class in org.apache.spark.status.api.v1.streaming" target="classFrame">OutputOperationInfo</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/OutputOperationInfo.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">OutputOperationInfo</a></li>
+<li><a href="org/apache/spark/graphx/lib/PageRank.html" title="class in org.apache.spark.graphx.lib" target="classFrame">PageRank</a></li>
+<li><a href="org/apache/spark/streaming/dstream/PairDStreamFunctions.html" title="class in org.apache.spark.streaming.dstream" target="classFrame">PairDStreamFunctions</a></li>
+<li><a href="org/apache/spark/api/java/function/PairFlatMapFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">PairFlatMapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/PairFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">PairFunction</span></a></li>
+<li><a href="org/apache/spark/rdd/PairRDDFunctions.html" title="class in org.apache.spark.rdd" target="classFrame">PairRDDFunctions</a></li>
+<li><a href="org/apache/spark/api/r/PairwiseRRDD.html" title="class in org.apache.spark.api.r" target="classFrame">PairwiseRRDD</a></li>
+<li><a href="org/apache/spark/ml/param/Param.html" title="class in org.apache.spark.ml.param" target="classFrame">Param</a></li>
+<li><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning" target="classFrame">ParamGridBuilder</a></li>
+<li><a href="org/apache/spark/ml/param/ParamMap.html" title="class in org.apache.spark.ml.param" target="classFrame">ParamMap</a></li>
+<li><a href="org/apache/spark/ml/param/ParamPair.html" title="class in org.apache.spark.ml.param" target="classFrame">ParamPair</a></li>
+<li><a href="org/apache/spark/ml/param/Params.html" title="interface in org.apache.spark.ml.param" target="classFrame"><span class="interfaceName">Params</span></a></li>
+<li><a href="org/apache/spark/ml/param/ParamValidators.html" title="class in org.apache.spark.ml.param" target="classFrame">ParamValidators</a></li>
+<li><a href="org/apache/spark/util/ParentClassLoader.html" title="class in org.apache.spark.util" target="classFrame">ParentClassLoader</a></li>
+<li><a href="org/apache/spark/partial/PartialResult.html" title="class in org.apache.spark.partial" target="classFrame">PartialResult</a></li>
+<li><a href="org/apache/spark/Partition.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">Partition</span></a></li>
+<li><a href="org/apache/spark/rdd/PartitionCoalescer.html" title="interface in org.apache.spark.rdd" target="classFrame"><span class="interfaceName">PartitionCoalescer</span></a></li>
+<li><a href="org/apache/spark/Partitioner.html" title="class in org.apache.spark" target="classFrame">Partitioner</a></li>
+<li><a href="org/apache/spark/rdd/PartitionGroup.html" title="class in org.apache.spark.rdd" target="classFrame">PartitionGroup</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/partitioning/Partitioning.html" title="interface in org.apache.spark.sql.sources.v2.reader.partitioning" target="classFrame"><span class="interfaceName">Partitioning</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/PartitionOffset.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming" target="classFrame"><span class="interfaceName">PartitionOffset</span></a></li>
+<li><a href="org/apache/spark/rdd/PartitionPruningRDD.html" title="class in org.apache.spark.rdd" target="classFrame">PartitionPruningRDD</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.html" title="interface in org.apache.spark.graphx" target="classFrame"><span class="interfaceName">PartitionStrategy</span></a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.CanonicalRandomVertexCut$.html" title="class in org.apache.spark.graphx" target="classFrame">PartitionStrategy.CanonicalRandomVertexCut$</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.EdgePartition1D$.html" title="class in org.apache.spark.graphx" target="classFrame">PartitionStrategy.EdgePartition1D$</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.EdgePartition2D$.html" title="class in org.apache.spark.graphx" target="classFrame">PartitionStrategy.EdgePartition2D$</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.RandomVertexCut$.html" title="class in org.apache.spark.graphx" target="classFrame">PartitionStrategy.RandomVertexCut$</a></li>
+<li><a href="org/apache/spark/ml/feature/PCA.html" title="class in org.apache.spark.ml.feature" target="classFrame">PCA</a></li>
+<li><a href="org/apache/spark/mllib/feature/PCA.html" title="class in org.apache.spark.mllib.feature" target="classFrame">PCA</a></li>
+<li><a href="org/apache/spark/ml/feature/PCAModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">PCAModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/PCAModel.html" title="class in org.apache.spark.mllib.feature" target="classFrame">PCAModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/PCAUtil.html" title="class in org.apache.spark.mllib.feature" target="classFrame">PCAUtil</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/PearsonCorrelation.html" title="class in org.apache.spark.mllib.stat.correlation" target="classFrame">PearsonCorrelation</a></li>
+<li><a href="org/apache/spark/ml/Pipeline.html" title="class in org.apache.spark.ml" target="classFrame">Pipeline</a></li>
+<li><a href="org/apache/spark/ml/Pipeline.SharedReadWrite$.html" title="class in org.apache.spark.ml" target="classFrame">Pipeline.SharedReadWrite$</a></li>
+<li><a href="org/apache/spark/ml/PipelineModel.html" title="class in org.apache.spark.ml" target="classFrame">PipelineModel</a></li>
+<li><a href="org/apache/spark/ml/PipelineStage.html" title="class in org.apache.spark.ml" target="classFrame">PipelineStage</a></li>
+<li><a href="org/apache/spark/mllib/pmml/PMMLExportable.html" title="interface in org.apache.spark.mllib.pmml" target="classFrame"><span class="interfaceName">PMMLExportable</span></a></li>
+<li><a href="org/apache/spark/ml/clustering/PMMLKMeansModelWriter.html" title="class in org.apache.spark.ml.clustering" target="classFrame">PMMLKMeansModelWriter</a></li>
+<li><a href="org/apache/spark/ml/regression/PMMLLinearRegressionModelWriter.html" title="class in org.apache.spark.ml.regression" target="classFrame">PMMLLinearRegressionModelWriter</a></li>
+<li><a href="org/apache/spark/mllib/pmml/export/PMMLModelExportFactory.html" title="class in org.apache.spark.mllib.pmml.export" target="classFrame">PMMLModelExportFactory</a></li>
+<li><a href="org/apache/spark/util/random/PoissonBounds.html" title="class in org.apache.spark.util.random" target="classFrame">PoissonBounds</a></li>
+<li><a href="org/apache/spark/mllib/random/PoissonGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">PoissonGenerator</a></li>
+<li><a href="org/apache/spark/util/random/PoissonSampler.html" title="class in org.apache.spark.util.random" target="classFrame">PoissonSampler</a></li>
+<li><a href="org/apache/spark/ml/feature/PolynomialExpansion.html" title="class in org.apache.spark.ml.feature" target="classFrame">PolynomialExpansion</a></li>
+<li><a href="org/apache/spark/input/PortableDataStream.html" title="class in org.apache.spark.input" target="classFrame">PortableDataStream</a></li>
+<li><a href="org/apache/spark/sql/jdbc/PostgresDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">PostgresDialect</a></li>
+<li><a href="org/apache/spark/ml/clustering/PowerIterationClustering.html" title="class in org.apache.spark.ml.clustering" target="classFrame">PowerIterationClustering</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">PowerIterationClustering</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">PowerIterationClustering.Assignment</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment$.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">PowerIterationClustering.Assignment$</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClusteringModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">PowerIterationClusteringModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClusteringModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">PowerIterationClusteringModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/binary/Precision.html" title="class in org.apache.spark.mllib.evaluation.binary" target="classFrame">Precision</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/Predict.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">Predict</a></li>
+<li><a href="org/apache/spark/ml/PredictionModel.html" title="class in org.apache.spark.ml" target="classFrame">PredictionModel</a></li>
+<li><a href="org/apache/spark/ml/Predictor.html" title="class in org.apache.spark.ml" target="classFrame">Predictor</a></li>
+<li><a href="org/apache/spark/ml/fpm/PrefixSpan.html" title="class in org.apache.spark.ml.fpm" target="classFrame">PrefixSpan</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">PrefixSpan</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.FreqSequence.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">PrefixSpan.FreqSequence</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.Postfix$.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">PrefixSpan.Postfix$</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.Prefix$.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">PrefixSpan.Prefix$</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpanModel.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">PrefixSpanModel</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpanModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.fpm" target="classFrame">PrefixSpanModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/graphx/Pregel.html" title="class in org.apache.spark.graphx" target="classFrame">Pregel</a></li>
+<li><a href="org/apache/spark/ml/classification/ProbabilisticClassificationModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">ProbabilisticClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/ProbabilisticClassifier.html" title="class in org.apache.spark.ml.classification" target="classFrame">ProbabilisticClassifier</a></li>
+<li><a href="org/apache/spark/sql/streaming/ProcessingTime.html" title="class in org.apache.spark.sql.streaming" target="classFrame">ProcessingTime</a></li>
+<li><a href="org/apache/spark/sql/sources/PrunedFilteredScan.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">PrunedFilteredScan</span></a></li>
+<li><a href="org/apache/spark/sql/sources/PrunedScan.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">PrunedScan</span></a></li>
+<li><a href="org/apache/spark/util/random/Pseudorandom.html" title="interface in org.apache.spark.util.random" target="classFrame"><span class="interfaceName">Pseudorandom</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/QRDecomposition.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">QRDecomposition</a></li>
+<li><a href="org/apache/spark/ml/feature/QuantileDiscretizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">QuantileDiscretizer</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/QuantileStrategy.html" title="class in org.apache.spark.mllib.tree.configuration" target="classFrame">QuantileStrategy</a></li>
+<li><a href="org/apache/spark/sql/util/QueryExecutionListener.html" title="interface in org.apache.spark.sql.util" target="classFrame"><span class="interfaceName">QueryExecutionListener</span></a></li>
+<li><a href="org/apache/spark/storage/RandomBlockReplicationPolicy.html" title="class in org.apache.spark.storage" target="classFrame">RandomBlockReplicationPolicy</a></li>
+<li><a href="org/apache/spark/mllib/random/RandomDataGenerator.html" title="interface in org.apache.spark.mllib.random" target="classFrame"><span class="interfaceName">RandomDataGenerator</span></a></li>
+<li><a href="org/apache/spark/ml/tree/impl/RandomForest.html" title="class in org.apache.spark.ml.tree.impl" target="classFrame">RandomForest</a></li>
+<li><a href="org/apache/spark/mllib/tree/RandomForest.html" title="class in org.apache.spark.mllib.tree" target="classFrame">RandomForest</a></li>
+<li><a href="org/apache/spark/ml/classification/RandomForestClassificationModel.html" title="class in org.apache.spark.ml.classification" target="classFrame">RandomForestClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/RandomForestClassifier.html" title="class in org.apache.spark.ml.classification" target="classFrame">RandomForestClassifier</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/RandomForestModel.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">RandomForestModel</a></li>
+<li><a href="org/apache/spark/ml/regression/RandomForestRegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">RandomForestRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/RandomForestRegressor.html" title="class in org.apache.spark.ml.regression" target="classFrame">RandomForestRegressor</a></li>
+<li><a href="org/apache/spark/mllib/random/RandomRDDs.html" title="class in org.apache.spark.mllib.random" target="classFrame">RandomRDDs</a></li>
+<li><a href="org/apache/spark/util/random/RandomSampler.html" title="interface in org.apache.spark.util.random" target="classFrame"><span class="interfaceName">RandomSampler</span></a></li>
+<li><a href="org/apache/spark/RangeDependency.html" title="class in org.apache.spark" target="classFrame">RangeDependency</a></li>
+<li><a href="org/apache/spark/RangePartitioner.html" title="class in org.apache.spark" target="classFrame">RangePartitioner</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/RankingMetrics.html" title="class in org.apache.spark.mllib.evaluation" target="classFrame">RankingMetrics</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/Rating.html" title="class in org.apache.spark.mllib.recommendation" target="classFrame">Rating</a></li>
+<li><a href="org/apache/spark/streaming/util/RawTextHelper.html" title="class in org.apache.spark.streaming.util" target="classFrame">RawTextHelper</a></li>
+<li><a href="org/apache/spark/streaming/util/RawTextSender.html" title="class in org.apache.spark.streaming.util" target="classFrame">RawTextSender</a></li>
+<li><a href="org/apache/spark/api/r/RBackendAuthHandler.html" title="class in org.apache.spark.api.r" target="classFrame">RBackendAuthHandler</a></li>
+<li><a href="org/apache/spark/rdd/RDD.html" title="class in org.apache.spark.rdd" target="classFrame">RDD</a></li>
+<li><a href="org/apache/spark/rdd/RDDBarrier.html" title="class in org.apache.spark.rdd" target="classFrame">RDDBarrier</a></li>
+<li><a href="org/apache/spark/storage/RDDBlockId.html" title="class in org.apache.spark.storage" target="classFrame">RDDBlockId</a></li>
+<li><a href="org/apache/spark/status/api/v1/RDDDataDistribution.html" title="class in org.apache.spark.status.api.v1" target="classFrame">RDDDataDistribution</a></li>
+<li><a href="org/apache/spark/mllib/rdd/RDDFunctions.html" title="class in org.apache.spark.mllib.rdd" target="classFrame">RDDFunctions</a></li>
+<li><a href="org/apache/spark/storage/RDDInfo.html" title="class in org.apache.spark.storage" target="classFrame">RDDInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/RDDPartitionInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">RDDPartitionInfo</a></li>
+<li><a href="org/apache/spark/status/RDDPartitionSeq.html" title="class in org.apache.spark.status" target="classFrame">RDDPartitionSeq</a></li>
+<li><a href="org/apache/spark/status/api/v1/RDDStorageInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">RDDStorageInfo</a></li>
+<li><a href="org/apache/spark/storage/ReadableChannelFileRegion.html" title="class in org.apache.spark.storage" target="classFrame">ReadableChannelFileRegion</a></li>
+<li><a href="org/apache/spark/io/ReadAheadInputStream.html" title="class in org.apache.spark.io" target="classFrame">ReadAheadInputStream</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/ReadSupport.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">ReadSupport</span></a></li>
+<li><a href="org/apache/spark/mllib/evaluation/binary/Recall.html" title="class in org.apache.spark.mllib.evaluation.binary" target="classFrame">Recall</a></li>
+<li><a href="org/apache/spark/streaming/receiver/Receiver.html" title="class in org.apache.spark.streaming.receiver" target="classFrame">Receiver</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/ReceiverInfo.html" title="class in org.apache.spark.status.api.v1.streaming" target="classFrame">ReceiverInfo</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/ReceiverInfo.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">ReceiverInfo</a></li>
+<li><a href="org/apache/spark/streaming/dstream/ReceiverInputDStream.html" title="class in org.apache.spark.streaming.dstream" target="classFrame">ReceiverInputDStream</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/ReceiverState.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">ReceiverState</a></li>
+<li><a href="org/apache/spark/ml/image/RecursiveFlag.html" title="class in org.apache.spark.ml.image" target="classFrame">RecursiveFlag</a></li>
+<li><a href="org/apache/spark/api/java/function/ReduceFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">ReduceFunction</span></a></li>
+<li><a href="org/apache/spark/ml/feature/RegexTokenizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">RegexTokenizer</a></li>
+<li><a href="org/apache/spark/ml/evaluation/RegressionEvaluator.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">RegressionEvaluator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/RegressionMetrics.html" title="class in org.apache.spark.mllib.evaluation" target="classFrame">RegressionMetrics</a></li>
+<li><a href="org/apache/spark/ml/regression/RegressionModel.html" title="class in org.apache.spark.ml.regression" target="classFrame">RegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/RegressionModel.html" title="interface in org.apache.spark.mllib.regression" target="classFrame"><span class="interfaceName">RegressionModel</span></a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql" target="classFrame">RelationalGroupedDataset</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.CubeType$.html" title="class in org.apache.spark.sql" target="classFrame">RelationalGroupedDataset.CubeType$</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.GroupByType$.html" title="class in org.apache.spark.sql" target="classFrame">RelationalGroupedDataset.GroupByType$</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.PivotType$.html" title="class in org.apache.spark.sql" target="classFrame">RelationalGroupedDataset.PivotType$</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.RollupType$.html" title="class in org.apache.spark.sql" target="classFrame">RelationalGroupedDataset.RollupType$</a></li>
+<li><a href="org/apache/spark/sql/hive/RelationConversions.html" title="class in org.apache.spark.sql.hive" target="classFrame">RelationConversions</a></li>
+<li><a href="org/apache/spark/sql/sources/RelationProvider.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">RelationProvider</span></a></li>
+<li><a href="org/apache/spark/sql/hive/ResolveHiveSerdeTable.html" title="class in org.apache.spark.sql.hive" target="classFrame">ResolveHiveSerdeTable</a></li>
+<li><a href="org/apache/spark/scheduler/ResubmitFailedStages.html" title="class in org.apache.spark.scheduler" target="classFrame">ResubmitFailedStages</a></li>
+<li><a href="org/apache/spark/Resubmitted.html" title="class in org.apache.spark" target="classFrame">Resubmitted</a></li>
+<li><a href="org/apache/spark/util/ReturnStatementFinder.html" title="class in org.apache.spark.util" target="classFrame">ReturnStatementFinder</a></li>
+<li><a href="org/apache/spark/scheduler/local/ReviveOffers.html" title="class in org.apache.spark.scheduler.local" target="classFrame">ReviveOffers</a></li>
+<li><a href="org/apache/spark/ml/feature/RFormula.html" title="class in org.apache.spark.ml.feature" target="classFrame">RFormula</a></li>
+<li><a href="org/apache/spark/ml/feature/RFormulaModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">RFormulaModel</a></li>
+<li><a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature" target="classFrame">RFormulaParser</a></li>
+<li><a href="org/apache/spark/mllib/regression/RidgeRegressionModel.html" title="class in org.apache.spark.mllib.regression" target="classFrame">RidgeRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/RidgeRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression" target="classFrame">RidgeRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/sql/Row.html" title="interface in org.apache.spark.sql" target="classFrame"><span class="interfaceName">Row</span></a></li>
+<li><a href="org/apache/spark/sql/RowFactory.html" title="class in org.apache.spark.sql" target="classFrame">RowFactory</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/RowMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed" target="classFrame">RowMatrix</a></li>
+<li><a href="org/apache/spark/util/RpcUtils.html" title="class in org.apache.spark.util" target="classFrame">RpcUtils</a></li>
+<li><a href="org/apache/spark/api/r/RRDD.html" title="class in org.apache.spark.api.r" target="classFrame">RRDD</a></li>
+<li><a href="org/apache/spark/api/r/RRunnerModes.html" title="class in org.apache.spark.api.r" target="classFrame">RRunnerModes</a></li>
+<li><a href="org/apache/spark/sql/RuntimeConfig.html" title="class in org.apache.spark.sql" target="classFrame">RuntimeConfig</a></li>
+<li><a href="org/apache/spark/status/api/v1/RuntimeInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">RuntimeInfo</a></li>
+<li><a href="org/apache/spark/scheduler/RuntimePercentage.html" title="class in org.apache.spark.scheduler" target="classFrame">RuntimePercentage</a></li>
+<li><a href="org/apache/spark/api/r/RUtils.html" title="class in org.apache.spark.api.r" target="classFrame">RUtils</a></li>
+<li><a href="org/apache/spark/ml/r/RWrappers.html" title="class in org.apache.spark.ml.r" target="classFrame">RWrappers</a></li>
+<li><a href="org/apache/spark/ml/r/RWrapperUtils.html" title="class in org.apache.spark.ml.r" target="classFrame">RWrapperUtils</a></li>
+<li><a href="org/apache/spark/ml/image/SamplePathFilter.html" title="class in org.apache.spark.ml.image" target="classFrame">SamplePathFilter</a></li>
+<li><a href="org/apache/spark/util/random/SamplingUtils.html" title="class in org.apache.spark.util.random" target="classFrame">SamplingUtils</a></li>
+<li><a href="org/apache/spark/mllib/util/Saveable.html" title="interface in org.apache.spark.mllib.util" target="classFrame"><span class="interfaceName">Saveable</span></a></li>
+<li><a href="org/apache/spark/sql/SaveMode.html" title="enum in org.apache.spark.sql" target="classFrame">SaveMode</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/SchedulerBackendUtils.html" title="class in org.apache.spark.scheduler.cluster" target="classFrame">SchedulerBackendUtils</a></li>
+<li><a href="org/apache/spark/status/SchedulerPool.html" title="class in org.apache.spark.status" target="classFrame">SchedulerPool</a></li>
+<li><a href="org/apache/spark/scheduler/SchedulingMode.html" title="class in org.apache.spark.scheduler" target="classFrame">SchedulingMode</a></li>
+<li><a href="org/apache/spark/sql/sources/SchemaRelationProvider.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">SchemaRelationProvider</span></a></li>
+<li><a href="org/apache/spark/ml/util/SchemaUtils.html" title="class in org.apache.spark.ml.util" target="classFrame">SchemaUtils</a></li>
+<li><a href="org/apache/spark/sql/util/SchemaUtils.html" title="class in org.apache.spark.sql.util" target="classFrame">SchemaUtils</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">ScriptTransformationExec</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/ScriptTransformationWriterThread.html" title="class in org.apache.spark.sql.hive.execution" target="classFrame">ScriptTransformationWriterThread</a></li>
+<li><a href="org/apache/spark/streaming/Seconds.html" title="class in org.apache.spark.streaming" target="classFrame">Seconds</a></li>
+<li><a href="org/apache/spark/rdd/SequenceFileRDDFunctions.html" title="class in org.apache.spark.rdd" target="classFrame">SequenceFileRDDFunctions</a></li>
+<li><a href="org/apache/spark/api/r/SerDe.html" title="class in org.apache.spark.api.r" target="classFrame">SerDe</a></li>
+<li><a href="org/apache/spark/SerializableWritable.html" title="class in org.apache.spark" target="classFrame">SerializableWritable</a></li>
+<li><a href="org/apache/spark/serializer/SerializationDebugger.html" title="class in org.apache.spark.serializer" target="classFrame">SerializationDebugger</a></li>
+<li><a href="org/apache/spark/serializer/SerializationDebugger.ObjectStreamClassMethods.html" title="class in org.apache.spark.serializer" target="classFrame">SerializationDebugger.ObjectStreamClassMethods</a></li>
+<li><a href="org/apache/spark/serializer/SerializationDebugger.ObjectStreamClassMethods$.html" title="class in org.apache.spark.serializer" target="classFrame">SerializationDebugger.ObjectStreamClassMethods$</a></li>
+<li><a href="org/apache/spark/api/r/SerializationFormats.html" title="class in org.apache.spark.api.r" target="classFrame">SerializationFormats</a></li>
+<li><a href="org/apache/spark/serializer/SerializationStream.html" title="class in org.apache.spark.serializer" target="classFrame">SerializationStream</a></li>
+<li><a href="org/apache/spark/storage/memory/SerializedMemoryEntry.html" title="class in org.apache.spark.storage.memory" target="classFrame">SerializedMemoryEntry</a></li>
+<li><a href="org/apache/spark/storage/memory/SerializedValuesHolder.html" title="class in org.apache.spark.storage.memory" target="classFrame">SerializedValuesHolder</a></li>
+<li><a href="org/apache/spark/serializer/Serializer.html" title="class in org.apache.spark.serializer" target="classFrame">Serializer</a></li>
+<li><a href="org/apache/spark/serializer/SerializerInstance.html" title="class in org.apache.spark.serializer" target="classFrame">SerializerInstance</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/SessionConfigSupport.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">SessionConfigSupport</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/SharedParamsCodeGen.html" title="class in org.apache.spark.ml.param.shared" target="classFrame">SharedParamsCodeGen</a></li>
+<li><a href="org/apache/spark/graphx/lib/ShortestPaths.html" title="class in org.apache.spark.graphx.lib" target="classFrame">ShortestPaths</a></li>
+<li><a href="org/apache/spark/sql/types/ShortType.html" title="class in org.apache.spark.sql.types" target="classFrame">ShortType</a></li>
+<li><a href="org/apache/spark/storage/ShuffleBlockId.html" title="class in org.apache.spark.storage" target="classFrame">ShuffleBlockId</a></li>
+<li><a href="org/apache/spark/storage/ShuffleDataBlockId.html" title="class in org.apache.spark.storage" target="classFrame">ShuffleDataBlockId</a></li>
+<li><a href="org/apache/spark/ShuffleDependency.html" title="class in org.apache.spark" target="classFrame">ShuffleDependency</a></li>
+<li><a href="org/apache/spark/rdd/ShuffledRDD.html" title="class in org.apache.spark.rdd" target="classFrame">ShuffledRDD</a></li>
+<li><a href="org/apache/spark/storage/ShuffleIndexBlockId.html" title="class in org.apache.spark.storage" target="classFrame">ShuffleIndexBlockId</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleReadMetricDistributions.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ShuffleReadMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleReadMetrics.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ShuffleReadMetrics</a></li>
+<li><a href="org/apache/spark/ShuffleStatus.html" title="class in org.apache.spark" target="classFrame">ShuffleStatus</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleWriteMetricDistributions.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ShuffleWriteMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleWriteMetrics.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ShuffleWriteMetrics</a></li>
+<li><a href="org/apache/spark/util/ShutdownHookManager.html" title="class in org.apache.spark.util" target="classFrame">ShutdownHookManager</a></li>
+<li><a href="org/apache/spark/util/SignalUtils.html" title="class in org.apache.spark.util" target="classFrame">SignalUtils</a></li>
+<li><a href="org/apache/spark/SimpleFutureAction.html" title="class in org.apache.spark" target="classFrame">SimpleFutureAction</a></li>
+<li><a href="org/apache/spark/mllib/optimization/SimpleUpdater.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">SimpleUpdater</a></li>
+<li><a href="org/apache/spark/mllib/linalg/SingularValueDecomposition.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">SingularValueDecomposition</a></li>
+<li><a href="org/apache/spark/sql/streaming/SinkProgress.html" title="class in org.apache.spark.sql.streaming" target="classFrame">SinkProgress</a></li>
+<li><a href="org/apache/spark/util/SizeEstimator.html" title="class in org.apache.spark.util" target="classFrame">SizeEstimator</a></li>
+<li><a href="org/apache/spark/io/SnappyCompressionCodec.html" title="class in org.apache.spark.io" target="classFrame">SnappyCompressionCodec</a></li>
+<li><a href="org/apache/spark/io/SnappyOutputStreamWrapper.html" title="class in org.apache.spark.io" target="classFrame">SnappyOutputStreamWrapper</a></li>
+<li><a href="org/apache/spark/sql/streaming/SourceProgress.html" title="class in org.apache.spark.sql.streaming" target="classFrame">SourceProgress</a></li>
+<li><a href="org/apache/spark/launcher/SparkAppHandle.html" title="interface in org.apache.spark.launcher" target="classFrame"><span class="interfaceName">SparkAppHandle</span></a></li>
+<li><a href="org/apache/spark/launcher/SparkAppHandle.Listener.html" title="interface in org.apache.spark.launcher" target="classFrame"><span class="interfaceName">SparkAppHandle.Listener</span></a></li>
+<li><a href="org/apache/spark/launcher/SparkAppHandle.State.html" title="enum in org.apache.spark.launcher" target="classFrame">SparkAppHandle.State</a></li>
+<li><a href="org/apache/spark/SparkConf.html" title="class in org.apache.spark" target="classFrame">SparkConf</a></li>
+<li><a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark" target="classFrame">SparkContext</a></li>
+<li><a href="org/apache/spark/SparkEnv.html" title="class in org.apache.spark" target="classFrame">SparkEnv</a></li>
+<li><a href="org/apache/spark/SparkException.html" title="class in org.apache.spark" target="classFrame">SparkException</a></li>
+<li><a href="org/apache/spark/SparkExecutorInfo.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">SparkExecutorInfo</span></a></li>
+<li><a href="org/apache/spark/SparkExecutorInfoImpl.html" title="class in org.apache.spark" target="classFrame">SparkExecutorInfoImpl</a></li>
+<li><a href="org/apache/spark/util/SparkExitCode.html" title="class in org.apache.spark.util" target="classFrame">SparkExitCode</a></li>
+<li><a href="org/apache/spark/SparkFiles.html" title="class in org.apache.spark" target="classFrame">SparkFiles</a></li>
+<li><a href="org/apache/spark/SparkFirehoseListener.html" title="class in org.apache.spark" target="classFrame">SparkFirehoseListener</a></li>
+<li><a href="org/apache/spark/mapred/SparkHadoopMapRedUtil.html" title="class in org.apache.spark.mapred" target="classFrame">SparkHadoopMapRedUtil</a></li>
+<li><a href="org/apache/spark/internal/io/SparkHadoopWriter.html" title="class in org.apache.spark.internal.io" target="classFrame">SparkHadoopWriter</a></li>
+<li><a href="org/apache/spark/internal/io/SparkHadoopWriterUtils.html" title="class in org.apache.spark.internal.io" target="classFrame">SparkHadoopWriterUtils</a></li>
+<li><a href="org/apache/spark/SparkJobInfo.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">SparkJobInfo</span></a></li>
+<li><a href="org/apache/spark/SparkJobInfoImpl.html" title="class in org.apache.spark" target="classFrame">SparkJobInfoImpl</a></li>
+<li><a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher" target="classFrame">SparkLauncher</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListener.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListener</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerApplicationEnd.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerApplicationEnd</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerApplicationStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerBlockManagerAdded.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerBlockManagerAdded</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerBlockManagerRemoved.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerBlockManagerRemoved</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerBlockUpdated.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerBlockUpdated</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerEnvironmentUpdate.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerEnvironmentUpdate</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerEvent.html" title="interface in org.apache.spark.scheduler" target="classFrame"><span class="interfaceName">SparkListenerEvent</span></a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorAdded.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerExecutorAdded</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorBlacklisted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerExecutorBlacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorBlacklistedForStage.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerExecutorBlacklistedForStage</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorMetricsUpdate.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerExecutorMetricsUpdate</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorRemoved.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerExecutorRemoved</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorUnblacklisted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerExecutorUnblacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerJobEnd.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerJobEnd</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerJobStart.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerJobStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerLogStart.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerLogStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerNodeBlacklisted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerNodeBlacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerNodeBlacklistedForStage.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerNodeBlacklistedForStage</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerNodeUnblacklisted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerNodeUnblacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerSpeculativeTaskSubmitted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerSpeculativeTaskSubmitted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerStageCompleted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerStageCompleted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerStageSubmitted.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerStageSubmitted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerTaskEnd.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerTaskEnd</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerTaskGettingResult.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerTaskGettingResult</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerTaskStart.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerTaskStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerUnpersistRDD.html" title="class in org.apache.spark.scheduler" target="classFrame">SparkListenerUnpersistRDD</a></li>
+<li><a href="org/apache/spark/SparkMasterRegex.html" title="class in org.apache.spark" target="classFrame">SparkMasterRegex</a></li>
+<li><a href="org/apache/spark/api/r/SparkRDefaults.html" title="class in org.apache.spark.api.r" target="classFrame">SparkRDefaults</a></li>
+<li><a href="org/apache/spark/sql/SparkSession.html" title="class in org.apache.spark.sql" target="classFrame">SparkSession</a></li>
+<li><a href="org/apache/spark/sql/SparkSession.Builder.html" title="class in org.apache.spark.sql" target="classFrame">SparkSession.Builder</a></li>
+<li><a href="org/apache/spark/sql/SparkSessionExtensions.html" title="class in org.apache.spark.sql" target="classFrame">SparkSessionExtensions</a></li>
+<li><a href="org/apache/spark/util/SparkShutdownHook.html" title="class in org.apache.spark.util" target="classFrame">SparkShutdownHook</a></li>
+<li><a href="org/apache/spark/SparkStageInfo.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">SparkStageInfo</span></a></li>
+<li><a href="org/apache/spark/SparkStageInfoImpl.html" title="class in org.apache.spark" target="classFrame">SparkStageInfoImpl</a></li>
+<li><a href="org/apache/spark/SparkStatusTracker.html" title="class in org.apache.spark" target="classFrame">SparkStatusTracker</a></li>
+<li><a href="org/apache/spark/sql/expressions/SparkUserDefinedFunction.html" title="class in org.apache.spark.sql.expressions" target="classFrame">SparkUserDefinedFunction</a></li>
+<li><a href="org/apache/spark/ml/linalg/SparseMatrix.html" title="class in org.apache.spark.ml.linalg" target="classFrame">SparseMatrix</a></li>
+<li><a href="org/apache/spark/mllib/linalg/SparseMatrix.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">SparseMatrix</a></li>
+<li><a href="org/apache/spark/ml/linalg/SparseVector.html" title="class in org.apache.spark.ml.linalg" target="classFrame">SparseVector</a></li>
+<li><a href="org/apache/spark/mllib/linalg/SparseVector.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">SparseVector</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/SpearmanCorrelation.html" title="class in org.apache.spark.mllib.stat.correlation" target="classFrame">SpearmanCorrelation</a></li>
+<li><a href="org/apache/spark/api/r/SpecialLengths.html" title="class in org.apache.spark.api.r" target="classFrame">SpecialLengths</a></li>
+<li><a href="org/apache/spark/SpillListener.html" title="class in org.apache.spark" target="classFrame">SpillListener</a></li>
+<li><a href="org/apache/spark/ml/tree/Split.html" title="interface in org.apache.spark.ml.tree" target="classFrame"><span class="interfaceName">Split</span></a></li>
+<li><a href="org/apache/spark/mllib/tree/model/Split.html" title="class in org.apache.spark.mllib.tree.model" target="classFrame">Split</a></li>
+<li><a href="org/apache/spark/scheduler/SplitInfo.html" title="class in org.apache.spark.scheduler" target="classFrame">SplitInfo</a></li>
+<li><a href="org/apache/spark/sql/SQLContext.html" title="class in org.apache.spark.sql" target="classFrame">SQLContext</a></li>
+<li><a href="org/apache/spark/ml/linalg/SQLDataTypes.html" title="class in org.apache.spark.ml.linalg" target="classFrame">SQLDataTypes</a></li>
+<li><a href="org/apache/spark/sql/SQLImplicits.html" title="class in org.apache.spark.sql" target="classFrame">SQLImplicits</a></li>
+<li><a href="org/apache/spark/ml/feature/SQLTransformer.html" title="class in org.apache.spark.ml.feature" target="classFrame">SQLTransformer</a></li>
+<li><a href="org/apache/spark/sql/types/SQLUserDefinedType.html" title="annotation in org.apache.spark.sql.types" target="classFrame">SQLUserDefinedType</a></li>
+<li><a href="org/apache/spark/sql/api/r/SQLUtils.html" title="class in org.apache.spark.sql.api.r" target="classFrame">SQLUtils</a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/SquaredError.html" title="class in org.apache.spark.mllib.tree.loss" target="classFrame">SquaredError</a></li>
+<li><a href="org/apache/spark/ml/evaluation/SquaredEuclideanSilhouette.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">SquaredEuclideanSilhouette</a></li>
+<li><a href="org/apache/spark/ml/evaluation/SquaredEuclideanSilhouette.ClusterStats.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">SquaredEuclideanSilhouette.ClusterStats</a></li>
+<li><a href="org/apache/spark/ml/evaluation/SquaredEuclideanSilhouette.ClusterStats$.html" title="class in org.apache.spark.ml.evaluation" target="classFrame">SquaredEuclideanSilhouette.ClusterStats$</a></li>
+<li><a href="org/apache/spark/mllib/optimization/SquaredL2Updater.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">SquaredL2Updater</a></li>
+<li><a href="org/apache/spark/status/api/v1/StackTrace.html" title="class in org.apache.spark.status.api.v1" target="classFrame">StackTrace</a></li>
+<li><a href="org/apache/spark/status/api/v1/StageData.html" title="class in org.apache.spark.status.api.v1" target="classFrame">StageData</a></li>
+<li><a href="org/apache/spark/scheduler/StageInfo.html" title="class in org.apache.spark.scheduler" target="classFrame">StageInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/StageStatus.html" title="enum in org.apache.spark.status.api.v1" target="classFrame">StageStatus</a></li>
+<li><a href="org/apache/spark/mllib/random/StandardNormalGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">StandardNormalGenerator</a></li>
+<li><a href="org/apache/spark/ml/feature/StandardScaler.html" title="class in org.apache.spark.ml.feature" target="classFrame">StandardScaler</a></li>
+<li><a href="org/apache/spark/mllib/feature/StandardScaler.html" title="class in org.apache.spark.mllib.feature" target="classFrame">StandardScaler</a></li>
+<li><a href="org/apache/spark/ml/feature/StandardScalerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">StandardScalerModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/StandardScalerModel.html" title="class in org.apache.spark.mllib.feature" target="classFrame">StandardScalerModel</a></li>
+<li><a href="org/apache/spark/util/StatCounter.html" title="class in org.apache.spark.util" target="classFrame">StatCounter</a></li>
+<li><a href="org/apache/spark/streaming/State.html" title="class in org.apache.spark.streaming" target="classFrame">State</a></li>
+<li><a href="org/apache/spark/sql/streaming/StateOperatorProgress.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StateOperatorProgress</a></li>
+<li><a href="org/apache/spark/streaming/StateSpec.html" title="class in org.apache.spark.streaming" target="classFrame">StateSpec</a></li>
+<li><a href="org/apache/spark/metrics/source/StaticSources.html" title="class in org.apache.spark.metrics.source" target="classFrame">StaticSources</a></li>
+<li><a href="org/apache/spark/mllib/stat/Statistics.html" title="class in org.apache.spark.mllib.stat" target="classFrame">Statistics</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/Statistics.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">Statistics</span></a></li>
+<li><a href="org/apache/spark/metrics/sink/StatsdMetricType.html" title="class in org.apache.spark.metrics.sink" target="classFrame">StatsdMetricType</a></li>
+<li><a href="org/apache/spark/scheduler/StatsReportListener.html" title="class in org.apache.spark.scheduler" target="classFrame">StatsReportListener</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StatsReportListener.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StatsReportListener</a></li>
+<li><a href="org/apache/spark/scheduler/local/StatusUpdate.html" title="class in org.apache.spark.scheduler.local" target="classFrame">StatusUpdate</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StopAllReceivers.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StopAllReceivers</a></li>
+<li><a href="org/apache/spark/scheduler/StopCoordinator.html" title="class in org.apache.spark.scheduler" target="classFrame">StopCoordinator</a></li>
+<li><a href="org/apache/spark/scheduler/local/StopExecutor.html" title="class in org.apache.spark.scheduler.local" target="classFrame">StopExecutor</a></li>
+<li><a href="org/apache/spark/StopMapOutputTracker.html" title="class in org.apache.spark" target="classFrame">StopMapOutputTracker</a></li>
+<li><a href="org/apache/spark/streaming/receiver/StopReceiver.html" title="class in org.apache.spark.streaming.receiver" target="classFrame">StopReceiver</a></li>
+<li><a href="org/apache/spark/ml/feature/StopWordsRemover.html" title="class in org.apache.spark.ml.feature" target="classFrame">StopWordsRemover</a></li>
+<li><a href="org/apache/spark/storage/StorageLevel.html" title="class in org.apache.spark.storage" target="classFrame">StorageLevel</a></li>
+<li><a href="org/apache/spark/api/java/StorageLevels.html" title="class in org.apache.spark.api.java" target="classFrame">StorageLevels</a></li>
+<li><a href="org/apache/spark/storage/StorageUtils.html" title="class in org.apache.spark.storage" target="classFrame">StorageUtils</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/Strategy.html" title="class in org.apache.spark.mllib.tree.configuration" target="classFrame">Strategy</a></li>
+<li><a href="org/apache/spark/util/random/StratifiedSamplingUtils.html" title="class in org.apache.spark.util.random" target="classFrame">StratifiedSamplingUtils</a></li>
+<li><a href="org/apache/spark/storage/StreamBlockId.html" title="class in org.apache.spark.storage" target="classFrame">StreamBlockId</a></li>
+<li><a href="org/apache/spark/streaming/StreamingContext.html" title="class in org.apache.spark.streaming" target="classFrame">StreamingContext</a></li>
+<li><a href="org/apache/spark/streaming/StreamingContextPythonHelper.html" title="class in org.apache.spark.streaming" target="classFrame">StreamingContextPythonHelper</a></li>
+<li><a href="org/apache/spark/streaming/StreamingContextState.html" title="enum in org.apache.spark.streaming" target="classFrame">StreamingContextState</a></li>
+<li><a href="org/apache/spark/mllib/clustering/StreamingKMeans.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">StreamingKMeans</a></li>
+<li><a href="org/apache/spark/mllib/clustering/StreamingKMeansModel.html" title="class in org.apache.spark.mllib.clustering" target="classFrame">StreamingKMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/StreamingLinearAlgorithm.html" title="class in org.apache.spark.mllib.regression" target="classFrame">StreamingLinearAlgorithm</a></li>
+<li><a href="org/apache/spark/mllib/regression/StreamingLinearRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression" target="classFrame">StreamingLinearRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListener.html" title="interface in org.apache.spark.streaming.scheduler" target="classFrame"><span class="interfaceName">StreamingListener</span></a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerBatchCompleted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerBatchCompleted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerBatchStarted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerBatchStarted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerBatchSubmitted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerBatchSubmitted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerEvent.html" title="interface in org.apache.spark.streaming.scheduler" target="classFrame"><span class="interfaceName">StreamingListenerEvent</span></a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerOutputOperationCompleted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerOutputOperationCompleted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerOutputOperationStarted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerOutputOperationStarted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerReceiverError.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerReceiverError</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerReceiverStarted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerReceiverStarted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerReceiverStopped.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerReceiverStopped</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerStreamingStarted.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamingListenerStreamingStarted</a></li>
+<li><a href="org/apache/spark/mllib/classification/StreamingLogisticRegressionWithSGD.html" title="class in org.apache.spark.mllib.classification" target="classFrame">StreamingLogisticRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQuery.html" title="interface in org.apache.spark.sql.streaming" target="classFrame"><span class="interfaceName">StreamingQuery</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryException.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryException</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryListener</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.Event.html" title="interface in org.apache.spark.sql.streaming" target="classFrame"><span class="interfaceName">StreamingQueryListener.Event</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.QueryProgressEvent.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryListener.QueryProgressEvent</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.QueryStartedEvent.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryListener.QueryStartedEvent</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.QueryTerminatedEvent.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryListener.QueryTerminatedEvent</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryManager.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryManager</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryProgress.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryProgress</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryStatus.html" title="class in org.apache.spark.sql.streaming" target="classFrame">StreamingQueryStatus</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/StreamingStatistics.html" title="class in org.apache.spark.status.api.v1.streaming" target="classFrame">StreamingStatistics</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/StreamingTest.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">StreamingTest</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamInputInfo.html" title="class in org.apache.spark.streaming.scheduler" target="classFrame">StreamInputInfo</a></li>
+<li><a href="org/apache/spark/sql/sources/StreamSinkProvider.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">StreamSinkProvider</span></a></li>
+<li><a href="org/apache/spark/sql/sources/StreamSourceProvider.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">StreamSourceProvider</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer.streaming" target="classFrame"><span class="interfaceName">StreamWriter</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/StreamWriteSupport.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">StreamWriteSupport</span></a></li>
+<li><a href="org/apache/spark/ml/param/StringArrayParam.html" title="class in org.apache.spark.ml.param" target="classFrame">StringArrayParam</a></li>
+<li><a href="org/apache/spark/sql/sources/StringContains.html" title="class in org.apache.spark.sql.sources" target="classFrame">StringContains</a></li>
+<li><a href="org/apache/spark/sql/sources/StringEndsWith.html" title="class in org.apache.spark.sql.sources" target="classFrame">StringEndsWith</a></li>
+<li><a href="org/apache/spark/ml/feature/StringIndexer.html" title="class in org.apache.spark.ml.feature" target="classFrame">StringIndexer</a></li>
+<li><a href="org/apache/spark/ml/feature/StringIndexerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">StringIndexerModel</a></li>
+<li><a href="org/apache/spark/api/r/StringRRDD.html" title="class in org.apache.spark.api.r" target="classFrame">StringRRDD</a></li>
+<li><a href="org/apache/spark/sql/sources/StringStartsWith.html" title="class in org.apache.spark.sql.sources" target="classFrame">StringStartsWith</a></li>
+<li><a href="org/apache/spark/sql/types/StringType.html" title="class in org.apache.spark.sql.types" target="classFrame">StringType</a></li>
+<li><a href="org/apache/spark/graphx/lib/StronglyConnectedComponents.html" title="class in org.apache.spark.graphx.lib" target="classFrame">StronglyConnectedComponents</a></li>
+<li><a href="org/apache/spark/sql/types/StructField.html" title="class in org.apache.spark.sql.types" target="classFrame">StructField</a></li>
+<li><a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types" target="classFrame">StructType</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/StudentTTest.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">StudentTTest</a></li>
+<li><a href="org/apache/spark/Success.html" title="class in org.apache.spark" target="classFrame">Success</a></li>
+<li><a href="org/apache/spark/ml/stat/Summarizer.html" title="class in org.apache.spark.ml.stat" target="classFrame">Summarizer</a></li>
+<li><a href="org/apache/spark/ml/stat/SummaryBuilder.html" title="class in org.apache.spark.ml.stat" target="classFrame">SummaryBuilder</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsPushDownFilters.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">SupportsPushDownFilters</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsPushDownRequiredColumns.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">SupportsPushDownRequiredColumns</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsReportPartitioning.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">SupportsReportPartitioning</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsReportStatistics.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">SupportsReportStatistics</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsScanColumnarBatch.html" title="interface in org.apache.spark.sql.sources.v2.reader" target="classFrame"><span class="interfaceName">SupportsScanColumnarBatch</span></a></li>
+<li><a href="org/apache/spark/graphx/lib/SVDPlusPlus.html" title="class in org.apache.spark.graphx.lib" target="classFrame">SVDPlusPlus</a></li>
+<li><a href="org/apache/spark/graphx/lib/SVDPlusPlus.Conf.html" title="class in org.apache.spark.graphx.lib" target="classFrame">SVDPlusPlus.Conf</a></li>
+<li><a href="org/apache/spark/mllib/util/SVMDataGenerator.html" title="class in org.apache.spark.mllib.util" target="classFrame">SVMDataGenerator</a></li>
+<li><a href="org/apache/spark/mllib/classification/SVMModel.html" title="class in org.apache.spark.mllib.classification" target="classFrame">SVMModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/SVMWithSGD.html" title="class in org.apache.spark.mllib.classification" target="classFrame">SVMWithSGD</a></li>
+<li><a href="org/apache/spark/sql/catalog/Table.html" title="class in org.apache.spark.sql.catalog" target="classFrame">Table</a></li>
+<li><a href="org/apache/spark/sql/sources/TableScan.html" title="interface in org.apache.spark.sql.sources" target="classFrame"><span class="interfaceName">TableScan</span></a></li>
+<li><a href="org/apache/spark/TaskCommitDenied.html" title="class in org.apache.spark" target="classFrame">TaskCommitDenied</a></li>
+<li><a href="org/apache/spark/util/TaskCompletionListener.html" title="interface in org.apache.spark.util" target="classFrame"><span class="interfaceName">TaskCompletionListener</span></a></li>
+<li><a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark" target="classFrame">TaskContext</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskData.html" title="class in org.apache.spark.status.api.v1" target="classFrame">TaskData</a></li>
+<li><a href="org/apache/spark/ui/jobs/TaskDetailsClassNames.html" title="class in org.apache.spark.ui.jobs" target="classFrame">TaskDetailsClassNames</a></li>
+<li><a href="org/apache/spark/TaskEndReason.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">TaskEndReason</span></a></li>
+<li><a href="org/apache/spark/TaskFailedReason.html" title="interface in org.apache.spark" target="classFrame"><span class="interfaceName">TaskFailedReason</span></a></li>
+<li><a href="org/apache/spark/util/TaskFailureListener.html" title="interface in org.apache.spark.util" target="classFrame"><span class="interfaceName">TaskFailureListener</span></a></li>
+<li><a href="org/apache/spark/status/TaskIndexNames.html" title="class in org.apache.spark.status" target="classFrame">TaskIndexNames</a></li>
+<li><a href="org/apache/spark/scheduler/TaskInfo.html" title="class in org.apache.spark.scheduler" target="classFrame">TaskInfo</a></li>
+<li><a href="org/apache/spark/TaskKilled.html" title="class in org.apache.spark" target="classFrame">TaskKilled</a></li>
+<li><a href="org/apache/spark/TaskKilledException.html" title="class in org.apache.spark" target="classFrame">TaskKilledException</a></li>
+<li><a href="org/apache/spark/scheduler/TaskLocality.html" title="class in org.apache.spark.scheduler" target="classFrame">TaskLocality</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskMetricDistributions.html" title="class in org.apache.spark.status.api.v1" target="classFrame">TaskMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskMetrics.html" title="class in org.apache.spark.status.api.v1" target="classFrame">TaskMetrics</a></li>
+<li><a href="org/apache/spark/storage/TaskResultBlockId.html" title="class in org.apache.spark.storage" target="classFrame">TaskResultBlockId</a></li>
+<li><a href="org/apache/spark/TaskResultLost.html" title="class in org.apache.spark" target="classFrame">TaskResultLost</a></li>
+<li><a href="org/apache/spark/TaskSchedulerIsSet.html" title="class in org.apache.spark" target="classFrame">TaskSchedulerIsSet</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskSorting.html" title="enum in org.apache.spark.status.api.v1" target="classFrame">TaskSorting</a></li>
+<li><a href="org/apache/spark/TaskState.html" title="class in org.apache.spark" target="classFrame">TaskState</a></li>
+<li><a href="org/apache/spark/sql/jdbc/TeradataDialect.html" title="class in org.apache.spark.sql.jdbc" target="classFrame">TeradataDialect</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/TestResult.html" title="interface in org.apache.spark.mllib.stat.test" target="classFrame"><span class="interfaceName">TestResult</span></a></li>
+<li><a href="org/apache/spark/TestUtils.html" title="class in org.apache.spark" target="classFrame">TestUtils</a></li>
+<li><a href="org/apache/spark/status/api/v1/ThreadStackTrace.html" title="class in org.apache.spark.status.api.v1" target="classFrame">ThreadStackTrace</a></li>
+<li><a href="org/apache/spark/util/ThreadUtils.html" title="class in org.apache.spark.util" target="classFrame">ThreadUtils</a></li>
+<li><a href="org/apache/spark/streaming/Time.html" title="class in org.apache.spark.streaming" target="classFrame">Time</a></li>
+<li><a href="org/apache/spark/sql/types/TimestampType.html" title="class in org.apache.spark.sql.types" target="classFrame">TimestampType</a></li>
+<li><a href="org/apache/spark/storage/TimeTrackingOutputStream.html" title="class in org.apache.spark.storage" target="classFrame">TimeTrackingOutputStream</a></li>
+<li><a href="org/apache/spark/ml/feature/Tokenizer.html" title="class in org.apache.spark.ml.feature" target="classFrame">Tokenizer</a></li>
+<li><a href="org/apache/spark/ui/ToolTips.html" title="class in org.apache.spark.ui" target="classFrame">ToolTips</a></li>
+<li><a href="org/apache/spark/storage/TopologyMapper.html" title="class in org.apache.spark.storage" target="classFrame">TopologyMapper</a></li>
+<li><a href="org/apache/spark/ml/tuning/TrainValidationSplit.html" title="class in org.apache.spark.ml.tuning" target="classFrame">TrainValidationSplit</a></li>
+<li><a href="org/apache/spark/ml/tuning/TrainValidationSplitModel.html" title="class in org.apache.spark.ml.tuning" target="classFrame">TrainValidationSplitModel</a></li>
+<li><a href="org/apache/spark/ml/tuning/TrainValidationSplitModel.TrainValidationSplitModelWriter.html" title="class in org.apache.spark.ml.tuning" target="classFrame">TrainValidationSplitModel.TrainValidationSplitModelWriter</a></li>
+<li><a href="org/apache/spark/ml/Transformer.html" title="class in org.apache.spark.ml" target="classFrame">Transformer</a></li>
+<li><a href="org/apache/spark/graphx/lib/TriangleCount.html" title="class in org.apache.spark.graphx.lib" target="classFrame">TriangleCount</a></li>
+<li><a href="org/apache/spark/sql/streaming/Trigger.html" title="class in org.apache.spark.sql.streaming" target="classFrame">Trigger</a></li>
+<li><a href="org/apache/spark/graphx/TripletFields.html" title="class in org.apache.spark.graphx" target="classFrame">TripletFields</a></li>
+<li><a href="org/apache/spark/sql/expressions/javalang/typed.html" title="class in org.apache.spark.sql.expressions.javalang" target="classFrame">typed</a></li>
+<li><a href="org/apache/spark/sql/expressions/scalalang/typed.html" title="class in org.apache.spark.sql.expressions.scalalang" target="classFrame">typed</a></li>
+<li><a href="org/apache/spark/sql/TypedColumn.html" title="class in org.apache.spark.sql" target="classFrame">TypedColumn</a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF0.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF0</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF1.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF1</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF10.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF10</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF11.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF11</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF12.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF12</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF13.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF13</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF14.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF14</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF15.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF15</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF16.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF16</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF17.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF17</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF18.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF18</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF19.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF19</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF2.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF2</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF20.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF20</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF21.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF21</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF22.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF22</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF3.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF3</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF4.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF4</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF5.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF5</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF6.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF6</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF7.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF7</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF8.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF8</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF9.html" title="interface in org.apache.spark.sql.api.java" target="classFrame"><span class="interfaceName">UDF9</span></a></li>
+<li><a href="org/apache/spark/sql/UDFRegistration.html" title="class in org.apache.spark.sql" target="classFrame">UDFRegistration</a></li>
+<li><a href="org/apache/spark/sql/types/UDTRegistration.html" title="class in org.apache.spark.sql.types" target="classFrame">UDTRegistration</a></li>
+<li><a href="org/apache/spark/status/api/v1/UIRootFromServletContext.html" title="class in org.apache.spark.status.api.v1" target="classFrame">UIRootFromServletContext</a></li>
+<li><a href="org/apache/spark/streaming/ui/UIUtils.html" title="class in org.apache.spark.streaming.ui" target="classFrame">UIUtils</a></li>
+<li><a href="org/apache/spark/ui/UIUtils.html" title="class in org.apache.spark.ui" target="classFrame">UIUtils</a></li>
+<li><a href="org/apache/spark/ui/UIWorkloadGenerator.html" title="class in org.apache.spark.ui" target="classFrame">UIWorkloadGenerator</a></li>
+<li><a href="org/apache/spark/ml/UnaryTransformer.html" title="class in org.apache.spark.ml" target="classFrame">UnaryTransformer</a></li>
+<li><a href="org/apache/spark/mllib/random/UniformGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">UniformGenerator</a></li>
+<li><a href="org/apache/spark/rdd/UnionRDD.html" title="class in org.apache.spark.rdd" target="classFrame">UnionRDD</a></li>
+<li><a href="org/apache/spark/UnknownReason.html" title="class in org.apache.spark" target="classFrame">UnknownReason</a></li>
+<li><a href="org/apache/spark/storage/UnrecognizedBlockId.html" title="class in org.apache.spark.storage" target="classFrame">UnrecognizedBlockId</a></li>
+<li><a href="org/apache/spark/ml/attribute/UnresolvedAttribute.html" title="class in org.apache.spark.ml.attribute" target="classFrame">UnresolvedAttribute</a></li>
+<li><a href="org/apache/spark/mllib/optimization/Updater.html" title="class in org.apache.spark.mllib.optimization" target="classFrame">Updater</a></li>
+<li><a href="org/apache/spark/sql/expressions/UserDefinedAggregateFunction.html" title="class in org.apache.spark.sql.expressions" target="classFrame">UserDefinedAggregateFunction</a></li>
+<li><a href="org/apache/spark/sql/expressions/UserDefinedFunction.html" title="class in org.apache.spark.sql.expressions" target="classFrame">UserDefinedFunction</a></li>
+<li><a href="org/apache/spark/ml/impl/Utils.html" title="class in org.apache.spark.ml.impl" target="classFrame">Utils</a></li>
+<li><a href="org/apache/spark/util/Utils.html" title="class in org.apache.spark.util" target="classFrame">Utils</a></li>
+<li><a href="org/apache/spark/storage/memory/ValuesHolder.html" title="interface in org.apache.spark.storage.memory" target="classFrame"><span class="interfaceName">ValuesHolder</span></a></li>
+<li><a href="org/apache/spark/sql/types/VarcharType.html" title="class in org.apache.spark.sql.types" target="classFrame">VarcharType</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Variance.html" title="class in org.apache.spark.mllib.tree.impurity" target="classFrame">Variance</a></li>
+<li><a href="org/apache/spark/ml/linalg/Vector.html" title="interface in org.apache.spark.ml.linalg" target="classFrame"><span class="interfaceName">Vector</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/Vector.html" title="interface in org.apache.spark.mllib.linalg" target="classFrame"><span class="interfaceName">Vector</span></a></li>
+<li><a href="org/apache/spark/ml/feature/VectorAssembler.html" title="class in org.apache.spark.ml.feature" target="classFrame">VectorAssembler</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorAttributeRewriter.html" title="class in org.apache.spark.ml.feature" target="classFrame">VectorAttributeRewriter</a></li>
+<li><a href="org/apache/spark/mllib/linalg/VectorImplicits.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">VectorImplicits</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorIndexer.html" title="class in org.apache.spark.ml.feature" target="classFrame">VectorIndexer</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorIndexerModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">VectorIndexerModel</a></li>
+<li><a href="org/apache/spark/ml/linalg/Vectors.html" title="class in org.apache.spark.ml.linalg" target="classFrame">Vectors</a></li>
+<li><a href="org/apache/spark/mllib/linalg/Vectors.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">Vectors</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorSizeHint.html" title="class in org.apache.spark.ml.feature" target="classFrame">VectorSizeHint</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorSlicer.html" title="class in org.apache.spark.ml.feature" target="classFrame">VectorSlicer</a></li>
+<li><a href="org/apache/spark/mllib/feature/VectorTransformer.html" title="interface in org.apache.spark.mllib.feature" target="classFrame"><span class="interfaceName">VectorTransformer</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/VectorUDT.html" title="class in org.apache.spark.mllib.linalg" target="classFrame">VectorUDT</a></li>
+<li><a href="org/apache/spark/status/api/v1/VersionInfo.html" title="class in org.apache.spark.status.api.v1" target="classFrame">VersionInfo</a></li>
+<li><a href="org/apache/spark/util/VersionUtils.html" title="class in org.apache.spark.util" target="classFrame">VersionUtils</a></li>
+<li><a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx" target="classFrame">VertexRDD</a></li>
+<li><a href="org/apache/spark/graphx/impl/VertexRDDImpl.html" title="class in org.apache.spark.graphx.impl" target="classFrame">VertexRDDImpl</a></li>
+<li><a href="org/apache/spark/mllib/feature/VocabWord.html" title="class in org.apache.spark.mllib.feature" target="classFrame">VocabWord</a></li>
+<li><a href="org/apache/spark/api/java/function/VoidFunction.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">VoidFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/VoidFunction2.html" title="interface in org.apache.spark.api.java.function" target="classFrame"><span class="interfaceName">VoidFunction2</span></a></li>
+<li><a href="org/apache/spark/mllib/random/WeibullGenerator.html" title="class in org.apache.spark.mllib.random" target="classFrame">WeibullGenerator</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/WelchTTest.html" title="class in org.apache.spark.mllib.stat.test" target="classFrame">WelchTTest</a></li>
+<li><a href="org/apache/spark/sql/expressions/Window.html" title="class in org.apache.spark.sql.expressions" target="classFrame">Window</a></li>
+<li><a href="org/apache/spark/sql/expressions/WindowSpec.html" title="class in org.apache.spark.sql.expressions" target="classFrame">WindowSpec</a></li>
+<li><a href="org/apache/spark/ml/feature/Word2Vec.html" title="class in org.apache.spark.ml.feature" target="classFrame">Word2Vec</a></li>
+<li><a href="org/apache/spark/mllib/feature/Word2Vec.html" title="class in org.apache.spark.mllib.feature" target="classFrame">Word2Vec</a></li>
+<li><a href="org/apache/spark/ml/feature/Word2VecModel.html" title="class in org.apache.spark.ml.feature" target="classFrame">Word2VecModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/Word2VecModel.html" title="class in org.apache.spark.mllib.feature" target="classFrame">Word2VecModel</a></li>
+<li><a href="org/apache/spark/ml/feature/Word2VecModel.Word2VecModelWriter$.html" title="class in org.apache.spark.ml.feature" target="classFrame">Word2VecModel.Word2VecModelWriter$</a></li>
+<li><a href="org/apache/spark/streaming/util/WriteAheadLog.html" title="class in org.apache.spark.streaming.util" target="classFrame">WriteAheadLog</a></li>
+<li><a href="org/apache/spark/streaming/util/WriteAheadLogRecordHandle.html" title="class in org.apache.spark.streaming.util" target="classFrame">WriteAheadLogRecordHandle</a></li>
+<li><a href="org/apache/spark/streaming/util/WriteAheadLogUtils.html" title="class in org.apache.spark.streaming.util" target="classFrame">WriteAheadLogUtils</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/WriterCommitMessage.html" title="interface in org.apache.spark.sql.sources.v2.writer" target="classFrame"><span class="interfaceName">WriterCommitMessage</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/WriteSupport.html" title="interface in org.apache.spark.sql.sources.v2" target="classFrame"><span class="interfaceName">WriteSupport</span></a></li>
+<li><a href="org/apache/spark/io/ZStdCompressionCodec.html" title="class in org.apache.spark.io" target="classFrame">ZStdCompressionCodec</a></li>
+</ul>
+</div>
+<script defer="defer" type="text/javascript" src="lib/jquery.js"></script><script defer="defer" type="text/javascript" src="lib/api-javadocs.js"></script></body>
+</html>
diff --git a/site/docs/2.4.3/api/java/allclasses-noframe.html b/site/docs/2.4.3/api/java/allclasses-noframe.html
new file mode 100644
index 0000000..d4cca49
--- /dev/null
+++ b/site/docs/2.4.3/api/java/allclasses-noframe.html
@@ -0,0 +1,1322 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (1.8.0_121) on Tue May 07 14:11:42 PDT 2019 -->
+<title>All Classes (Spark 2.4.3 JavaDoc)</title>
+<meta name="date" content="2019-05-07">
+<link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
+<script type="text/javascript" src="script.js"></script>
+</head>
+<body>
+<h1 class="bar">All&nbsp;Classes</h1>
+<div class="indexContainer">
+<ul>
+<li><a href="org/apache/spark/mllib/tree/loss/AbsoluteError.html" title="class in org.apache.spark.mllib.tree.loss">AbsoluteError</a></li>
+<li><a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></li>
+<li><a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark">Accumulable</a></li>
+<li><a href="org/apache/spark/scheduler/AccumulableInfo.html" title="class in org.apache.spark.scheduler">AccumulableInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/AccumulableInfo.html" title="class in org.apache.spark.status.api.v1">AccumulableInfo</a></li>
+<li><a href="org/apache/spark/AccumulableParam.html" title="interface in org.apache.spark"><span class="interfaceName">AccumulableParam</span></a></li>
+<li><a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark">Accumulator</a></li>
+<li><a href="org/apache/spark/util/AccumulatorContext.html" title="class in org.apache.spark.util">AccumulatorContext</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.html" title="interface in org.apache.spark"><span class="interfaceName">AccumulatorParam</span></a></li>
+<li><a href="org/apache/spark/AccumulatorParam.DoubleAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.DoubleAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.FloatAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.FloatAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.IntAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.IntAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.LongAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.LongAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/AccumulatorParam.StringAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.StringAccumulatorParam$</a></li>
+<li><a href="org/apache/spark/util/AccumulatorV2.html" title="class in org.apache.spark.util">AccumulatorV2</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTAggregator.html" title="class in org.apache.spark.ml.regression">AFTAggregator</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTCostFun.html" title="class in org.apache.spark.ml.regression">AFTCostFun</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression">AFTSurvivalRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/AFTSurvivalRegressionModel.html" title="class in org.apache.spark.ml.regression">AFTSurvivalRegressionModel</a></li>
+<li><a href="org/apache/spark/sql/jdbc/AggregatedDialect.html" title="class in org.apache.spark.sql.jdbc">AggregatedDialect</a></li>
+<li><a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html" title="class in org.apache.spark.graphx.impl">AggregatingEdgeContext</a></li>
+<li><a href="org/apache/spark/Aggregator.html" title="class in org.apache.spark">Aggregator</a></li>
+<li><a href="org/apache/spark/sql/expressions/Aggregator.html" title="class in org.apache.spark.sql.expressions">Aggregator</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/Algo.html" title="class in org.apache.spark.mllib.tree.configuration">Algo</a></li>
+<li><a href="org/apache/spark/scheduler/AllJobsCancelled.html" title="class in org.apache.spark.scheduler">AllJobsCancelled</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/AllReceiverIds.html" title="class in org.apache.spark.streaming.scheduler">AllReceiverIds</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.html" title="class in org.apache.spark.ml.recommendation">ALS</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/ALS.html" title="class in org.apache.spark.mllib.recommendation">ALS</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.InBlock$.html" title="class in org.apache.spark.ml.recommendation">ALS.InBlock$</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.Rating.html" title="class in org.apache.spark.ml.recommendation">ALS.Rating</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.Rating$.html" title="class in org.apache.spark.ml.recommendation">ALS.Rating$</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALS.RatingBlock$.html" title="class in org.apache.spark.ml.recommendation">ALS.RatingBlock$</a></li>
+<li><a href="org/apache/spark/ml/recommendation/ALSModel.html" title="class in org.apache.spark.ml.recommendation">ALSModel</a></li>
+<li><a href="org/apache/spark/sql/AnalysisException.html" title="class in org.apache.spark.sql">AnalysisException</a></li>
+<li><a href="org/apache/spark/sql/sources/And.html" title="class in org.apache.spark.sql.sources">And</a></li>
+<li><a href="org/apache/spark/sql/types/AnyDataType.html" title="class in org.apache.spark.sql.types">AnyDataType</a></li>
+<li><a href="org/apache/spark/ui/jobs/ApiHelper.html" title="class in org.apache.spark.ui.jobs">ApiHelper</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html" title="class in org.apache.spark.status.api.v1">ApplicationAttemptInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationEnvironmentInfo.html" title="class in org.apache.spark.status.api.v1">ApplicationEnvironmentInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationInfo.html" title="class in org.apache.spark.status.api.v1">ApplicationInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/ApplicationStatus.html" title="enum in org.apache.spark.status.api.v1">ApplicationStatus</a></li>
+<li><a href="org/apache/spark/ml/ann/ApplyInPlace.html" title="class in org.apache.spark.ml.ann">ApplyInPlace</a></li>
+<li><a href="org/apache/spark/status/AppStatusUtils.html" title="class in org.apache.spark.status">AppStatusUtils</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/AreaUnderCurve.html" title="class in org.apache.spark.mllib.evaluation">AreaUnderCurve</a></li>
+<li><a href="org/apache/spark/sql/types/ArrayType.html" title="class in org.apache.spark.sql.types">ArrayType</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ArrowColumnVector.html" title="class in org.apache.spark.sql.vectorized">ArrowColumnVector</a></li>
+<li><a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html" title="class in org.apache.spark.scheduler">AskPermissionToCommitOutput</a></li>
+<li><a href="org/apache/spark/ml/fpm/AssociationRules.html" title="class in org.apache.spark.ml.fpm">AssociationRules</a></li>
+<li><a href="org/apache/spark/mllib/fpm/AssociationRules.html" title="class in org.apache.spark.mllib.fpm">AssociationRules</a></li>
+<li><a href="org/apache/spark/mllib/fpm/AssociationRules.Rule.html" title="class in org.apache.spark.mllib.fpm">AssociationRules.Rule</a></li>
+<li><a href="org/apache/spark/scheduler/AsyncEventQueue.html" title="class in org.apache.spark.scheduler">AsyncEventQueue</a></li>
+<li><a href="org/apache/spark/rdd/AsyncRDDActions.html" title="class in org.apache.spark.rdd">AsyncRDDActions</a></li>
+<li><a href="org/apache/spark/ml/attribute/Attribute.html" title="class in org.apache.spark.ml.attribute">Attribute</a></li>
+<li><a href="org/apache/spark/ml/attribute/AttributeGroup.html" title="class in org.apache.spark.ml.attribute">AttributeGroup</a></li>
+<li><a href="org/apache/spark/ml/attribute/AttributeKeys.html" title="class in org.apache.spark.ml.attribute">AttributeKeys</a></li>
+<li><a href="org/apache/spark/ml/attribute/AttributeType.html" title="class in org.apache.spark.ml.attribute">AttributeType</a></li>
+<li><a href="org/apache/spark/BarrierTaskContext.html" title="class in org.apache.spark">BarrierTaskContext</a></li>
+<li><a href="org/apache/spark/BarrierTaskInfo.html" title="class in org.apache.spark">BarrierTaskInfo</a></li>
+<li><a href="org/apache/spark/sql/sources/BaseRelation.html" title="class in org.apache.spark.sql.sources">BaseRelation</a></li>
+<li><a href="org/apache/spark/api/r/BaseRRDD.html" title="class in org.apache.spark.api.r">BaseRRDD</a></li>
+<li><a href="org/apache/spark/storage/BasicBlockReplicationPolicy.html" title="class in org.apache.spark.storage">BasicBlockReplicationPolicy</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/BatchInfo.html" title="class in org.apache.spark.status.api.v1.streaming">BatchInfo</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/BatchInfo.html" title="class in org.apache.spark.streaming.scheduler">BatchInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/BatchStatus.html" title="enum in org.apache.spark.status.api.v1.streaming">BatchStatus</a></li>
+<li><a href="org/apache/spark/util/random/BernoulliCellSampler.html" title="class in org.apache.spark.util.random">BernoulliCellSampler</a></li>
+<li><a href="org/apache/spark/util/random/BernoulliSampler.html" title="class in org.apache.spark.util.random">BernoulliSampler</a></li>
+<li><a href="org/apache/spark/ml/feature/Binarizer.html" title="class in org.apache.spark.ml.feature">Binarizer</a></li>
+<li><a href="org/apache/spark/ml/attribute/BinaryAttribute.html" title="class in org.apache.spark.ml.attribute">BinaryAttribute</a></li>
+<li><a href="org/apache/spark/ml/evaluation/BinaryClassificationEvaluator.html" title="class in org.apache.spark.ml.evaluation">BinaryClassificationEvaluator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/BinaryClassificationMetrics.html" title="class in org.apache.spark.mllib.evaluation">BinaryClassificationMetrics</a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification"><span class="interfaceName">BinaryLogisticRegressionSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionSummaryImpl.html" title="class in org.apache.spark.ml.classification">BinaryLogisticRegressionSummaryImpl</a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionTrainingSummary.html" title="interface in org.apache.spark.ml.classification"><span class="interfaceName">BinaryLogisticRegressionTrainingSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionTrainingSummaryImpl.html" title="class in org.apache.spark.ml.classification">BinaryLogisticRegressionTrainingSummaryImpl</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/BinarySample.html" title="class in org.apache.spark.mllib.stat.test">BinarySample</a></li>
+<li><a href="org/apache/spark/sql/types/BinaryType.html" title="class in org.apache.spark.sql.types">BinaryType</a></li>
+<li><a href="org/apache/spark/util/random/BinomialBounds.html" title="class in org.apache.spark.util.random">BinomialBounds</a></li>
+<li><a href="org/apache/spark/ml/clustering/BisectingKMeans.html" title="class in org.apache.spark.ml.clustering">BisectingKMeans</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeans.html" title="class in org.apache.spark.mllib.clustering">BisectingKMeans</a></li>
+<li><a href="org/apache/spark/ml/clustering/BisectingKMeansModel.html" title="class in org.apache.spark.ml.clustering">BisectingKMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeansModel.html" title="class in org.apache.spark.mllib.clustering">BisectingKMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeansModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.clustering">BisectingKMeansModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/clustering/BisectingKMeansModel.SaveLoadV2_0$.html" title="class in org.apache.spark.mllib.clustering">BisectingKMeansModel.SaveLoadV2_0$</a></li>
+<li><a href="org/apache/spark/ml/clustering/BisectingKMeansSummary.html" title="class in org.apache.spark.ml.clustering">BisectingKMeansSummary</a></li>
+<li><a href="org/apache/spark/scheduler/BlacklistedExecutor.html" title="class in org.apache.spark.scheduler">BlacklistedExecutor</a></li>
+<li><a href="org/apache/spark/ml/linalg/BLAS.html" title="class in org.apache.spark.ml.linalg">BLAS</a></li>
+<li><a href="org/apache/spark/mllib/linalg/BLAS.html" title="class in org.apache.spark.mllib.linalg">BLAS</a></li>
+<li><a href="org/apache/spark/storage/BlockId.html" title="class in org.apache.spark.storage">BlockId</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerId.html" title="class in org.apache.spark.storage">BlockManagerId</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.html" title="class in org.apache.spark.storage">BlockManagerMessages</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockLocationsAndStatus.html" title="class in org.apache.spark.storage">BlockManagerMessages.BlockLocationsAndStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockLocationsAndStatus$.html" title="class in org.apache.spark.storage">BlockManagerMessages.BlockLocationsAndStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockManagerHeartbeat.html" title="class in org.apache.spark.storage">BlockManagerMessages.BlockManagerHeartbeat</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.BlockManagerHeartbeat$.html" title="class in org.apache.spark.storage">BlockManagerMessages.BlockManagerHeartbeat$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetBlockStatus.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetBlockStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetBlockStatus$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetBlockStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetExecutorEndpointRef.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetExecutorEndpointRef</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetExecutorEndpointRef$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetExecutorEndpointRef$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocations.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetLocations</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocations$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetLocations$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsAndStatus.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetLocationsAndStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsAndStatus$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetLocationsAndStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsMultipleBlockIds.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetLocationsMultipleBlockIds</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetLocationsMultipleBlockIds$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetLocationsMultipleBlockIds$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetMatchingBlockIds.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetMatchingBlockIds</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetMatchingBlockIds$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetMatchingBlockIds$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetMemoryStatus$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetMemoryStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetPeers.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetPeers</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetPeers$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetPeers$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.GetStorageStatus$.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetStorageStatus$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.HasCachedBlocks.html" title="class in org.apache.spark.storage">BlockManagerMessages.HasCachedBlocks</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.HasCachedBlocks$.html" title="class in org.apache.spark.storage">BlockManagerMessages.HasCachedBlocks$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RegisterBlockManager.html" title="class in org.apache.spark.storage">BlockManagerMessages.RegisterBlockManager</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RegisterBlockManager$.html" title="class in org.apache.spark.storage">BlockManagerMessages.RegisterBlockManager$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBlock.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveBlock</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBlock$.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveBlock$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBroadcast.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveBroadcast</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveBroadcast$.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveBroadcast$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveExecutor.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveExecutor</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveExecutor$.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveExecutor$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveRdd.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveRdd</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveRdd$.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveRdd$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveShuffle.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveShuffle</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.RemoveShuffle$.html" title="class in org.apache.spark.storage">BlockManagerMessages.RemoveShuffle$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ReplicateBlock.html" title="class in org.apache.spark.storage">BlockManagerMessages.ReplicateBlock</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ReplicateBlock$.html" title="class in org.apache.spark.storage">BlockManagerMessages.ReplicateBlock$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.StopBlockManagerMaster$.html" title="class in org.apache.spark.storage">BlockManagerMessages.StopBlockManagerMaster$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ToBlockManagerMaster.html" title="interface in org.apache.spark.storage"><span class="interfaceName">BlockManagerMessages.ToBlockManagerMaster</span></a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.ToBlockManagerSlave.html" title="interface in org.apache.spark.storage"><span class="interfaceName">BlockManagerMessages.ToBlockManagerSlave</span></a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.TriggerThreadDump$.html" title="class in org.apache.spark.storage">BlockManagerMessages.TriggerThreadDump$</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.UpdateBlockInfo.html" title="class in org.apache.spark.storage">BlockManagerMessages.UpdateBlockInfo</a></li>
+<li><a href="org/apache/spark/storage/BlockManagerMessages.UpdateBlockInfo$.html" title="class in org.apache.spark.storage">BlockManagerMessages.UpdateBlockInfo$</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/BlockMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed">BlockMatrix</a></li>
+<li><a href="org/apache/spark/storage/BlockNotFoundException.html" title="class in org.apache.spark.storage">BlockNotFoundException</a></li>
+<li><a href="org/apache/spark/storage/BlockReplicationPolicy.html" title="interface in org.apache.spark.storage"><span class="interfaceName">BlockReplicationPolicy</span></a></li>
+<li><a href="org/apache/spark/storage/BlockReplicationUtils.html" title="class in org.apache.spark.storage">BlockReplicationUtils</a></li>
+<li><a href="org/apache/spark/storage/BlockStatus.html" title="class in org.apache.spark.storage">BlockStatus</a></li>
+<li><a href="org/apache/spark/storage/BlockUpdatedInfo.html" title="class in org.apache.spark.storage">BlockUpdatedInfo</a></li>
+<li><a href="org/apache/spark/util/sketch/BloomFilter.html" title="class in org.apache.spark.util.sketch">BloomFilter</a></li>
+<li><a href="org/apache/spark/util/sketch/BloomFilter.Version.html" title="enum in org.apache.spark.util.sketch">BloomFilter.Version</a></li>
+<li><a href="org/apache/spark/ml/param/BooleanParam.html" title="class in org.apache.spark.ml.param">BooleanParam</a></li>
+<li><a href="org/apache/spark/sql/types/BooleanType.html" title="class in org.apache.spark.sql.types">BooleanType</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/BoostingStrategy.html" title="class in org.apache.spark.mllib.tree.configuration">BoostingStrategy</a></li>
+<li><a href="org/apache/spark/partial/BoundedDouble.html" title="class in org.apache.spark.partial">BoundedDouble</a></li>
+<li><a href="org/apache/spark/ml/ann/BreezeUtil.html" title="class in org.apache.spark.ml.ann">BreezeUtil</a></li>
+<li><a href="org/apache/spark/broadcast/Broadcast.html" title="class in org.apache.spark.broadcast">Broadcast</a></li>
+<li><a href="org/apache/spark/storage/BroadcastBlockId.html" title="class in org.apache.spark.storage">BroadcastBlockId</a></li>
+<li><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSH.html" title="class in org.apache.spark.ml.feature">BucketedRandomProjectionLSH</a></li>
+<li><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html" title="class in org.apache.spark.ml.feature">BucketedRandomProjectionLSHModel</a></li>
+<li><a href="org/apache/spark/ml/feature/Bucketizer.html" title="class in org.apache.spark.ml.feature">Bucketizer</a></li>
+<li><a href="org/apache/spark/storage/BufferReleasingInputStream.html" title="class in org.apache.spark.storage">BufferReleasingInputStream</a></li>
+<li><a href="org/apache/spark/graphx/util/BytecodeUtils.html" title="class in org.apache.spark.graphx.util">BytecodeUtils</a></li>
+<li><a href="org/apache/spark/sql/types/ByteType.html" title="class in org.apache.spark.sql.types">ByteType</a></li>
+<li><a href="org/apache/spark/sql/types/CalendarIntervalType.html" title="class in org.apache.spark.sql.types">CalendarIntervalType</a></li>
+<li><a href="org/apache/spark/sql/catalog/Catalog.html" title="class in org.apache.spark.sql.catalog">Catalog</a></li>
+<li><a href="org/apache/spark/sql/sources/CatalystScan.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">CatalystScan</span></a></li>
+<li><a href="org/apache/spark/ml/tree/CategoricalSplit.html" title="class in org.apache.spark.ml.tree">CategoricalSplit</a></li>
+<li><a href="org/apache/spark/util/CausedBy.html" title="class in org.apache.spark.util">CausedBy</a></li>
+<li><a href="org/apache/spark/sql/types/CharType.html" title="class in org.apache.spark.sql.types">CharType</a></li>
+<li><a href="org/apache/spark/streaming/CheckpointReader.html" title="class in org.apache.spark.streaming">CheckpointReader</a></li>
+<li><a href="org/apache/spark/rdd/CheckpointState.html" title="class in org.apache.spark.rdd">CheckpointState</a></li>
+<li><a href="org/apache/spark/util/ChildFirstURLClassLoader.html" title="class in org.apache.spark.util">ChildFirstURLClassLoader</a></li>
+<li><a href="org/apache/spark/ml/feature/ChiSqSelector.html" title="class in org.apache.spark.ml.feature">ChiSqSelector</a></li>
+<li><a href="org/apache/spark/mllib/feature/ChiSqSelector.html" title="class in org.apache.spark.mllib.feature">ChiSqSelector</a></li>
+<li><a href="org/apache/spark/ml/feature/ChiSqSelectorModel.html" title="class in org.apache.spark.ml.feature">ChiSqSelectorModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/ChiSqSelectorModel.html" title="class in org.apache.spark.mllib.feature">ChiSqSelectorModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/ChiSqSelectorModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.feature">ChiSqSelectorModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.html" title="class in org.apache.spark.mllib.stat.test">ChiSqTest</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.Method.html" title="class in org.apache.spark.mllib.stat.test">ChiSqTest.Method</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.Method$.html" title="class in org.apache.spark.mllib.stat.test">ChiSqTest.Method$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTest.NullHypothesis$.html" title="class in org.apache.spark.mllib.stat.test">ChiSqTest.NullHypothesis$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/ChiSqTestResult.html" title="class in org.apache.spark.mllib.stat.test">ChiSqTestResult</a></li>
+<li><a href="org/apache/spark/ml/stat/ChiSquareTest.html" title="class in org.apache.spark.ml.stat">ChiSquareTest</a></li>
+<li><a href="org/apache/spark/mllib/linalg/CholeskyDecomposition.html" title="class in org.apache.spark.mllib.linalg">CholeskyDecomposition</a></li>
+<li><a href="org/apache/spark/ml/classification/ClassificationModel.html" title="class in org.apache.spark.ml.classification">ClassificationModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/ClassificationModel.html" title="interface in org.apache.spark.mllib.classification"><span class="interfaceName">ClassificationModel</span></a></li>
+<li><a href="org/apache/spark/ml/classification/Classifier.html" title="class in org.apache.spark.ml.classification">Classifier</a></li>
+<li><a href="org/apache/spark/CleanAccum.html" title="class in org.apache.spark">CleanAccum</a></li>
+<li><a href="org/apache/spark/CleanBroadcast.html" title="class in org.apache.spark">CleanBroadcast</a></li>
+<li><a href="org/apache/spark/CleanCheckpoint.html" title="class in org.apache.spark">CleanCheckpoint</a></li>
+<li><a href="org/apache/spark/CleanRDD.html" title="class in org.apache.spark">CleanRDD</a></li>
+<li><a href="org/apache/spark/CleanShuffle.html" title="class in org.apache.spark">CleanShuffle</a></li>
+<li><a href="org/apache/spark/CleanupTask.html" title="interface in org.apache.spark"><span class="interfaceName">CleanupTask</span></a></li>
+<li><a href="org/apache/spark/CleanupTaskWeakReference.html" title="class in org.apache.spark">CleanupTaskWeakReference</a></li>
+<li><a href="org/apache/spark/util/ClosureCleaner.html" title="class in org.apache.spark.util">ClosureCleaner</a></li>
+<li><a href="org/apache/spark/ml/clustering/ClusterData.html" title="class in org.apache.spark.ml.clustering">ClusterData</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/partitioning/ClusteredDistribution.html" title="class in org.apache.spark.sql.sources.v2.reader.partitioning">ClusteredDistribution</a></li>
+<li><a href="org/apache/spark/ml/evaluation/ClusteringEvaluator.html" title="class in org.apache.spark.ml.evaluation">ClusteringEvaluator</a></li>
+<li><a href="org/apache/spark/ml/clustering/ClusteringSummary.html" title="class in org.apache.spark.ml.clustering">ClusteringSummary</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.AddWebUIFilter</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.AddWebUIFilter$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.GetExecutorLossReason.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.GetExecutorLossReason</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.GetExecutorLossReason$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.GetExecutorLossReason$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutors.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.KillExecutors</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutors$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.KillExecutors$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutorsOnHost.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.KillExecutorsOnHost</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillExecutorsOnHost$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.KillExecutorsOnHost$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillTask.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.KillTask</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.KillTask$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.KillTask$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.LaunchTask.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.LaunchTask</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.LaunchTask$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.LaunchTask$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterClusterManager.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterClusterManager</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterClusterManager$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterClusterManager$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisteredExecutor$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisteredExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutor.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterExecutor</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutor$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutorFailed.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterExecutorFailed</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutorFailed$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterExecutorFailed$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterExecutorResponse.html" title="interface in org.apache.spark.scheduler.cluster"><span class="interfaceName">CoarseGrainedClusterMessages.RegisterExecutorResponse</span></a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveExecutor.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RemoveExecutor</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveExecutor$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RemoveExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveWorker.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RemoveWorker</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RemoveWorker$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RemoveWorker$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RequestExecutors.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RequestExecutors</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RequestExecutors$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RequestExecutors$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RetrieveLastAllocatedExecutorId$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RetrieveLastAllocatedExecutorId$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RetrieveSparkAppConfig$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RetrieveSparkAppConfig$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.ReviveOffers$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.ReviveOffers$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SetupDriver.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.SetupDriver</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SetupDriver$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.SetupDriver$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.Shutdown$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.Shutdown$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SparkAppConfig.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.SparkAppConfig</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.SparkAppConfig$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.SparkAppConfig$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StatusUpdate.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.StatusUpdate</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StatusUpdate$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.StatusUpdate$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StopDriver$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.StopDriver$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StopExecutor$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.StopExecutor$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StopExecutors$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.StopExecutors$</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.UpdateDelegationTokens.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.UpdateDelegationTokens</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.UpdateDelegationTokens$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.UpdateDelegationTokens$</a></li>
+<li><a href="org/apache/spark/metrics/source/CodegenMetrics.html" title="class in org.apache.spark.metrics.source">CodegenMetrics</a></li>
+<li><a href="org/apache/spark/rdd/CoGroupedRDD.html" title="class in org.apache.spark.rdd">CoGroupedRDD</a></li>
+<li><a href="org/apache/spark/api/java/function/CoGroupFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">CoGroupFunction</span></a></li>
+<li><a href="org/apache/spark/util/CollectionAccumulator.html" title="class in org.apache.spark.util">CollectionAccumulator</a></li>
+<li><a href="org/apache/spark/util/CollectionsUtils.html" title="class in org.apache.spark.util">CollectionsUtils</a></li>
+<li><a href="org/apache/spark/sql/catalog/Column.html" title="class in org.apache.spark.sql.catalog">Column</a></li>
+<li><a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarArray.html" title="class in org.apache.spark.sql.vectorized">ColumnarArray</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarBatch.html" title="class in org.apache.spark.sql.vectorized">ColumnarBatch</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarMap.html" title="class in org.apache.spark.sql.vectorized">ColumnarMap</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnarRow.html" title="class in org.apache.spark.sql.vectorized">ColumnarRow</a></li>
+<li><a href="org/apache/spark/sql/ColumnName.html" title="class in org.apache.spark.sql">ColumnName</a></li>
+<li><a href="org/apache/spark/ml/feature/ColumnPruner.html" title="class in org.apache.spark.ml.feature">ColumnPruner</a></li>
+<li><a href="org/apache/spark/sql/vectorized/ColumnVector.html" title="class in org.apache.spark.sql.vectorized">ColumnVector</a></li>
+<li><a href="org/apache/spark/ComplexFutureAction.html" title="class in org.apache.spark">ComplexFutureAction</a></li>
+<li><a href="org/apache/spark/io/CompressionCodec.html" title="interface in org.apache.spark.io"><span class="interfaceName">CompressionCodec</span></a></li>
+<li><a href="org/apache/spark/status/config.html" title="class in org.apache.spark.status">config</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigEntryWithDefault.html" title="class in org.apache.spark.internal.config">ConfigEntryWithDefault</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigEntryWithDefaultFunction.html" title="class in org.apache.spark.internal.config">ConfigEntryWithDefaultFunction</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigEntryWithDefaultString.html" title="class in org.apache.spark.internal.config">ConfigEntryWithDefaultString</a></li>
+<li><a href="org/apache/spark/internal/config/ConfigHelpers.html" title="class in org.apache.spark.internal.config">ConfigHelpers</a></li>
+<li><a href="org/apache/spark/graphx/lib/ConnectedComponents.html" title="class in org.apache.spark.graphx.lib">ConnectedComponents</a></li>
+<li><a href="org/apache/spark/streaming/dstream/ConstantInputDStream.html" title="class in org.apache.spark.streaming.dstream">ConstantInputDStream</a></li>
+<li><a href="org/apache/spark/ContextBarrierId.html" title="class in org.apache.spark">ContextBarrierId</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/ContinuousInputPartition.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">ContinuousInputPartition</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/ContinuousInputPartitionReader.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming"><span class="interfaceName">ContinuousInputPartitionReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/ContinuousReader.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming"><span class="interfaceName">ContinuousReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/ContinuousReadSupport.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">ContinuousReadSupport</span></a></li>
+<li><a href="org/apache/spark/ml/tree/ContinuousSplit.html" title="class in org.apache.spark.ml.tree">ContinuousSplit</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/CoordinateMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed">CoordinateMatrix</a></li>
+<li><a href="org/apache/spark/ml/stat/Correlation.html" title="class in org.apache.spark.ml.stat">Correlation</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/CorrelationNames.html" title="class in org.apache.spark.mllib.stat.correlation">CorrelationNames</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/Correlations.html" title="class in org.apache.spark.mllib.stat.correlation">Correlations</a></li>
+<li><a href="org/apache/spark/ml/evaluation/CosineSilhouette.html" title="class in org.apache.spark.ml.evaluation">CosineSilhouette</a></li>
+<li><a href="org/apache/spark/storage/CountingWritableChannel.html" title="class in org.apache.spark.storage">CountingWritableChannel</a></li>
+<li><a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></li>
+<li><a href="org/apache/spark/util/sketch/CountMinSketch.Version.html" title="enum in org.apache.spark.util.sketch">CountMinSketch.Version</a></li>
+<li><a href="org/apache/spark/ml/feature/CountVectorizer.html" title="class in org.apache.spark.ml.feature">CountVectorizer</a></li>
+<li><a href="org/apache/spark/ml/feature/CountVectorizerModel.html" title="class in org.apache.spark.ml.feature">CountVectorizerModel</a></li>
+<li><a href="org/apache/spark/sql/sources/CreatableRelationProvider.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">CreatableRelationProvider</span></a></li>
+<li><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution">CreateHiveTableAsSelectCommand</a></li>
+<li><a href="org/apache/spark/ml/tuning/CrossValidator.html" title="class in org.apache.spark.ml.tuning">CrossValidator</a></li>
+<li><a href="org/apache/spark/ml/tuning/CrossValidatorModel.html" title="class in org.apache.spark.ml.tuning">CrossValidatorModel</a></li>
+<li><a href="org/apache/spark/ml/tuning/CrossValidatorModel.CrossValidatorModelWriter.html" title="class in org.apache.spark.ml.tuning">CrossValidatorModel.CrossValidatorModelWriter</a></li>
+<li><a href="org/apache/spark/security/CryptoStreamUtils.html" title="class in org.apache.spark.security">CryptoStreamUtils</a></li>
+<li><a href="org/apache/spark/security/CryptoStreamUtils.BaseErrorHandler.html" title="interface in org.apache.spark.security"><span class="interfaceName">CryptoStreamUtils.BaseErrorHandler</span></a></li>
+<li><a href="org/apache/spark/security/CryptoStreamUtils.ErrorHandlingReadableChannel.html" title="class in org.apache.spark.security">CryptoStreamUtils.ErrorHandlingReadableChannel</a></li>
+<li><a href="org/apache/spark/sql/catalog/Database.html" title="class in org.apache.spark.sql.catalog">Database</a></li>
+<li><a href="org/apache/spark/sql/DataFrameNaFunctions.html" title="class in org.apache.spark.sql">DataFrameNaFunctions</a></li>
+<li><a href="org/apache/spark/sql/DataFrameReader.html" title="class in org.apache.spark.sql">DataFrameReader</a></li>
+<li><a href="org/apache/spark/sql/DataFrameStatFunctions.html" title="class in org.apache.spark.sql">DataFrameStatFunctions</a></li>
+<li><a href="org/apache/spark/sql/DataFrameWriter.html" title="class in org.apache.spark.sql">DataFrameWriter</a></li>
+<li><a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></li>
+<li><a href="org/apache/spark/sql/DatasetHolder.html" title="class in org.apache.spark.sql">DatasetHolder</a></li>
+<li><a href="org/apache/spark/ml/util/DatasetUtils.html" title="class in org.apache.spark.ml.util">DatasetUtils</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html" title="class in org.apache.spark.sql.sources.v2">DataSourceOptions</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/DataSourceReader.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">DataSourceReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/DataSourceRegister.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">DataSourceRegister</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/DataSourceV2.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">DataSourceV2</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/DataSourceWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer"><span class="interfaceName">DataSourceWriter</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/DataStreamReader.html" title="class in org.apache.spark.sql.streaming">DataStreamReader</a></li>
+<li><a href="org/apache/spark/sql/streaming/DataStreamWriter.html" title="class in org.apache.spark.sql.streaming">DataStreamWriter</a></li>
+<li><a href="org/apache/spark/sql/types/DataType.html" title="class in org.apache.spark.sql.types">DataType</a></li>
+<li><a href="org/apache/spark/sql/types/DataTypes.html" title="class in org.apache.spark.sql.types">DataTypes</a></li>
+<li><a href="org/apache/spark/mllib/util/DataValidators.html" title="class in org.apache.spark.mllib.util">DataValidators</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/DataWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer"><span class="interfaceName">DataWriter</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/DataWriterFactory.html" title="interface in org.apache.spark.sql.sources.v2.writer"><span class="interfaceName">DataWriterFactory</span></a></li>
+<li><a href="org/apache/spark/sql/types/DateType.html" title="class in org.apache.spark.sql.types">DateType</a></li>
+<li><a href="org/apache/spark/sql/jdbc/DB2Dialect.html" title="class in org.apache.spark.sql.jdbc">DB2Dialect</a></li>
+<li><a href="org/apache/spark/ml/feature/DCT.html" title="class in org.apache.spark.ml.feature">DCT</a></li>
+<li><a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></li>
+<li><a href="org/apache/spark/sql/types/Decimal.DecimalAsIfIntegral$.html" title="class in org.apache.spark.sql.types">Decimal.DecimalAsIfIntegral$</a></li>
+<li><a href="org/apache/spark/sql/types/Decimal.DecimalIsFractional$.html" title="class in org.apache.spark.sql.types">Decimal.DecimalIsFractional$</a></li>
+<li><a href="org/apache/spark/sql/types/DecimalType.html" title="class in org.apache.spark.sql.types">DecimalType</a></li>
+<li><a href="org/apache/spark/sql/types/DecimalType.Expression$.html" title="class in org.apache.spark.sql.types">DecimalType.Expression$</a></li>
+<li><a href="org/apache/spark/sql/types/DecimalType.Fixed$.html" title="class in org.apache.spark.sql.types">DecimalType.Fixed$</a></li>
+<li><a href="org/apache/spark/mllib/tree/DecisionTree.html" title="class in org.apache.spark.mllib.tree">DecisionTree</a></li>
+<li><a href="org/apache/spark/ml/classification/DecisionTreeClassificationModel.html" title="class in org.apache.spark.ml.classification">DecisionTreeClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/DecisionTreeClassifier.html" title="class in org.apache.spark.ml.classification">DecisionTreeClassifier</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.html" title="class in org.apache.spark.ml.tree">DecisionTreeModelReadWrite</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.NodeData.html" title="class in org.apache.spark.ml.tree">DecisionTreeModelReadWrite.NodeData</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.NodeData$.html" title="class in org.apache.spark.ml.tree">DecisionTreeModelReadWrite.NodeData$</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.SplitData.html" title="class in org.apache.spark.ml.tree">DecisionTreeModelReadWrite.SplitData</a></li>
+<li><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.SplitData$.html" title="class in org.apache.spark.ml.tree">DecisionTreeModelReadWrite.SplitData$</a></li>
+<li><a href="org/apache/spark/ml/regression/DecisionTreeRegressionModel.html" title="class in org.apache.spark.ml.regression">DecisionTreeRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/DecisionTreeRegressor.html" title="class in org.apache.spark.ml.regression">DecisionTreeRegressor</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/DefaultCredentials.html" title="class in org.apache.spark.streaming.kinesis">DefaultCredentials</a></li>
+<li><a href="org/apache/spark/ml/util/DefaultParamsReadable.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">DefaultParamsReadable</span></a></li>
+<li><a href="org/apache/spark/ml/util/DefaultParamsWritable.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">DefaultParamsWritable</span></a></li>
+<li><a href="org/apache/spark/rdd/DefaultPartitionCoalescer.html" title="class in org.apache.spark.rdd">DefaultPartitionCoalescer</a></li>
+<li><a href="org/apache/spark/storage/DefaultTopologyMapper.html" title="class in org.apache.spark.storage">DefaultTopologyMapper</a></li>
+<li><a href="org/apache/spark/ml/linalg/DenseMatrix.html" title="class in org.apache.spark.ml.linalg">DenseMatrix</a></li>
+<li><a href="org/apache/spark/mllib/linalg/DenseMatrix.html" title="class in org.apache.spark.mllib.linalg">DenseMatrix</a></li>
+<li><a href="org/apache/spark/ml/linalg/DenseVector.html" title="class in org.apache.spark.ml.linalg">DenseVector</a></li>
+<li><a href="org/apache/spark/mllib/linalg/DenseVector.html" title="class in org.apache.spark.mllib.linalg">DenseVector</a></li>
+<li><a href="org/apache/spark/Dependency.html" title="class in org.apache.spark">Dependency</a></li>
+<li><a href="org/apache/spark/sql/jdbc/DerbyDialect.html" title="class in org.apache.spark.sql.jdbc">DerbyDialect</a></li>
+<li><a href="org/apache/spark/serializer/DeserializationStream.html" title="class in org.apache.spark.serializer">DeserializationStream</a></li>
+<li><a href="org/apache/spark/storage/memory/DeserializedMemoryEntry.html" title="class in org.apache.spark.storage.memory">DeserializedMemoryEntry</a></li>
+<li><a href="org/apache/spark/storage/memory/DeserializedValuesHolder.html" title="class in org.apache.spark.storage.memory">DeserializedValuesHolder</a></li>
+<li><a href="org/apache/spark/sql/hive/DetermineTableStats.html" title="class in org.apache.spark.sql.hive">DetermineTableStats</a></li>
+<li><a href="org/apache/spark/rdd/DeterministicLevel.html" title="class in org.apache.spark.rdd">DeterministicLevel</a></li>
+<li><a href="org/apache/spark/storage/DiskBlockData.html" title="class in org.apache.spark.storage">DiskBlockData</a></li>
+<li><a href="org/apache/spark/ml/clustering/DistributedLDAModel.html" title="class in org.apache.spark.ml.clustering">DistributedLDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/DistributedLDAModel.html" title="class in org.apache.spark.mllib.clustering">DistributedLDAModel</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/DistributedMatrix.html" title="interface in org.apache.spark.mllib.linalg.distributed"><span class="interfaceName">DistributedMatrix</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/partitioning/Distribution.html" title="interface in org.apache.spark.sql.sources.v2.reader.partitioning"><span class="interfaceName">Distribution</span></a></li>
+<li><a href="org/apache/spark/ml/feature/Dot.html" title="class in org.apache.spark.ml.feature">Dot</a></li>
+<li><a href="org/apache/spark/util/DoubleAccumulator.html" title="class in org.apache.spark.util">DoubleAccumulator</a></li>
+<li><a href="org/apache/spark/ml/param/DoubleArrayArrayParam.html" title="class in org.apache.spark.ml.param">DoubleArrayArrayParam</a></li>
+<li><a href="org/apache/spark/ml/param/DoubleArrayParam.html" title="class in org.apache.spark.ml.param">DoubleArrayParam</a></li>
+<li><a href="org/apache/spark/api/java/function/DoubleFlatMapFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">DoubleFlatMapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/DoubleFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">DoubleFunction</span></a></li>
+<li><a href="org/apache/spark/ml/param/DoubleParam.html" title="class in org.apache.spark.ml.param">DoubleParam</a></li>
+<li><a href="org/apache/spark/rdd/DoubleRDDFunctions.html" title="class in org.apache.spark.rdd">DoubleRDDFunctions</a></li>
+<li><a href="org/apache/spark/sql/types/DoubleType.html" title="class in org.apache.spark.sql.types">DoubleType</a></li>
+<li><a href="org/apache/spark/streaming/dstream/DStream.html" title="class in org.apache.spark.streaming.dstream">DStream</a></li>
+<li><a href="org/apache/spark/serializer/DummySerializerInstance.html" title="class in org.apache.spark.serializer">DummySerializerInstance</a></li>
+<li><a href="org/apache/spark/streaming/Duration.html" title="class in org.apache.spark.streaming">Duration</a></li>
+<li><a href="org/apache/spark/streaming/Durations.html" title="class in org.apache.spark.streaming">Durations</a></li>
+<li><a href="org/apache/spark/graphx/Edge.html" title="class in org.apache.spark.graphx">Edge</a></li>
+<li><a href="org/apache/spark/graphx/impl/EdgeActiveness.html" title="enum in org.apache.spark.graphx.impl">EdgeActiveness</a></li>
+<li><a href="org/apache/spark/graphx/EdgeContext.html" title="class in org.apache.spark.graphx">EdgeContext</a></li>
+<li><a href="org/apache/spark/graphx/EdgeDirection.html" title="class in org.apache.spark.graphx">EdgeDirection</a></li>
+<li><a href="org/apache/spark/graphx/EdgeRDD.html" title="class in org.apache.spark.graphx">EdgeRDD</a></li>
+<li><a href="org/apache/spark/graphx/impl/EdgeRDDImpl.html" title="class in org.apache.spark.graphx.impl">EdgeRDDImpl</a></li>
+<li><a href="org/apache/spark/graphx/EdgeTriplet.html" title="class in org.apache.spark.graphx">EdgeTriplet</a></li>
+<li><a href="org/apache/spark/mllib/linalg/EigenValueDecomposition.html" title="class in org.apache.spark.mllib.linalg">EigenValueDecomposition</a></li>
+<li><a href="org/apache/spark/ml/feature/ElementwiseProduct.html" title="class in org.apache.spark.ml.feature">ElementwiseProduct</a></li>
+<li><a href="org/apache/spark/mllib/feature/ElementwiseProduct.html" title="class in org.apache.spark.mllib.feature">ElementwiseProduct</a></li>
+<li><a href="org/apache/spark/mllib/clustering/EMLDAOptimizer.html" title="class in org.apache.spark.mllib.clustering">EMLDAOptimizer</a></li>
+<li><a href="org/apache/spark/sql/Encoder.html" title="interface in org.apache.spark.sql"><span class="interfaceName">Encoder</span></a></li>
+<li><a href="org/apache/spark/sql/Encoders.html" title="class in org.apache.spark.sql">Encoders</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/EnsembleCombiningStrategy.html" title="class in org.apache.spark.mllib.tree.configuration">EnsembleCombiningStrategy</a></li>
+<li><a href="org/apache/spark/ml/tree/EnsembleModelReadWrite.html" title="class in org.apache.spark.ml.tree">EnsembleModelReadWrite</a></li>
+<li><a href="org/apache/spark/ml/tree/EnsembleModelReadWrite.EnsembleNodeData.html" title="class in org.apache.spark.ml.tree">EnsembleModelReadWrite.EnsembleNodeData</a></li>
+<li><a href="org/apache/spark/ml/tree/EnsembleModelReadWrite.EnsembleNodeData$.html" title="class in org.apache.spark.ml.tree">EnsembleModelReadWrite.EnsembleNodeData$</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Entropy.html" title="class in org.apache.spark.mllib.tree.impurity">Entropy</a></li>
+<li><a href="org/apache/spark/util/EnumUtil.html" title="class in org.apache.spark.util">EnumUtil</a></li>
+<li><a href="org/apache/spark/sql/sources/EqualNullSafe.html" title="class in org.apache.spark.sql.sources">EqualNullSafe</a></li>
+<li><a href="org/apache/spark/sql/sources/EqualTo.html" title="class in org.apache.spark.sql.sources">EqualTo</a></li>
+<li><a href="org/apache/spark/ml/Estimator.html" title="class in org.apache.spark.ml">Estimator</a></li>
+<li><a href="org/apache/spark/ml/evaluation/Evaluator.html" title="class in org.apache.spark.ml.evaluation">Evaluator</a></li>
+<li><a href="org/apache/spark/ExceptionFailure.html" title="class in org.apache.spark">ExceptionFailure</a></li>
+<li><a href="org/apache/spark/sql/util/ExecutionListenerManager.html" title="class in org.apache.spark.sql.util">ExecutionListenerManager</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/ExecutorInfo.html" title="class in org.apache.spark.scheduler.cluster">ExecutorInfo</a></li>
+<li><a href="org/apache/spark/scheduler/ExecutorKilled.html" title="class in org.apache.spark.scheduler">ExecutorKilled</a></li>
+<li><a href="org/apache/spark/ExecutorLostFailure.html" title="class in org.apache.spark">ExecutorLostFailure</a></li>
+<li><a href="org/apache/spark/ExecutorPlugin.html" title="interface in org.apache.spark"><span class="interfaceName">ExecutorPlugin</span></a></li>
+<li><a href="org/apache/spark/ExecutorRegistered.html" title="class in org.apache.spark">ExecutorRegistered</a></li>
+<li><a href="org/apache/spark/ExecutorRemoved.html" title="class in org.apache.spark">ExecutorRemoved</a></li>
+<li><a href="org/apache/spark/status/api/v1/ExecutorStageSummary.html" title="class in org.apache.spark.status.api.v1">ExecutorStageSummary</a></li>
+<li><a href="org/apache/spark/ui/storage/ExecutorStreamSummary.html" title="class in org.apache.spark.ui.storage">ExecutorStreamSummary</a></li>
+<li><a href="org/apache/spark/status/api/v1/ExecutorSummary.html" title="class in org.apache.spark.status.api.v1">ExecutorSummary</a></li>
+<li><a href="org/apache/spark/ml/clustering/ExpectationAggregator.html" title="class in org.apache.spark.ml.clustering">ExpectationAggregator</a></li>
+<li><a href="org/apache/spark/mllib/clustering/ExpectationSum.html" title="class in org.apache.spark.mllib.clustering">ExpectationSum</a></li>
+<li><a href="org/apache/spark/sql/ExperimentalMethods.html" title="class in org.apache.spark.sql">ExperimentalMethods</a></li>
+<li><a href="org/apache/spark/ExpireDeadHosts.html" title="class in org.apache.spark">ExpireDeadHosts</a></li>
+<li><a href="org/apache/spark/mllib/random/ExponentialGenerator.html" title="class in org.apache.spark.mllib.random">ExponentialGenerator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/binary/FalsePositiveRate.html" title="class in org.apache.spark.mllib.evaluation.binary">FalsePositiveRate</a></li>
+<li><a href="org/apache/spark/ml/feature/FeatureHasher.html" title="class in org.apache.spark.ml.feature">FeatureHasher</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/FeatureType.html" title="class in org.apache.spark.mllib.tree.configuration">FeatureType</a></li>
+<li><a href="org/apache/spark/FetchFailed.html" title="class in org.apache.spark">FetchFailed</a></li>
+<li><a href="org/apache/spark/storage/FileBasedTopologyMapper.html" title="class in org.apache.spark.storage">FileBasedTopologyMapper</a></li>
+<li><a href="org/apache/spark/internal/io/FileCommitProtocol.html" title="class in org.apache.spark.internal.io">FileCommitProtocol</a></li>
+<li><a href="org/apache/spark/internal/io/FileCommitProtocol.EmptyTaskCommitMessage$.html" title="class in org.apache.spark.internal.io">FileCommitProtocol.EmptyTaskCommitMessage$</a></li>
+<li><a href="org/apache/spark/internal/io/FileCommitProtocol.TaskCommitMessage.html" title="class in org.apache.spark.internal.io">FileCommitProtocol.TaskCommitMessage</a></li>
+<li><a href="org/apache/spark/sql/sources/Filter.html" title="class in org.apache.spark.sql.sources">Filter</a></li>
+<li><a href="org/apache/spark/api/java/function/FilterFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">FilterFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">FlatMapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapFunction2.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">FlatMapFunction2</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapGroupsFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">FlatMapGroupsFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/FlatMapGroupsWithStateFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">FlatMapGroupsWithStateFunction</span></a></li>
+<li><a href="org/apache/spark/ml/param/FloatParam.html" title="class in org.apache.spark.ml.param">FloatParam</a></li>
+<li><a href="org/apache/spark/sql/types/FloatType.html" title="class in org.apache.spark.sql.types">FloatType</a></li>
+<li><a href="org/apache/spark/api/java/function/ForeachFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">ForeachFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/ForeachPartitionFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">ForeachPartitionFunction</span></a></li>
+<li><a href="org/apache/spark/sql/ForeachWriter.html" title="class in org.apache.spark.sql">ForeachWriter</a></li>
+<li><a href="org/apache/spark/ml/fpm/FPGrowth.html" title="class in org.apache.spark.ml.fpm">FPGrowth</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowth.html" title="class in org.apache.spark.mllib.fpm">FPGrowth</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowth.FreqItemset.html" title="class in org.apache.spark.mllib.fpm">FPGrowth.FreqItemset</a></li>
+<li><a href="org/apache/spark/ml/fpm/FPGrowthModel.html" title="class in org.apache.spark.ml.fpm">FPGrowthModel</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowthModel.html" title="class in org.apache.spark.mllib.fpm">FPGrowthModel</a></li>
+<li><a href="org/apache/spark/mllib/fpm/FPGrowthModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.fpm">FPGrowthModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/api/java/function/Function.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">Function</span></a></li>
+<li><a href="org/apache/spark/sql/catalog/Function.html" title="class in org.apache.spark.sql.catalog">Function</a></li>
+<li><a href="org/apache/spark/api/java/function/Function0.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">Function0</span></a></li>
+<li><a href="org/apache/spark/api/java/function/Function2.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">Function2</span></a></li>
+<li><a href="org/apache/spark/api/java/function/Function3.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">Function3</span></a></li>
+<li><a href="org/apache/spark/api/java/function/Function4.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">Function4</span></a></li>
+<li><a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></li>
+<li><a href="org/apache/spark/FutureAction.html" title="interface in org.apache.spark"><span class="interfaceName">FutureAction</span></a></li>
+<li><a href="org/apache/spark/mllib/random/GammaGenerator.html" title="class in org.apache.spark.mllib.random">GammaGenerator</a></li>
+<li><a href="org/apache/spark/ml/clustering/GaussianMixture.html" title="class in org.apache.spark.ml.clustering">GaussianMixture</a></li>
+<li><a href="org/apache/spark/mllib/clustering/GaussianMixture.html" title="class in org.apache.spark.mllib.clustering">GaussianMixture</a></li>
+<li><a href="org/apache/spark/ml/clustering/GaussianMixtureModel.html" title="class in org.apache.spark.ml.clustering">GaussianMixtureModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/GaussianMixtureModel.html" title="class in org.apache.spark.mllib.clustering">GaussianMixtureModel</a></li>
+<li><a href="org/apache/spark/ml/clustering/GaussianMixtureSummary.html" title="class in org.apache.spark.ml.clustering">GaussianMixtureSummary</a></li>
+<li><a href="org/apache/spark/ml/classification/GBTClassificationModel.html" title="class in org.apache.spark.ml.classification">GBTClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/GBTClassifier.html" title="class in org.apache.spark.ml.classification">GBTClassifier</a></li>
+<li><a href="org/apache/spark/ml/regression/GBTRegressionModel.html" title="class in org.apache.spark.ml.regression">GBTRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/GBTRegressor.html" title="class in org.apache.spark.ml.regression">GBTRegressor</a></li>
+<li><a href="org/apache/spark/mllib/regression/GeneralizedLinearAlgorithm.html" title="class in org.apache.spark.mllib.regression">GeneralizedLinearAlgorithm</a></li>
+<li><a href="org/apache/spark/mllib/regression/GeneralizedLinearModel.html" title="class in org.apache.spark.mllib.regression">GeneralizedLinearModel</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Binomial$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Binomial$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.CLogLog$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.CLogLog$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Family$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Family$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.FamilyAndLink$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.FamilyAndLink$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gamma$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Gamma$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gaussian$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Gaussian$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Identity$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Identity$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Inverse$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Inverse$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Link$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Link$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Log$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Log$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Logit$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Logit$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Poisson$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Poisson$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Probit$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Probit$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Sqrt$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Sqrt$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Tweedie$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Tweedie$</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionModel.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionSummary.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegressionSummary</a></li>
+<li><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionTrainingSummary.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegressionTrainingSummary</a></li>
+<li><a href="org/apache/spark/ml/util/GeneralMLWritable.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">GeneralMLWritable</span></a></li>
+<li><a href="org/apache/spark/ml/util/GeneralMLWriter.html" title="class in org.apache.spark.ml.util">GeneralMLWriter</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/GetAllReceiverInfo.html" title="class in org.apache.spark.streaming.scheduler">GetAllReceiverInfo</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Gini.html" title="class in org.apache.spark.mllib.tree.impurity">Gini</a></li>
+<li><a href="org/apache/spark/mllib/classification/impl/GLMClassificationModel.html" title="class in org.apache.spark.mllib.classification.impl">GLMClassificationModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/impl/GLMClassificationModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.classification.impl">GLMClassificationModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/regression/impl/GLMRegressionModel.html" title="class in org.apache.spark.mllib.regression.impl">GLMRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/impl/GLMRegressionModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.regression.impl">GLMRegressionModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/optimization/Gradient.html" title="class in org.apache.spark.mllib.optimization">Gradient</a></li>
+<li><a href="org/apache/spark/ml/tree/impl/GradientBoostedTrees.html" title="class in org.apache.spark.ml.tree.impl">GradientBoostedTrees</a></li>
+<li><a href="org/apache/spark/mllib/tree/GradientBoostedTrees.html" title="class in org.apache.spark.mllib.tree">GradientBoostedTrees</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/GradientBoostedTreesModel.html" title="class in org.apache.spark.mllib.tree.model">GradientBoostedTreesModel</a></li>
+<li><a href="org/apache/spark/mllib/optimization/GradientDescent.html" title="class in org.apache.spark.mllib.optimization">GradientDescent</a></li>
+<li><a href="org/apache/spark/graphx/Graph.html" title="class in org.apache.spark.graphx">Graph</a></li>
+<li><a href="org/apache/spark/graphx/util/GraphGenerators.html" title="class in org.apache.spark.graphx.util">GraphGenerators</a></li>
+<li><a href="org/apache/spark/graphx/impl/GraphImpl.html" title="class in org.apache.spark.graphx.impl">GraphImpl</a></li>
+<li><a href="org/apache/spark/graphx/GraphLoader.html" title="class in org.apache.spark.graphx">GraphLoader</a></li>
+<li><a href="org/apache/spark/graphx/GraphOps.html" title="class in org.apache.spark.graphx">GraphOps</a></li>
+<li><a href="org/apache/spark/graphx/GraphXUtils.html" title="class in org.apache.spark.graphx">GraphXUtils</a></li>
+<li><a href="org/apache/spark/sql/sources/GreaterThan.html" title="class in org.apache.spark.sql.sources">GreaterThan</a></li>
+<li><a href="org/apache/spark/sql/sources/GreaterThanOrEqual.html" title="class in org.apache.spark.sql.sources">GreaterThanOrEqual</a></li>
+<li><a href="org/apache/spark/security/GroupMappingServiceProvider.html" title="interface in org.apache.spark.security"><span class="interfaceName">GroupMappingServiceProvider</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/GroupState.html" title="interface in org.apache.spark.sql.streaming"><span class="interfaceName">GroupState</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/GroupStateTimeout.html" title="class in org.apache.spark.sql.streaming">GroupStateTimeout</a></li>
+<li><a href="org/apache/spark/internal/io/HadoopMapRedCommitProtocol.html" title="class in org.apache.spark.internal.io">HadoopMapRedCommitProtocol</a></li>
+<li><a href="org/apache/spark/internal/io/HadoopMapReduceCommitProtocol.html" title="class in org.apache.spark.internal.io">HadoopMapReduceCommitProtocol</a></li>
+<li><a href="org/apache/spark/rdd/HadoopRDD.html" title="class in org.apache.spark.rdd">HadoopRDD</a></li>
+<li><a href="org/apache/spark/rdd/HadoopRDD.HadoopMapPartitionsWithSplitRDD$.html" title="class in org.apache.spark.rdd">HadoopRDD.HadoopMapPartitionsWithSplitRDD$</a></li>
+<li><a href="org/apache/spark/internal/io/HadoopWriteConfigUtil.html" title="class in org.apache.spark.internal.io">HadoopWriteConfigUtil</a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasAggregationDepth.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasAggregationDepth</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasCheckpointInterval.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasCheckpointInterval</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasCollectSubModels.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasCollectSubModels</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasDistanceMeasure.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasDistanceMeasure</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasElasticNetParam.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasElasticNetParam</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasFeaturesCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasFeaturesCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasFitIntercept.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasFitIntercept</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasHandleInvalid.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasHandleInvalid</span></a></li>
+<li><a href="org/apache/spark/ml/feature/HashingTF.html" title="class in org.apache.spark.ml.feature">HashingTF</a></li>
+<li><a href="org/apache/spark/mllib/feature/HashingTF.html" title="class in org.apache.spark.mllib.feature">HashingTF</a></li>
+<li><a href="org/apache/spark/HashPartitioner.html" title="class in org.apache.spark">HashPartitioner</a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasInputCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasInputCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasInputCols.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasInputCols</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasLabelCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasLabelCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasLoss.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasLoss</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasMaxIter.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasMaxIter</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasOutputCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasOutputCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasOutputCols.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasOutputCols</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasPredictionCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasPredictionCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasProbabilityCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasProbabilityCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasRawPredictionCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasRawPredictionCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasRegParam.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasRegParam</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasSeed.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasSeed</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasSolver.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasSolver</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasStandardization.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasStandardization</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasStepSize.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasStepSize</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasThreshold.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasThreshold</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasThresholds.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasThresholds</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasTol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasTol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasValidationIndicatorCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasValidationIndicatorCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasVarianceCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasVarianceCol</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/HasWeightCol.html" title="interface in org.apache.spark.ml.param.shared"><span class="interfaceName">HasWeightCol</span></a></li>
+<li><a href="org/apache/spark/streaming/util/HdfsUtils.html" title="class in org.apache.spark.streaming.util">HdfsUtils</a></li>
+<li><a href="org/apache/spark/mllib/optimization/HingeGradient.html" title="class in org.apache.spark.mllib.optimization">HingeGradient</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveAnalysis.html" title="class in org.apache.spark.sql.hive">HiveAnalysis</a></li>
+<li><a href="org/apache/spark/metrics/source/HiveCatalogMetrics.html" title="class in org.apache.spark.metrics.source">HiveCatalogMetrics</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveContext.html" title="class in org.apache.spark.sql.hive">HiveContext</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveFileFormat.html" title="class in org.apache.spark.sql.hive.execution">HiveFileFormat</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveOptions.html" title="class in org.apache.spark.sql.hive.execution">HiveOptions</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveOutputWriter.html" title="class in org.apache.spark.sql.hive.execution">HiveOutputWriter</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/HiveScriptIOSchema.html" title="class in org.apache.spark.sql.hive.execution">HiveScriptIOSchema</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveSessionResourceLoader.html" title="class in org.apache.spark.sql.hive">HiveSessionResourceLoader</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveSessionStateBuilder.html" title="class in org.apache.spark.sql.hive">HiveSessionStateBuilder</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveShim.html" title="class in org.apache.spark.sql.hive">HiveShim</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveShim.HiveFunctionWrapper$.html" title="class in org.apache.spark.sql.hive">HiveShim.HiveFunctionWrapper$</a></li>
+<li><a href="org/apache/spark/sql/types/HiveStringType.html" title="class in org.apache.spark.sql.types">HiveStringType</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveTableUtil.html" title="class in org.apache.spark.sql.hive">HiveTableUtil</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveUDAFBuffer.html" title="class in org.apache.spark.sql.hive">HiveUDAFBuffer</a></li>
+<li><a href="org/apache/spark/sql/hive/HiveUtils.html" title="class in org.apache.spark.sql.hive">HiveUtils</a></li>
+<li><a href="org/apache/spark/ml/util/Identifiable.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">Identifiable</span></a></li>
+<li><a href="org/apache/spark/ml/feature/IDF.html" title="class in org.apache.spark.ml.feature">IDF</a></li>
+<li><a href="org/apache/spark/mllib/feature/IDF.html" title="class in org.apache.spark.mllib.feature">IDF</a></li>
+<li><a href="org/apache/spark/mllib/feature/IDF.DocumentFrequencyAggregator.html" title="class in org.apache.spark.mllib.feature">IDF.DocumentFrequencyAggregator</a></li>
+<li><a href="org/apache/spark/ml/feature/IDFModel.html" title="class in org.apache.spark.ml.feature">IDFModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/IDFModel.html" title="class in org.apache.spark.mllib.feature">IDFModel</a></li>
+<li><a href="org/apache/spark/ml/source/image/ImageDataSource.html" title="class in org.apache.spark.ml.source.image">ImageDataSource</a></li>
+<li><a href="org/apache/spark/ml/image/ImageSchema.html" title="class in org.apache.spark.ml.image">ImageSchema</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Impurities.html" title="class in org.apache.spark.mllib.tree.impurity">Impurities</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Impurity.html" title="interface in org.apache.spark.mllib.tree.impurity"><span class="interfaceName">Impurity</span></a></li>
+<li><a href="org/apache/spark/ml/feature/Imputer.html" title="class in org.apache.spark.ml.feature">Imputer</a></li>
+<li><a href="org/apache/spark/ml/feature/ImputerModel.html" title="class in org.apache.spark.ml.feature">ImputerModel</a></li>
+<li><a href="org/apache/spark/sql/sources/In.html" title="class in org.apache.spark.sql.sources">In</a></li>
+<li><a href="org/apache/spark/util/sketch/IncompatibleMergeException.html" title="class in org.apache.spark.util.sketch">IncompatibleMergeException</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/IndexedRow.html" title="class in org.apache.spark.mllib.linalg.distributed">IndexedRow</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/IndexedRowMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed">IndexedRowMatrix</a></li>
+<li><a href="org/apache/spark/ml/feature/IndexToString.html" title="class in org.apache.spark.ml.feature">IndexToString</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/InformationGainStats.html" title="class in org.apache.spark.mllib.tree.model">InformationGainStats</a></li>
+<li><a href="org/apache/spark/util/InnerClosureFinder.html" title="class in org.apache.spark.util">InnerClosureFinder</a></li>
+<li><a href="org/apache/spark/launcher/InProcessLauncher.html" title="class in org.apache.spark.launcher">InProcessLauncher</a></li>
+<li><a href="org/apache/spark/streaming/dstream/InputDStream.html" title="class in org.apache.spark.streaming.dstream">InputDStream</a></li>
+<li><a href="org/apache/spark/rdd/InputFileBlockHolder.html" title="class in org.apache.spark.rdd">InputFileBlockHolder</a></li>
+<li><a href="org/apache/spark/scheduler/InputFormatInfo.html" title="class in org.apache.spark.scheduler">InputFormatInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/InputMetricDistributions.html" title="class in org.apache.spark.status.api.v1">InputMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/InputMetrics.html" title="class in org.apache.spark.status.api.v1">InputMetrics</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/InputPartition.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">InputPartition</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/InputPartitionReader.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">InputPartitionReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/InsertableRelation.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">InsertableRelation</span></a></li>
+<li><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveDirCommand</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveTable</a></li>
+<li><a href="org/apache/spark/ml/param/IntArrayParam.html" title="class in org.apache.spark.ml.param">IntArrayParam</a></li>
+<li><a href="org/apache/spark/sql/types/IntegerType.html" title="class in org.apache.spark.sql.types">IntegerType</a></li>
+<li><a href="org/apache/spark/ml/feature/Interaction.html" title="class in org.apache.spark.ml.feature">Interaction</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.html" title="class in org.apache.spark">InternalAccumulator</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.input$.html" title="class in org.apache.spark">InternalAccumulator.input$</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.output$.html" title="class in org.apache.spark">InternalAccumulator.output$</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.shuffleRead$.html" title="class in org.apache.spark">InternalAccumulator.shuffleRead$</a></li>
+<li><a href="org/apache/spark/InternalAccumulator.shuffleWrite$.html" title="class in org.apache.spark">InternalAccumulator.shuffleWrite$</a></li>
+<li><a href="org/apache/spark/ml/clustering/InternalKMeansModelWriter.html" title="class in org.apache.spark.ml.clustering">InternalKMeansModelWriter</a></li>
+<li><a href="org/apache/spark/ml/regression/InternalLinearRegressionModelWriter.html" title="class in org.apache.spark.ml.regression">InternalLinearRegressionModelWriter</a></li>
+<li><a href="org/apache/spark/ml/tree/InternalNode.html" title="class in org.apache.spark.ml.tree">InternalNode</a></li>
+<li><a href="org/apache/spark/InterruptibleIterator.html" title="class in org.apache.spark">InterruptibleIterator</a></li>
+<li><a href="org/apache/spark/ml/param/IntParam.html" title="class in org.apache.spark.ml.param">IntParam</a></li>
+<li><a href="org/apache/spark/util/IntParam.html" title="class in org.apache.spark.util">IntParam</a></li>
+<li><a href="org/apache/spark/sql/sources/IsNotNull.html" title="class in org.apache.spark.sql.sources">IsNotNull</a></li>
+<li><a href="org/apache/spark/sql/sources/IsNull.html" title="class in org.apache.spark.sql.sources">IsNull</a></li>
+<li><a href="org/apache/spark/ml/regression/IsotonicRegression.html" title="class in org.apache.spark.ml.regression">IsotonicRegression</a></li>
+<li><a href="org/apache/spark/mllib/regression/IsotonicRegression.html" title="class in org.apache.spark.mllib.regression">IsotonicRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/IsotonicRegressionModel.html" title="class in org.apache.spark.ml.regression">IsotonicRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/IsotonicRegressionModel.html" title="class in org.apache.spark.mllib.regression">IsotonicRegressionModel</a></li>
+<li><a href="org/apache/spark/api/java/JavaDoubleRDD.html" title="class in org.apache.spark.api.java">JavaDoubleRDD</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaDStream.html" title="class in org.apache.spark.streaming.api.java">JavaDStream</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaDStreamLike.html" title="interface in org.apache.spark.streaming.api.java"><span class="interfaceName">JavaDStreamLike</span></a></li>
+<li><a href="org/apache/spark/api/java/JavaFutureAction.html" title="interface in org.apache.spark.api.java"><span class="interfaceName">JavaFutureAction</span></a></li>
+<li><a href="org/apache/spark/api/java/JavaHadoopRDD.html" title="class in org.apache.spark.api.java">JavaHadoopRDD</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaInputDStream.html" title="class in org.apache.spark.streaming.api.java">JavaInputDStream</a></li>
+<li><a href="org/apache/spark/serializer/JavaIterableWrapperSerializer.html" title="class in org.apache.spark.serializer">JavaIterableWrapperSerializer</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaMapWithStateDStream.html" title="class in org.apache.spark.streaming.api.java">JavaMapWithStateDStream</a></li>
+<li><a href="org/apache/spark/api/java/JavaNewHadoopRDD.html" title="class in org.apache.spark.api.java">JavaNewHadoopRDD</a></li>
+<li><a href="org/apache/spark/mllib/JavaPackage.html" title="class in org.apache.spark.mllib">JavaPackage</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaPairDStream.html" title="class in org.apache.spark.streaming.api.java">JavaPairDStream</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaPairInputDStream.html" title="class in org.apache.spark.streaming.api.java">JavaPairInputDStream</a></li>
+<li><a href="org/apache/spark/api/java/JavaPairRDD.html" title="class in org.apache.spark.api.java">JavaPairRDD</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaPairReceiverInputDStream.html" title="class in org.apache.spark.streaming.api.java">JavaPairReceiverInputDStream</a></li>
+<li><a href="org/apache/spark/ml/param/JavaParams.html" title="class in org.apache.spark.ml.param">JavaParams</a></li>
+<li><a href="org/apache/spark/api/java/JavaRDD.html" title="class in org.apache.spark.api.java">JavaRDD</a></li>
+<li><a href="org/apache/spark/api/java/JavaRDDLike.html" title="interface in org.apache.spark.api.java"><span class="interfaceName">JavaRDDLike</span></a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaReceiverInputDStream.html" title="class in org.apache.spark.streaming.api.java">JavaReceiverInputDStream</a></li>
+<li><a href="org/apache/spark/serializer/JavaSerializer.html" title="class in org.apache.spark.serializer">JavaSerializer</a></li>
+<li><a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></li>
+<li><a href="org/apache/spark/api/java/JavaSparkStatusTracker.html" title="class in org.apache.spark.api.java">JavaSparkStatusTracker</a></li>
+<li><a href="org/apache/spark/streaming/api/java/JavaStreamingContext.html" title="class in org.apache.spark.streaming.api.java">JavaStreamingContext</a></li>
+<li><a href="org/apache/spark/api/java/JavaUtils.html" title="class in org.apache.spark.api.java">JavaUtils</a></li>
+<li><a href="org/apache/spark/api/java/JavaUtils.SerializableMapWrapper.html" title="class in org.apache.spark.api.java">JavaUtils.SerializableMapWrapper</a></li>
+<li><a href="org/apache/spark/sql/jdbc/JdbcDialect.html" title="class in org.apache.spark.sql.jdbc">JdbcDialect</a></li>
+<li><a href="org/apache/spark/sql/jdbc/JdbcDialects.html" title="class in org.apache.spark.sql.jdbc">JdbcDialects</a></li>
+<li><a href="org/apache/spark/rdd/JdbcRDD.html" title="class in org.apache.spark.rdd">JdbcRDD</a></li>
+<li><a href="org/apache/spark/rdd/JdbcRDD.ConnectionFactory.html" title="interface in org.apache.spark.rdd"><span class="interfaceName">JdbcRDD.ConnectionFactory</span></a></li>
+<li><a href="org/apache/spark/sql/jdbc/JdbcType.html" title="class in org.apache.spark.sql.jdbc">JdbcType</a></li>
+<li><a href="org/apache/spark/ui/JettyUtils.html" title="class in org.apache.spark.ui">JettyUtils</a></li>
+<li><a href="org/apache/spark/ui/JettyUtils.ServletParams.html" title="class in org.apache.spark.ui">JettyUtils.ServletParams</a></li>
+<li><a href="org/apache/spark/ui/JettyUtils.ServletParams$.html" title="class in org.apache.spark.ui">JettyUtils.ServletParams$</a></li>
+<li><a href="org/apache/spark/status/api/v1/JobData.html" title="class in org.apache.spark.status.api.v1">JobData</a></li>
+<li><a href="org/apache/spark/JobExecutionStatus.html" title="enum in org.apache.spark">JobExecutionStatus</a></li>
+<li><a href="org/apache/spark/scheduler/JobResult.html" title="interface in org.apache.spark.scheduler"><span class="interfaceName">JobResult</span></a></li>
+<li><a href="org/apache/spark/JobSubmitter.html" title="interface in org.apache.spark"><span class="interfaceName">JobSubmitter</span></a></li>
+<li><a href="org/apache/spark/scheduler/JobSucceeded.html" title="class in org.apache.spark.scheduler">JobSucceeded</a></li>
+<li><a href="org/apache/spark/ml/linalg/JsonMatrixConverter.html" title="class in org.apache.spark.ml.linalg">JsonMatrixConverter</a></li>
+<li><a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></li>
+<li><a href="org/apache/spark/ml/linalg/JsonVectorConverter.html" title="class in org.apache.spark.ml.linalg">JsonVectorConverter</a></li>
+<li><a href="org/apache/spark/mllib/stat/KernelDensity.html" title="class in org.apache.spark.mllib.stat">KernelDensity</a></li>
+<li><a href="org/apache/spark/sql/KeyValueGroupedDataset.html" title="class in org.apache.spark.sql">KeyValueGroupedDataset</a></li>
+<li><a href="org/apache/spark/scheduler/local/KillTask.html" title="class in org.apache.spark.scheduler.local">KillTask</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.html" title="class in org.apache.spark.streaming.kinesis">KinesisInitialPositions</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.AtTimestamp.html" title="class in org.apache.spark.streaming.kinesis">KinesisInitialPositions.AtTimestamp</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.Latest.html" title="class in org.apache.spark.streaming.kinesis">KinesisInitialPositions.Latest</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.TrimHorizon.html" title="class in org.apache.spark.streaming.kinesis">KinesisInitialPositions.TrimHorizon</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html" title="class in org.apache.spark.streaming.kinesis">KinesisUtils</a></li>
+<li><a href="org/apache/spark/streaming/kinesis/KinesisUtilsPythonHelper.html" title="class in org.apache.spark.streaming.kinesis">KinesisUtilsPythonHelper</a></li>
+<li><a href="org/apache/spark/ml/clustering/KMeans.html" title="class in org.apache.spark.ml.clustering">KMeans</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeans.html" title="class in org.apache.spark.mllib.clustering">KMeans</a></li>
+<li><a href="org/apache/spark/mllib/util/KMeansDataGenerator.html" title="class in org.apache.spark.mllib.util">KMeansDataGenerator</a></li>
+<li><a href="org/apache/spark/ml/clustering/KMeansModel.html" title="class in org.apache.spark.ml.clustering">KMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeansModel.html" title="class in org.apache.spark.mllib.clustering">KMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeansModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.clustering">KMeansModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/clustering/KMeansModel.SaveLoadV2_0$.html" title="class in org.apache.spark.mllib.clustering">KMeansModel.SaveLoadV2_0$</a></li>
+<li><a href="org/apache/spark/ml/clustering/KMeansSummary.html" title="class in org.apache.spark.ml.clustering">KMeansSummary</a></li>
+<li><a href="org/apache/spark/ml/stat/KolmogorovSmirnovTest.html" title="class in org.apache.spark.ml.stat">KolmogorovSmirnovTest</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/KolmogorovSmirnovTest.html" title="class in org.apache.spark.mllib.stat.test">KolmogorovSmirnovTest</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/KolmogorovSmirnovTest.NullHypothesis$.html" title="class in org.apache.spark.mllib.stat.test">KolmogorovSmirnovTest.NullHypothesis$</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/KolmogorovSmirnovTestResult.html" title="class in org.apache.spark.mllib.stat.test">KolmogorovSmirnovTestResult</a></li>
+<li><a href="org/apache/spark/serializer/KryoRegistrator.html" title="interface in org.apache.spark.serializer"><span class="interfaceName">KryoRegistrator</span></a></li>
+<li><a href="org/apache/spark/serializer/KryoSerializer.html" title="class in org.apache.spark.serializer">KryoSerializer</a></li>
+<li><a href="org/apache/spark/status/KVUtils.html" title="class in org.apache.spark.status">KVUtils</a></li>
+<li><a href="org/apache/spark/mllib/optimization/L1Updater.html" title="class in org.apache.spark.mllib.optimization">L1Updater</a></li>
+<li><a href="org/apache/spark/ml/feature/LabeledPoint.html" title="class in org.apache.spark.ml.feature">LabeledPoint</a></li>
+<li><a href="org/apache/spark/mllib/regression/LabeledPoint.html" title="class in org.apache.spark.mllib.regression">LabeledPoint</a></li>
+<li><a href="org/apache/spark/graphx/lib/LabelPropagation.html" title="class in org.apache.spark.graphx.lib">LabelPropagation</a></li>
+<li><a href="org/apache/spark/mllib/regression/LassoModel.html" title="class in org.apache.spark.mllib.regression">LassoModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/LassoWithSGD.html" title="class in org.apache.spark.mllib.regression">LassoWithSGD</a></li>
+<li><a href="org/apache/spark/mllib/optimization/LBFGS.html" title="class in org.apache.spark.mllib.optimization">LBFGS</a></li>
+<li><a href="org/apache/spark/ml/clustering/LDA.html" title="class in org.apache.spark.ml.clustering">LDA</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDA.html" title="class in org.apache.spark.mllib.clustering">LDA</a></li>
+<li><a href="org/apache/spark/ml/clustering/LDAModel.html" title="class in org.apache.spark.ml.clustering">LDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDAModel.html" title="class in org.apache.spark.mllib.clustering">LDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDAOptimizer.html" title="interface in org.apache.spark.mllib.clustering"><span class="interfaceName">LDAOptimizer</span></a></li>
+<li><a href="org/apache/spark/mllib/clustering/LDAUtils.html" title="class in org.apache.spark.mllib.clustering">LDAUtils</a></li>
+<li><a href="org/apache/spark/ml/tree/LeafNode.html" title="class in org.apache.spark.ml.tree">LeafNode</a></li>
+<li><a href="org/apache/spark/mllib/optimization/LeastSquaresGradient.html" title="class in org.apache.spark.mllib.optimization">LeastSquaresGradient</a></li>
+<li><a href="org/apache/spark/util/LegacyAccumulatorWrapper.html" title="class in org.apache.spark.util">LegacyAccumulatorWrapper</a></li>
+<li><a href="org/apache/spark/sql/sources/LessThan.html" title="class in org.apache.spark.sql.sources">LessThan</a></li>
+<li><a href="org/apache/spark/sql/sources/LessThanOrEqual.html" title="class in org.apache.spark.sql.sources">LessThanOrEqual</a></li>
+<li><a href="org/apache/spark/ml/source/libsvm/LibSVMDataSource.html" title="class in org.apache.spark.ml.source.libsvm">LibSVMDataSource</a></li>
+<li><a href="org/apache/spark/mllib/util/LinearDataGenerator.html" title="class in org.apache.spark.mllib.util">LinearDataGenerator</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegression.html" title="class in org.apache.spark.ml.regression">LinearRegression</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegressionModel.html" title="class in org.apache.spark.ml.regression">LinearRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/LinearRegressionModel.html" title="class in org.apache.spark.mllib.regression">LinearRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegressionSummary.html" title="class in org.apache.spark.ml.regression">LinearRegressionSummary</a></li>
+<li><a href="org/apache/spark/ml/regression/LinearRegressionTrainingSummary.html" title="class in org.apache.spark.ml.regression">LinearRegressionTrainingSummary</a></li>
+<li><a href="org/apache/spark/mllib/regression/LinearRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression">LinearRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/ml/classification/LinearSVC.html" title="class in org.apache.spark.ml.classification">LinearSVC</a></li>
+<li><a href="org/apache/spark/ml/classification/LinearSVCModel.html" title="class in org.apache.spark.ml.classification">LinearSVCModel</a></li>
+<li><a href="org/apache/spark/status/LiveEntityHelpers.html" title="class in org.apache.spark.status">LiveEntityHelpers</a></li>
+<li><a href="org/apache/spark/status/LiveExecutor.html" title="class in org.apache.spark.status">LiveExecutor</a></li>
+<li><a href="org/apache/spark/status/LiveExecutorStageSummary.html" title="class in org.apache.spark.status">LiveExecutorStageSummary</a></li>
+<li><a href="org/apache/spark/status/LiveJob.html" title="class in org.apache.spark.status">LiveJob</a></li>
+<li><a href="org/apache/spark/status/LiveRDD.html" title="class in org.apache.spark.status">LiveRDD</a></li>
+<li><a href="org/apache/spark/status/LiveRDDDistribution.html" title="class in org.apache.spark.status">LiveRDDDistribution</a></li>
+<li><a href="org/apache/spark/status/LiveRDDPartition.html" title="class in org.apache.spark.status">LiveRDDPartition</a></li>
+<li><a href="org/apache/spark/status/LiveStage.html" title="class in org.apache.spark.status">LiveStage</a></li>
+<li><a href="org/apache/spark/status/LiveTask.html" title="class in org.apache.spark.status">LiveTask</a></li>
+<li><a href="org/apache/spark/mllib/util/Loader.html" title="interface in org.apache.spark.mllib.util"><span class="interfaceName">Loader</span></a></li>
+<li><a href="org/apache/spark/mllib/clustering/LocalKMeans.html" title="class in org.apache.spark.mllib.clustering">LocalKMeans</a></li>
+<li><a href="org/apache/spark/ml/clustering/LocalLDAModel.html" title="class in org.apache.spark.ml.clustering">LocalLDAModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/LocalLDAModel.html" title="class in org.apache.spark.mllib.clustering">LocalLDAModel</a></li>
+<li><a href="org/apache/spark/internal/Logging.html" title="interface in org.apache.spark.internal"><span class="interfaceName">Logging</span></a></li>
+<li><a href="org/apache/spark/mllib/optimization/LogisticGradient.html" title="class in org.apache.spark.mllib.optimization">LogisticGradient</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegression.html" title="class in org.apache.spark.ml.classification">LogisticRegression</a></li>
+<li><a href="org/apache/spark/mllib/util/LogisticRegressionDataGenerator.html" title="class in org.apache.spark.mllib.util">LogisticRegressionDataGenerator</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionModel.html" title="class in org.apache.spark.ml.classification">LogisticRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/LogisticRegressionModel.html" title="class in org.apache.spark.mllib.classification">LogisticRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification"><span class="interfaceName">LogisticRegressionSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionSummaryImpl.html" title="class in org.apache.spark.ml.classification">LogisticRegressionSummaryImpl</a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionTrainingSummary.html" title="interface in org.apache.spark.ml.classification"><span class="interfaceName">LogisticRegressionTrainingSummary</span></a></li>
+<li><a href="org/apache/spark/ml/classification/LogisticRegressionTrainingSummaryImpl.html" title="class in org.apache.spark.ml.classification">LogisticRegressionTrainingSummaryImpl</a></li>
+<li><a href="org/apache/spark/mllib/classification/LogisticRegressionWithLBFGS.html" title="class in org.apache.spark.mllib.classification">LogisticRegressionWithLBFGS</a></li>
+<li><a href="org/apache/spark/mllib/classification/LogisticRegressionWithSGD.html" title="class in org.apache.spark.mllib.classification">LogisticRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/LogLoss.html" title="class in org.apache.spark.mllib.tree.loss">LogLoss</a></li>
+<li><a href="org/apache/spark/mllib/random/LogNormalGenerator.html" title="class in org.apache.spark.mllib.random">LogNormalGenerator</a></li>
+<li><a href="org/apache/spark/util/LongAccumulator.html" title="class in org.apache.spark.util">LongAccumulator</a></li>
+<li><a href="org/apache/spark/ml/param/LongParam.html" title="class in org.apache.spark.ml.param">LongParam</a></li>
+<li><a href="org/apache/spark/sql/types/LongType.html" title="class in org.apache.spark.sql.types">LongType</a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/Loss.html" title="interface in org.apache.spark.mllib.tree.loss"><span class="interfaceName">Loss</span></a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/Losses.html" title="class in org.apache.spark.mllib.tree.loss">Losses</a></li>
+<li><a href="org/apache/spark/scheduler/LossReasonPending.html" title="class in org.apache.spark.scheduler">LossReasonPending</a></li>
+<li><a href="org/apache/spark/sql/LowPrioritySQLImplicits.html" title="interface in org.apache.spark.sql"><span class="interfaceName">LowPrioritySQLImplicits</span></a></li>
+<li><a href="org/apache/spark/io/LZ4CompressionCodec.html" title="class in org.apache.spark.io">LZ4CompressionCodec</a></li>
+<li><a href="org/apache/spark/io/LZFCompressionCodec.html" title="class in org.apache.spark.io">LZFCompressionCodec</a></li>
+<li><a href="org/apache/spark/api/java/function/MapFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">MapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/MapGroupsFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">MapGroupsFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/MapGroupsWithStateFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">MapGroupsWithStateFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/MapPartitionsFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">MapPartitionsFunction</span></a></li>
+<li><a href="org/apache/spark/sql/types/MapType.html" title="class in org.apache.spark.sql.types">MapType</a></li>
+<li><a href="org/apache/spark/streaming/dstream/MapWithStateDStream.html" title="class in org.apache.spark.streaming.dstream">MapWithStateDStream</a></li>
+<li><a href="org/apache/spark/ml/linalg/Matrices.html" title="class in org.apache.spark.ml.linalg">Matrices</a></li>
+<li><a href="org/apache/spark/mllib/linalg/Matrices.html" title="class in org.apache.spark.mllib.linalg">Matrices</a></li>
+<li><a href="org/apache/spark/ml/linalg/Matrix.html" title="interface in org.apache.spark.ml.linalg"><span class="interfaceName">Matrix</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/Matrix.html" title="interface in org.apache.spark.mllib.linalg"><span class="interfaceName">Matrix</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/MatrixEntry.html" title="class in org.apache.spark.mllib.linalg.distributed">MatrixEntry</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/MatrixFactorizationModel.html" title="class in org.apache.spark.mllib.recommendation">MatrixFactorizationModel</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/MatrixFactorizationModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.recommendation">MatrixFactorizationModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/linalg/MatrixImplicits.html" title="class in org.apache.spark.mllib.linalg">MatrixImplicits</a></li>
+<li><a href="org/apache/spark/ml/feature/MaxAbsScaler.html" title="class in org.apache.spark.ml.feature">MaxAbsScaler</a></li>
+<li><a href="org/apache/spark/ml/feature/MaxAbsScalerModel.html" title="class in org.apache.spark.ml.feature">MaxAbsScalerModel</a></li>
+<li><a href="org/apache/spark/storage/memory/MemoryEntry.html" title="interface in org.apache.spark.storage.memory"><span class="interfaceName">MemoryEntry</span></a></li>
+<li><a href="org/apache/spark/storage/memory/MemoryEntryBuilder.html" title="interface in org.apache.spark.storage.memory"><span class="interfaceName">MemoryEntryBuilder</span></a></li>
+<li><a href="org/apache/spark/status/api/v1/MemoryMetrics.html" title="class in org.apache.spark.status.api.v1">MemoryMetrics</a></li>
+<li><a href="org/apache/spark/util/MemoryParam.html" title="class in org.apache.spark.util">MemoryParam</a></li>
+<li><a href="org/apache/spark/ml/util/MetaAlgorithmReadWrite.html" title="class in org.apache.spark.ml.util">MetaAlgorithmReadWrite</a></li>
+<li><a href="org/apache/spark/sql/types/Metadata.html" title="class in org.apache.spark.sql.types">Metadata</a></li>
+<li><a href="org/apache/spark/sql/types/MetadataBuilder.html" title="class in org.apache.spark.sql.types">MetadataBuilder</a></li>
+<li><a href="org/apache/spark/ml/util/MetadataUtils.html" title="class in org.apache.spark.ml.util">MetadataUtils</a></li>
+<li><a href="org/apache/spark/util/MethodIdentifier.html" title="class in org.apache.spark.util">MethodIdentifier</a></li>
+<li><a href="org/apache/spark/mllib/util/MFDataGenerator.html" title="class in org.apache.spark.mllib.util">MFDataGenerator</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/MicroBatchReader.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming"><span class="interfaceName">MicroBatchReader</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/MicroBatchReadSupport.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">MicroBatchReadSupport</span></a></li>
+<li><a href="org/apache/spark/streaming/Milliseconds.html" title="class in org.apache.spark.streaming">Milliseconds</a></li>
+<li><a href="org/apache/spark/ml/feature/MinHashLSH.html" title="class in org.apache.spark.ml.feature">MinHashLSH</a></li>
+<li><a href="org/apache/spark/ml/feature/MinHashLSHModel.html" title="class in org.apache.spark.ml.feature">MinHashLSHModel</a></li>
+<li><a href="org/apache/spark/ml/feature/MinMaxScaler.html" title="class in org.apache.spark.ml.feature">MinMaxScaler</a></li>
+<li><a href="org/apache/spark/ml/feature/MinMaxScalerModel.html" title="class in org.apache.spark.ml.feature">MinMaxScalerModel</a></li>
+<li><a href="org/apache/spark/streaming/Minutes.html" title="class in org.apache.spark.streaming">Minutes</a></li>
+<li><a href="org/apache/spark/ml/util/MLFormatRegister.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">MLFormatRegister</span></a></li>
+<li><a href="org/apache/spark/mllib/rdd/MLPairRDDFunctions.html" title="class in org.apache.spark.mllib.rdd">MLPairRDDFunctions</a></li>
+<li><a href="org/apache/spark/ml/util/MLReadable.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">MLReadable</span></a></li>
+<li><a href="org/apache/spark/ml/util/MLReader.html" title="class in org.apache.spark.ml.util">MLReader</a></li>
+<li><a href="org/apache/spark/mllib/util/MLUtils.html" title="class in org.apache.spark.mllib.util">MLUtils</a></li>
+<li><a href="org/apache/spark/ml/util/MLWritable.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">MLWritable</span></a></li>
+<li><a href="org/apache/spark/ml/util/MLWriter.html" title="class in org.apache.spark.ml.util">MLWriter</a></li>
+<li><a href="org/apache/spark/ml/util/MLWriterFormat.html" title="interface in org.apache.spark.ml.util"><span class="interfaceName">MLWriterFormat</span></a></li>
+<li><a href="org/apache/spark/ml/Model.html" title="class in org.apache.spark.ml">Model</a></li>
+<li><a href="org/apache/spark/sql/jdbc/MsSqlServerDialect.html" title="class in org.apache.spark.sql.jdbc">MsSqlServerDialect</a></li>
+<li><a href="org/apache/spark/ml/evaluation/MulticlassClassificationEvaluator.html" title="class in org.apache.spark.ml.evaluation">MulticlassClassificationEvaluator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html" title="class in org.apache.spark.mllib.evaluation">MulticlassMetrics</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/MultilabelMetrics.html" title="class in org.apache.spark.mllib.evaluation">MultilabelMetrics</a></li>
+<li><a href="org/apache/spark/ml/classification/MultilayerPerceptronClassificationModel.html" title="class in org.apache.spark.ml.classification">MultilayerPerceptronClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/MultilayerPerceptronClassifier.html" title="class in org.apache.spark.ml.classification">MultilayerPerceptronClassifier</a></li>
+<li><a href="org/apache/spark/ml/stat/distribution/MultivariateGaussian.html" title="class in org.apache.spark.ml.stat.distribution">MultivariateGaussian</a></li>
+<li><a href="org/apache/spark/mllib/stat/distribution/MultivariateGaussian.html" title="class in org.apache.spark.mllib.stat.distribution">MultivariateGaussian</a></li>
+<li><a href="org/apache/spark/mllib/stat/MultivariateOnlineSummarizer.html" title="class in org.apache.spark.mllib.stat">MultivariateOnlineSummarizer</a></li>
+<li><a href="org/apache/spark/mllib/stat/MultivariateStatisticalSummary.html" title="interface in org.apache.spark.mllib.stat"><span class="interfaceName">MultivariateStatisticalSummary</span></a></li>
+<li><a href="org/apache/spark/sql/expressions/MutableAggregationBuffer.html" title="class in org.apache.spark.sql.expressions">MutableAggregationBuffer</a></li>
+<li><a href="org/apache/spark/util/MutablePair.html" title="class in org.apache.spark.util">MutablePair</a></li>
+<li><a href="org/apache/spark/util/MutableURLClassLoader.html" title="class in org.apache.spark.util">MutableURLClassLoader</a></li>
+<li><a href="org/apache/spark/sql/jdbc/MySQLDialect.html" title="class in org.apache.spark.sql.jdbc">MySQLDialect</a></li>
+<li><a href="org/apache/spark/ml/classification/NaiveBayes.html" title="class in org.apache.spark.ml.classification">NaiveBayes</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayes.html" title="class in org.apache.spark.mllib.classification">NaiveBayes</a></li>
+<li><a href="org/apache/spark/ml/classification/NaiveBayesModel.html" title="class in org.apache.spark.ml.classification">NaiveBayesModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayesModel.html" title="class in org.apache.spark.mllib.classification">NaiveBayesModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayesModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.classification">NaiveBayesModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/classification/NaiveBayesModel.SaveLoadV2_0$.html" title="class in org.apache.spark.mllib.classification">NaiveBayesModel.SaveLoadV2_0$</a></li>
+<li><a href="org/apache/spark/NarrowDependency.html" title="class in org.apache.spark">NarrowDependency</a></li>
+<li><a href="org/apache/spark/rdd/NewHadoopRDD.html" title="class in org.apache.spark.rdd">NewHadoopRDD</a></li>
+<li><a href="org/apache/spark/rdd/NewHadoopRDD.NewHadoopMapPartitionsWithSplitRDD$.html" title="class in org.apache.spark.rdd">NewHadoopRDD.NewHadoopMapPartitionsWithSplitRDD$</a></li>
+<li><a href="org/apache/spark/ml/feature/NGram.html" title="class in org.apache.spark.ml.feature">NGram</a></li>
+<li><a href="org/apache/spark/io/NioBufferedFileInputStream.html" title="class in org.apache.spark.io">NioBufferedFileInputStream</a></li>
+<li><a href="org/apache/spark/mllib/optimization/NNLS.html" title="class in org.apache.spark.mllib.optimization">NNLS</a></li>
+<li><a href="org/apache/spark/mllib/optimization/NNLS.Workspace.html" title="class in org.apache.spark.mllib.optimization">NNLS.Workspace</a></li>
+<li><a href="org/apache/spark/ml/tree/Node.html" title="class in org.apache.spark.ml.tree">Node</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/Node.html" title="class in org.apache.spark.mllib.tree.model">Node</a></li>
+<li><a href="org/apache/spark/ml/attribute/NominalAttribute.html" title="class in org.apache.spark.ml.attribute">NominalAttribute</a></li>
+<li><a href="org/apache/spark/sql/jdbc/NoopDialect.html" title="class in org.apache.spark.sql.jdbc">NoopDialect</a></li>
+<li><a href="org/apache/spark/ml/feature/Normalizer.html" title="class in org.apache.spark.ml.feature">Normalizer</a></li>
+<li><a href="org/apache/spark/mllib/feature/Normalizer.html" title="class in org.apache.spark.mllib.feature">Normalizer</a></li>
+<li><a href="org/apache/spark/sql/sources/Not.html" title="class in org.apache.spark.sql.sources">Not</a></li>
+<li><a href="org/apache/spark/sql/types/NullType.html" title="class in org.apache.spark.sql.types">NullType</a></li>
+<li><a href="org/apache/spark/ml/attribute/NumericAttribute.html" title="class in org.apache.spark.ml.attribute">NumericAttribute</a></li>
+<li><a href="org/apache/spark/mllib/util/NumericParser.html" title="class in org.apache.spark.mllib.util">NumericParser</a></li>
+<li><a href="org/apache/spark/sql/types/NumericType.html" title="class in org.apache.spark.sql.types">NumericType</a></li>
+<li><a href="org/apache/spark/sql/types/ObjectType.html" title="class in org.apache.spark.sql.types">ObjectType</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/Offset.html" title="class in org.apache.spark.sql.sources.v2.reader.streaming">Offset</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoder.html" title="class in org.apache.spark.ml.feature">OneHotEncoder</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoderCommon.html" title="class in org.apache.spark.ml.feature">OneHotEncoderCommon</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoderEstimator.html" title="class in org.apache.spark.ml.feature">OneHotEncoderEstimator</a></li>
+<li><a href="org/apache/spark/ml/feature/OneHotEncoderModel.html" title="class in org.apache.spark.ml.feature">OneHotEncoderModel</a></li>
+<li><a href="org/apache/spark/OneToOneDependency.html" title="class in org.apache.spark">OneToOneDependency</a></li>
+<li><a href="org/apache/spark/ml/classification/OneVsRest.html" title="class in org.apache.spark.ml.classification">OneVsRest</a></li>
+<li><a href="org/apache/spark/ml/classification/OneVsRestModel.html" title="class in org.apache.spark.ml.classification">OneVsRestModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/OnlineLDAOptimizer.html" title="class in org.apache.spark.mllib.clustering">OnlineLDAOptimizer</a></li>
+<li><a href="org/apache/spark/rpc/netty/OnStart.html" title="class in org.apache.spark.rpc.netty">OnStart</a></li>
+<li><a href="org/apache/spark/rpc/netty/OnStop.html" title="class in org.apache.spark.rpc.netty">OnStop</a></li>
+<li><a href="org/apache/spark/mllib/optimization/Optimizer.html" title="interface in org.apache.spark.mllib.optimization"><span class="interfaceName">Optimizer</span></a></li>
+<li><a href="org/apache/spark/api/java/Optional.html" title="class in org.apache.spark.api.java">Optional</a></li>
+<li><a href="org/apache/spark/sql/sources/Or.html" title="class in org.apache.spark.sql.sources">Or</a></li>
+<li><a href="org/apache/spark/sql/jdbc/OracleDialect.html" title="class in org.apache.spark.sql.jdbc">OracleDialect</a></li>
+<li><a href="org/apache/spark/sql/hive/orc/OrcFileFormat.html" title="class in org.apache.spark.sql.hive.orc">OrcFileFormat</a></li>
+<li><a href="org/apache/spark/sql/hive/orc/OrcFileOperator.html" title="class in org.apache.spark.sql.hive.orc">OrcFileOperator</a></li>
+<li><a href="org/apache/spark/sql/hive/orc/OrcFilters.html" title="class in org.apache.spark.sql.hive.orc">OrcFilters</a></li>
+<li><a href="org/apache/spark/rdd/OrderedRDDFunctions.html" title="class in org.apache.spark.rdd">OrderedRDDFunctions</a></li>
+<li><a href="org/apache/spark/scheduler/OutputCommitCoordinationMessage.html" title="interface in org.apache.spark.scheduler"><span class="interfaceName">OutputCommitCoordinationMessage</span></a></li>
+<li><a href="org/apache/spark/status/api/v1/OutputMetricDistributions.html" title="class in org.apache.spark.status.api.v1">OutputMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/OutputMetrics.html" title="class in org.apache.spark.status.api.v1">OutputMetrics</a></li>
+<li><a href="org/apache/spark/sql/streaming/OutputMode.html" title="class in org.apache.spark.sql.streaming">OutputMode</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/OutputOperationInfo.html" title="class in org.apache.spark.status.api.v1.streaming">OutputOperationInfo</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/OutputOperationInfo.html" title="class in org.apache.spark.streaming.scheduler">OutputOperationInfo</a></li>
+<li><a href="org/apache/spark/graphx/lib/PageRank.html" title="class in org.apache.spark.graphx.lib">PageRank</a></li>
+<li><a href="org/apache/spark/streaming/dstream/PairDStreamFunctions.html" title="class in org.apache.spark.streaming.dstream">PairDStreamFunctions</a></li>
+<li><a href="org/apache/spark/api/java/function/PairFlatMapFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">PairFlatMapFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/PairFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">PairFunction</span></a></li>
+<li><a href="org/apache/spark/rdd/PairRDDFunctions.html" title="class in org.apache.spark.rdd">PairRDDFunctions</a></li>
+<li><a href="org/apache/spark/api/r/PairwiseRRDD.html" title="class in org.apache.spark.api.r">PairwiseRRDD</a></li>
+<li><a href="org/apache/spark/ml/param/Param.html" title="class in org.apache.spark.ml.param">Param</a></li>
+<li><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></li>
+<li><a href="org/apache/spark/ml/param/ParamMap.html" title="class in org.apache.spark.ml.param">ParamMap</a></li>
+<li><a href="org/apache/spark/ml/param/ParamPair.html" title="class in org.apache.spark.ml.param">ParamPair</a></li>
+<li><a href="org/apache/spark/ml/param/Params.html" title="interface in org.apache.spark.ml.param"><span class="interfaceName">Params</span></a></li>
+<li><a href="org/apache/spark/ml/param/ParamValidators.html" title="class in org.apache.spark.ml.param">ParamValidators</a></li>
+<li><a href="org/apache/spark/util/ParentClassLoader.html" title="class in org.apache.spark.util">ParentClassLoader</a></li>
+<li><a href="org/apache/spark/partial/PartialResult.html" title="class in org.apache.spark.partial">PartialResult</a></li>
+<li><a href="org/apache/spark/Partition.html" title="interface in org.apache.spark"><span class="interfaceName">Partition</span></a></li>
+<li><a href="org/apache/spark/rdd/PartitionCoalescer.html" title="interface in org.apache.spark.rdd"><span class="interfaceName">PartitionCoalescer</span></a></li>
+<li><a href="org/apache/spark/Partitioner.html" title="class in org.apache.spark">Partitioner</a></li>
+<li><a href="org/apache/spark/rdd/PartitionGroup.html" title="class in org.apache.spark.rdd">PartitionGroup</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/partitioning/Partitioning.html" title="interface in org.apache.spark.sql.sources.v2.reader.partitioning"><span class="interfaceName">Partitioning</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/streaming/PartitionOffset.html" title="interface in org.apache.spark.sql.sources.v2.reader.streaming"><span class="interfaceName">PartitionOffset</span></a></li>
+<li><a href="org/apache/spark/rdd/PartitionPruningRDD.html" title="class in org.apache.spark.rdd">PartitionPruningRDD</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.html" title="interface in org.apache.spark.graphx"><span class="interfaceName">PartitionStrategy</span></a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.CanonicalRandomVertexCut$.html" title="class in org.apache.spark.graphx">PartitionStrategy.CanonicalRandomVertexCut$</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.EdgePartition1D$.html" title="class in org.apache.spark.graphx">PartitionStrategy.EdgePartition1D$</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.EdgePartition2D$.html" title="class in org.apache.spark.graphx">PartitionStrategy.EdgePartition2D$</a></li>
+<li><a href="org/apache/spark/graphx/PartitionStrategy.RandomVertexCut$.html" title="class in org.apache.spark.graphx">PartitionStrategy.RandomVertexCut$</a></li>
+<li><a href="org/apache/spark/ml/feature/PCA.html" title="class in org.apache.spark.ml.feature">PCA</a></li>
+<li><a href="org/apache/spark/mllib/feature/PCA.html" title="class in org.apache.spark.mllib.feature">PCA</a></li>
+<li><a href="org/apache/spark/ml/feature/PCAModel.html" title="class in org.apache.spark.ml.feature">PCAModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/PCAModel.html" title="class in org.apache.spark.mllib.feature">PCAModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/PCAUtil.html" title="class in org.apache.spark.mllib.feature">PCAUtil</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/PearsonCorrelation.html" title="class in org.apache.spark.mllib.stat.correlation">PearsonCorrelation</a></li>
+<li><a href="org/apache/spark/ml/Pipeline.html" title="class in org.apache.spark.ml">Pipeline</a></li>
+<li><a href="org/apache/spark/ml/Pipeline.SharedReadWrite$.html" title="class in org.apache.spark.ml">Pipeline.SharedReadWrite$</a></li>
+<li><a href="org/apache/spark/ml/PipelineModel.html" title="class in org.apache.spark.ml">PipelineModel</a></li>
+<li><a href="org/apache/spark/ml/PipelineStage.html" title="class in org.apache.spark.ml">PipelineStage</a></li>
+<li><a href="org/apache/spark/mllib/pmml/PMMLExportable.html" title="interface in org.apache.spark.mllib.pmml"><span class="interfaceName">PMMLExportable</span></a></li>
+<li><a href="org/apache/spark/ml/clustering/PMMLKMeansModelWriter.html" title="class in org.apache.spark.ml.clustering">PMMLKMeansModelWriter</a></li>
+<li><a href="org/apache/spark/ml/regression/PMMLLinearRegressionModelWriter.html" title="class in org.apache.spark.ml.regression">PMMLLinearRegressionModelWriter</a></li>
+<li><a href="org/apache/spark/mllib/pmml/export/PMMLModelExportFactory.html" title="class in org.apache.spark.mllib.pmml.export">PMMLModelExportFactory</a></li>
+<li><a href="org/apache/spark/util/random/PoissonBounds.html" title="class in org.apache.spark.util.random">PoissonBounds</a></li>
+<li><a href="org/apache/spark/mllib/random/PoissonGenerator.html" title="class in org.apache.spark.mllib.random">PoissonGenerator</a></li>
+<li><a href="org/apache/spark/util/random/PoissonSampler.html" title="class in org.apache.spark.util.random">PoissonSampler</a></li>
+<li><a href="org/apache/spark/ml/feature/PolynomialExpansion.html" title="class in org.apache.spark.ml.feature">PolynomialExpansion</a></li>
+<li><a href="org/apache/spark/input/PortableDataStream.html" title="class in org.apache.spark.input">PortableDataStream</a></li>
+<li><a href="org/apache/spark/sql/jdbc/PostgresDialect.html" title="class in org.apache.spark.sql.jdbc">PostgresDialect</a></li>
+<li><a href="org/apache/spark/ml/clustering/PowerIterationClustering.html" title="class in org.apache.spark.ml.clustering">PowerIterationClustering</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClustering</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClustering.Assignment</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment$.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClustering.Assignment$</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClusteringModel.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClusteringModel</a></li>
+<li><a href="org/apache/spark/mllib/clustering/PowerIterationClusteringModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClusteringModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/binary/Precision.html" title="class in org.apache.spark.mllib.evaluation.binary">Precision</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/Predict.html" title="class in org.apache.spark.mllib.tree.model">Predict</a></li>
+<li><a href="org/apache/spark/ml/PredictionModel.html" title="class in org.apache.spark.ml">PredictionModel</a></li>
+<li><a href="org/apache/spark/ml/Predictor.html" title="class in org.apache.spark.ml">Predictor</a></li>
+<li><a href="org/apache/spark/ml/fpm/PrefixSpan.html" title="class in org.apache.spark.ml.fpm">PrefixSpan</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.html" title="class in org.apache.spark.mllib.fpm">PrefixSpan</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.FreqSequence.html" title="class in org.apache.spark.mllib.fpm">PrefixSpan.FreqSequence</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.Postfix$.html" title="class in org.apache.spark.mllib.fpm">PrefixSpan.Postfix$</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpan.Prefix$.html" title="class in org.apache.spark.mllib.fpm">PrefixSpan.Prefix$</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpanModel.html" title="class in org.apache.spark.mllib.fpm">PrefixSpanModel</a></li>
+<li><a href="org/apache/spark/mllib/fpm/PrefixSpanModel.SaveLoadV1_0$.html" title="class in org.apache.spark.mllib.fpm">PrefixSpanModel.SaveLoadV1_0$</a></li>
+<li><a href="org/apache/spark/graphx/Pregel.html" title="class in org.apache.spark.graphx">Pregel</a></li>
+<li><a href="org/apache/spark/ml/classification/ProbabilisticClassificationModel.html" title="class in org.apache.spark.ml.classification">ProbabilisticClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/ProbabilisticClassifier.html" title="class in org.apache.spark.ml.classification">ProbabilisticClassifier</a></li>
+<li><a href="org/apache/spark/sql/streaming/ProcessingTime.html" title="class in org.apache.spark.sql.streaming">ProcessingTime</a></li>
+<li><a href="org/apache/spark/sql/sources/PrunedFilteredScan.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">PrunedFilteredScan</span></a></li>
+<li><a href="org/apache/spark/sql/sources/PrunedScan.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">PrunedScan</span></a></li>
+<li><a href="org/apache/spark/util/random/Pseudorandom.html" title="interface in org.apache.spark.util.random"><span class="interfaceName">Pseudorandom</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/QRDecomposition.html" title="class in org.apache.spark.mllib.linalg">QRDecomposition</a></li>
+<li><a href="org/apache/spark/ml/feature/QuantileDiscretizer.html" title="class in org.apache.spark.ml.feature">QuantileDiscretizer</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/QuantileStrategy.html" title="class in org.apache.spark.mllib.tree.configuration">QuantileStrategy</a></li>
+<li><a href="org/apache/spark/sql/util/QueryExecutionListener.html" title="interface in org.apache.spark.sql.util"><span class="interfaceName">QueryExecutionListener</span></a></li>
+<li><a href="org/apache/spark/storage/RandomBlockReplicationPolicy.html" title="class in org.apache.spark.storage">RandomBlockReplicationPolicy</a></li>
+<li><a href="org/apache/spark/mllib/random/RandomDataGenerator.html" title="interface in org.apache.spark.mllib.random"><span class="interfaceName">RandomDataGenerator</span></a></li>
+<li><a href="org/apache/spark/ml/tree/impl/RandomForest.html" title="class in org.apache.spark.ml.tree.impl">RandomForest</a></li>
+<li><a href="org/apache/spark/mllib/tree/RandomForest.html" title="class in org.apache.spark.mllib.tree">RandomForest</a></li>
+<li><a href="org/apache/spark/ml/classification/RandomForestClassificationModel.html" title="class in org.apache.spark.ml.classification">RandomForestClassificationModel</a></li>
+<li><a href="org/apache/spark/ml/classification/RandomForestClassifier.html" title="class in org.apache.spark.ml.classification">RandomForestClassifier</a></li>
+<li><a href="org/apache/spark/mllib/tree/model/RandomForestModel.html" title="class in org.apache.spark.mllib.tree.model">RandomForestModel</a></li>
+<li><a href="org/apache/spark/ml/regression/RandomForestRegressionModel.html" title="class in org.apache.spark.ml.regression">RandomForestRegressionModel</a></li>
+<li><a href="org/apache/spark/ml/regression/RandomForestRegressor.html" title="class in org.apache.spark.ml.regression">RandomForestRegressor</a></li>
+<li><a href="org/apache/spark/mllib/random/RandomRDDs.html" title="class in org.apache.spark.mllib.random">RandomRDDs</a></li>
+<li><a href="org/apache/spark/util/random/RandomSampler.html" title="interface in org.apache.spark.util.random"><span class="interfaceName">RandomSampler</span></a></li>
+<li><a href="org/apache/spark/RangeDependency.html" title="class in org.apache.spark">RangeDependency</a></li>
+<li><a href="org/apache/spark/RangePartitioner.html" title="class in org.apache.spark">RangePartitioner</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/RankingMetrics.html" title="class in org.apache.spark.mllib.evaluation">RankingMetrics</a></li>
+<li><a href="org/apache/spark/mllib/recommendation/Rating.html" title="class in org.apache.spark.mllib.recommendation">Rating</a></li>
+<li><a href="org/apache/spark/streaming/util/RawTextHelper.html" title="class in org.apache.spark.streaming.util">RawTextHelper</a></li>
+<li><a href="org/apache/spark/streaming/util/RawTextSender.html" title="class in org.apache.spark.streaming.util">RawTextSender</a></li>
+<li><a href="org/apache/spark/api/r/RBackendAuthHandler.html" title="class in org.apache.spark.api.r">RBackendAuthHandler</a></li>
+<li><a href="org/apache/spark/rdd/RDD.html" title="class in org.apache.spark.rdd">RDD</a></li>
+<li><a href="org/apache/spark/rdd/RDDBarrier.html" title="class in org.apache.spark.rdd">RDDBarrier</a></li>
+<li><a href="org/apache/spark/storage/RDDBlockId.html" title="class in org.apache.spark.storage">RDDBlockId</a></li>
+<li><a href="org/apache/spark/status/api/v1/RDDDataDistribution.html" title="class in org.apache.spark.status.api.v1">RDDDataDistribution</a></li>
+<li><a href="org/apache/spark/mllib/rdd/RDDFunctions.html" title="class in org.apache.spark.mllib.rdd">RDDFunctions</a></li>
+<li><a href="org/apache/spark/storage/RDDInfo.html" title="class in org.apache.spark.storage">RDDInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/RDDPartitionInfo.html" title="class in org.apache.spark.status.api.v1">RDDPartitionInfo</a></li>
+<li><a href="org/apache/spark/status/RDDPartitionSeq.html" title="class in org.apache.spark.status">RDDPartitionSeq</a></li>
+<li><a href="org/apache/spark/status/api/v1/RDDStorageInfo.html" title="class in org.apache.spark.status.api.v1">RDDStorageInfo</a></li>
+<li><a href="org/apache/spark/storage/ReadableChannelFileRegion.html" title="class in org.apache.spark.storage">ReadableChannelFileRegion</a></li>
+<li><a href="org/apache/spark/io/ReadAheadInputStream.html" title="class in org.apache.spark.io">ReadAheadInputStream</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/ReadSupport.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">ReadSupport</span></a></li>
+<li><a href="org/apache/spark/mllib/evaluation/binary/Recall.html" title="class in org.apache.spark.mllib.evaluation.binary">Recall</a></li>
+<li><a href="org/apache/spark/streaming/receiver/Receiver.html" title="class in org.apache.spark.streaming.receiver">Receiver</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/ReceiverInfo.html" title="class in org.apache.spark.status.api.v1.streaming">ReceiverInfo</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/ReceiverInfo.html" title="class in org.apache.spark.streaming.scheduler">ReceiverInfo</a></li>
+<li><a href="org/apache/spark/streaming/dstream/ReceiverInputDStream.html" title="class in org.apache.spark.streaming.dstream">ReceiverInputDStream</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/ReceiverState.html" title="class in org.apache.spark.streaming.scheduler">ReceiverState</a></li>
+<li><a href="org/apache/spark/ml/image/RecursiveFlag.html" title="class in org.apache.spark.ml.image">RecursiveFlag</a></li>
+<li><a href="org/apache/spark/api/java/function/ReduceFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">ReduceFunction</span></a></li>
+<li><a href="org/apache/spark/ml/feature/RegexTokenizer.html" title="class in org.apache.spark.ml.feature">RegexTokenizer</a></li>
+<li><a href="org/apache/spark/ml/evaluation/RegressionEvaluator.html" title="class in org.apache.spark.ml.evaluation">RegressionEvaluator</a></li>
+<li><a href="org/apache/spark/mllib/evaluation/RegressionMetrics.html" title="class in org.apache.spark.mllib.evaluation">RegressionMetrics</a></li>
+<li><a href="org/apache/spark/ml/regression/RegressionModel.html" title="class in org.apache.spark.ml.regression">RegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/RegressionModel.html" title="interface in org.apache.spark.mllib.regression"><span class="interfaceName">RegressionModel</span></a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.CubeType$.html" title="class in org.apache.spark.sql">RelationalGroupedDataset.CubeType$</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.GroupByType$.html" title="class in org.apache.spark.sql">RelationalGroupedDataset.GroupByType$</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.PivotType$.html" title="class in org.apache.spark.sql">RelationalGroupedDataset.PivotType$</a></li>
+<li><a href="org/apache/spark/sql/RelationalGroupedDataset.RollupType$.html" title="class in org.apache.spark.sql">RelationalGroupedDataset.RollupType$</a></li>
+<li><a href="org/apache/spark/sql/hive/RelationConversions.html" title="class in org.apache.spark.sql.hive">RelationConversions</a></li>
+<li><a href="org/apache/spark/sql/sources/RelationProvider.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">RelationProvider</span></a></li>
+<li><a href="org/apache/spark/sql/hive/ResolveHiveSerdeTable.html" title="class in org.apache.spark.sql.hive">ResolveHiveSerdeTable</a></li>
+<li><a href="org/apache/spark/scheduler/ResubmitFailedStages.html" title="class in org.apache.spark.scheduler">ResubmitFailedStages</a></li>
+<li><a href="org/apache/spark/Resubmitted.html" title="class in org.apache.spark">Resubmitted</a></li>
+<li><a href="org/apache/spark/util/ReturnStatementFinder.html" title="class in org.apache.spark.util">ReturnStatementFinder</a></li>
+<li><a href="org/apache/spark/scheduler/local/ReviveOffers.html" title="class in org.apache.spark.scheduler.local">ReviveOffers</a></li>
+<li><a href="org/apache/spark/ml/feature/RFormula.html" title="class in org.apache.spark.ml.feature">RFormula</a></li>
+<li><a href="org/apache/spark/ml/feature/RFormulaModel.html" title="class in org.apache.spark.ml.feature">RFormulaModel</a></li>
+<li><a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></li>
+<li><a href="org/apache/spark/mllib/regression/RidgeRegressionModel.html" title="class in org.apache.spark.mllib.regression">RidgeRegressionModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/RidgeRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression">RidgeRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/sql/Row.html" title="interface in org.apache.spark.sql"><span class="interfaceName">Row</span></a></li>
+<li><a href="org/apache/spark/sql/RowFactory.html" title="class in org.apache.spark.sql">RowFactory</a></li>
+<li><a href="org/apache/spark/mllib/linalg/distributed/RowMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed">RowMatrix</a></li>
+<li><a href="org/apache/spark/util/RpcUtils.html" title="class in org.apache.spark.util">RpcUtils</a></li>
+<li><a href="org/apache/spark/api/r/RRDD.html" title="class in org.apache.spark.api.r">RRDD</a></li>
+<li><a href="org/apache/spark/api/r/RRunnerModes.html" title="class in org.apache.spark.api.r">RRunnerModes</a></li>
+<li><a href="org/apache/spark/sql/RuntimeConfig.html" title="class in org.apache.spark.sql">RuntimeConfig</a></li>
+<li><a href="org/apache/spark/status/api/v1/RuntimeInfo.html" title="class in org.apache.spark.status.api.v1">RuntimeInfo</a></li>
+<li><a href="org/apache/spark/scheduler/RuntimePercentage.html" title="class in org.apache.spark.scheduler">RuntimePercentage</a></li>
+<li><a href="org/apache/spark/api/r/RUtils.html" title="class in org.apache.spark.api.r">RUtils</a></li>
+<li><a href="org/apache/spark/ml/r/RWrappers.html" title="class in org.apache.spark.ml.r">RWrappers</a></li>
+<li><a href="org/apache/spark/ml/r/RWrapperUtils.html" title="class in org.apache.spark.ml.r">RWrapperUtils</a></li>
+<li><a href="org/apache/spark/ml/image/SamplePathFilter.html" title="class in org.apache.spark.ml.image">SamplePathFilter</a></li>
+<li><a href="org/apache/spark/util/random/SamplingUtils.html" title="class in org.apache.spark.util.random">SamplingUtils</a></li>
+<li><a href="org/apache/spark/mllib/util/Saveable.html" title="interface in org.apache.spark.mllib.util"><span class="interfaceName">Saveable</span></a></li>
+<li><a href="org/apache/spark/sql/SaveMode.html" title="enum in org.apache.spark.sql">SaveMode</a></li>
+<li><a href="org/apache/spark/scheduler/cluster/SchedulerBackendUtils.html" title="class in org.apache.spark.scheduler.cluster">SchedulerBackendUtils</a></li>
+<li><a href="org/apache/spark/status/SchedulerPool.html" title="class in org.apache.spark.status">SchedulerPool</a></li>
+<li><a href="org/apache/spark/scheduler/SchedulingMode.html" title="class in org.apache.spark.scheduler">SchedulingMode</a></li>
+<li><a href="org/apache/spark/sql/sources/SchemaRelationProvider.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">SchemaRelationProvider</span></a></li>
+<li><a href="org/apache/spark/ml/util/SchemaUtils.html" title="class in org.apache.spark.ml.util">SchemaUtils</a></li>
+<li><a href="org/apache/spark/sql/util/SchemaUtils.html" title="class in org.apache.spark.sql.util">SchemaUtils</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html" title="class in org.apache.spark.sql.hive.execution">ScriptTransformationExec</a></li>
+<li><a href="org/apache/spark/sql/hive/execution/ScriptTransformationWriterThread.html" title="class in org.apache.spark.sql.hive.execution">ScriptTransformationWriterThread</a></li>
+<li><a href="org/apache/spark/streaming/Seconds.html" title="class in org.apache.spark.streaming">Seconds</a></li>
+<li><a href="org/apache/spark/rdd/SequenceFileRDDFunctions.html" title="class in org.apache.spark.rdd">SequenceFileRDDFunctions</a></li>
+<li><a href="org/apache/spark/api/r/SerDe.html" title="class in org.apache.spark.api.r">SerDe</a></li>
+<li><a href="org/apache/spark/SerializableWritable.html" title="class in org.apache.spark">SerializableWritable</a></li>
+<li><a href="org/apache/spark/serializer/SerializationDebugger.html" title="class in org.apache.spark.serializer">SerializationDebugger</a></li>
+<li><a href="org/apache/spark/serializer/SerializationDebugger.ObjectStreamClassMethods.html" title="class in org.apache.spark.serializer">SerializationDebugger.ObjectStreamClassMethods</a></li>
+<li><a href="org/apache/spark/serializer/SerializationDebugger.ObjectStreamClassMethods$.html" title="class in org.apache.spark.serializer">SerializationDebugger.ObjectStreamClassMethods$</a></li>
+<li><a href="org/apache/spark/api/r/SerializationFormats.html" title="class in org.apache.spark.api.r">SerializationFormats</a></li>
+<li><a href="org/apache/spark/serializer/SerializationStream.html" title="class in org.apache.spark.serializer">SerializationStream</a></li>
+<li><a href="org/apache/spark/storage/memory/SerializedMemoryEntry.html" title="class in org.apache.spark.storage.memory">SerializedMemoryEntry</a></li>
+<li><a href="org/apache/spark/storage/memory/SerializedValuesHolder.html" title="class in org.apache.spark.storage.memory">SerializedValuesHolder</a></li>
+<li><a href="org/apache/spark/serializer/Serializer.html" title="class in org.apache.spark.serializer">Serializer</a></li>
+<li><a href="org/apache/spark/serializer/SerializerInstance.html" title="class in org.apache.spark.serializer">SerializerInstance</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/SessionConfigSupport.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">SessionConfigSupport</span></a></li>
+<li><a href="org/apache/spark/ml/param/shared/SharedParamsCodeGen.html" title="class in org.apache.spark.ml.param.shared">SharedParamsCodeGen</a></li>
+<li><a href="org/apache/spark/graphx/lib/ShortestPaths.html" title="class in org.apache.spark.graphx.lib">ShortestPaths</a></li>
+<li><a href="org/apache/spark/sql/types/ShortType.html" title="class in org.apache.spark.sql.types">ShortType</a></li>
+<li><a href="org/apache/spark/storage/ShuffleBlockId.html" title="class in org.apache.spark.storage">ShuffleBlockId</a></li>
+<li><a href="org/apache/spark/storage/ShuffleDataBlockId.html" title="class in org.apache.spark.storage">ShuffleDataBlockId</a></li>
+<li><a href="org/apache/spark/ShuffleDependency.html" title="class in org.apache.spark">ShuffleDependency</a></li>
+<li><a href="org/apache/spark/rdd/ShuffledRDD.html" title="class in org.apache.spark.rdd">ShuffledRDD</a></li>
+<li><a href="org/apache/spark/storage/ShuffleIndexBlockId.html" title="class in org.apache.spark.storage">ShuffleIndexBlockId</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleReadMetricDistributions.html" title="class in org.apache.spark.status.api.v1">ShuffleReadMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleReadMetrics.html" title="class in org.apache.spark.status.api.v1">ShuffleReadMetrics</a></li>
+<li><a href="org/apache/spark/ShuffleStatus.html" title="class in org.apache.spark">ShuffleStatus</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleWriteMetricDistributions.html" title="class in org.apache.spark.status.api.v1">ShuffleWriteMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/ShuffleWriteMetrics.html" title="class in org.apache.spark.status.api.v1">ShuffleWriteMetrics</a></li>
+<li><a href="org/apache/spark/util/ShutdownHookManager.html" title="class in org.apache.spark.util">ShutdownHookManager</a></li>
+<li><a href="org/apache/spark/util/SignalUtils.html" title="class in org.apache.spark.util">SignalUtils</a></li>
+<li><a href="org/apache/spark/SimpleFutureAction.html" title="class in org.apache.spark">SimpleFutureAction</a></li>
+<li><a href="org/apache/spark/mllib/optimization/SimpleUpdater.html" title="class in org.apache.spark.mllib.optimization">SimpleUpdater</a></li>
+<li><a href="org/apache/spark/mllib/linalg/SingularValueDecomposition.html" title="class in org.apache.spark.mllib.linalg">SingularValueDecomposition</a></li>
+<li><a href="org/apache/spark/sql/streaming/SinkProgress.html" title="class in org.apache.spark.sql.streaming">SinkProgress</a></li>
+<li><a href="org/apache/spark/util/SizeEstimator.html" title="class in org.apache.spark.util">SizeEstimator</a></li>
+<li><a href="org/apache/spark/io/SnappyCompressionCodec.html" title="class in org.apache.spark.io">SnappyCompressionCodec</a></li>
+<li><a href="org/apache/spark/io/SnappyOutputStreamWrapper.html" title="class in org.apache.spark.io">SnappyOutputStreamWrapper</a></li>
+<li><a href="org/apache/spark/sql/streaming/SourceProgress.html" title="class in org.apache.spark.sql.streaming">SourceProgress</a></li>
+<li><a href="org/apache/spark/launcher/SparkAppHandle.html" title="interface in org.apache.spark.launcher"><span class="interfaceName">SparkAppHandle</span></a></li>
+<li><a href="org/apache/spark/launcher/SparkAppHandle.Listener.html" title="interface in org.apache.spark.launcher"><span class="interfaceName">SparkAppHandle.Listener</span></a></li>
+<li><a href="org/apache/spark/launcher/SparkAppHandle.State.html" title="enum in org.apache.spark.launcher">SparkAppHandle.State</a></li>
+<li><a href="org/apache/spark/SparkConf.html" title="class in org.apache.spark">SparkConf</a></li>
+<li><a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></li>
+<li><a href="org/apache/spark/SparkEnv.html" title="class in org.apache.spark">SparkEnv</a></li>
+<li><a href="org/apache/spark/SparkException.html" title="class in org.apache.spark">SparkException</a></li>
+<li><a href="org/apache/spark/SparkExecutorInfo.html" title="interface in org.apache.spark"><span class="interfaceName">SparkExecutorInfo</span></a></li>
+<li><a href="org/apache/spark/SparkExecutorInfoImpl.html" title="class in org.apache.spark">SparkExecutorInfoImpl</a></li>
+<li><a href="org/apache/spark/util/SparkExitCode.html" title="class in org.apache.spark.util">SparkExitCode</a></li>
+<li><a href="org/apache/spark/SparkFiles.html" title="class in org.apache.spark">SparkFiles</a></li>
+<li><a href="org/apache/spark/SparkFirehoseListener.html" title="class in org.apache.spark">SparkFirehoseListener</a></li>
+<li><a href="org/apache/spark/mapred/SparkHadoopMapRedUtil.html" title="class in org.apache.spark.mapred">SparkHadoopMapRedUtil</a></li>
+<li><a href="org/apache/spark/internal/io/SparkHadoopWriter.html" title="class in org.apache.spark.internal.io">SparkHadoopWriter</a></li>
+<li><a href="org/apache/spark/internal/io/SparkHadoopWriterUtils.html" title="class in org.apache.spark.internal.io">SparkHadoopWriterUtils</a></li>
+<li><a href="org/apache/spark/SparkJobInfo.html" title="interface in org.apache.spark"><span class="interfaceName">SparkJobInfo</span></a></li>
+<li><a href="org/apache/spark/SparkJobInfoImpl.html" title="class in org.apache.spark">SparkJobInfoImpl</a></li>
+<li><a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListener.html" title="class in org.apache.spark.scheduler">SparkListener</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerApplicationEnd.html" title="class in org.apache.spark.scheduler">SparkListenerApplicationEnd</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html" title="class in org.apache.spark.scheduler">SparkListenerApplicationStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerBlockManagerAdded.html" title="class in org.apache.spark.scheduler">SparkListenerBlockManagerAdded</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerBlockManagerRemoved.html" title="class in org.apache.spark.scheduler">SparkListenerBlockManagerRemoved</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerBlockUpdated.html" title="class in org.apache.spark.scheduler">SparkListenerBlockUpdated</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerEnvironmentUpdate.html" title="class in org.apache.spark.scheduler">SparkListenerEnvironmentUpdate</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerEvent.html" title="interface in org.apache.spark.scheduler"><span class="interfaceName">SparkListenerEvent</span></a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorAdded.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorAdded</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorBlacklisted.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorBlacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorBlacklistedForStage.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorBlacklistedForStage</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorMetricsUpdate.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorMetricsUpdate</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorRemoved.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorRemoved</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerExecutorUnblacklisted.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorUnblacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerJobEnd.html" title="class in org.apache.spark.scheduler">SparkListenerJobEnd</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerJobStart.html" title="class in org.apache.spark.scheduler">SparkListenerJobStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerLogStart.html" title="class in org.apache.spark.scheduler">SparkListenerLogStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerNodeBlacklisted.html" title="class in org.apache.spark.scheduler">SparkListenerNodeBlacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerNodeBlacklistedForStage.html" title="class in org.apache.spark.scheduler">SparkListenerNodeBlacklistedForStage</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerNodeUnblacklisted.html" title="class in org.apache.spark.scheduler">SparkListenerNodeUnblacklisted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerSpeculativeTaskSubmitted.html" title="class in org.apache.spark.scheduler">SparkListenerSpeculativeTaskSubmitted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerStageCompleted.html" title="class in org.apache.spark.scheduler">SparkListenerStageCompleted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerStageSubmitted.html" title="class in org.apache.spark.scheduler">SparkListenerStageSubmitted</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerTaskEnd.html" title="class in org.apache.spark.scheduler">SparkListenerTaskEnd</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerTaskGettingResult.html" title="class in org.apache.spark.scheduler">SparkListenerTaskGettingResult</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerTaskStart.html" title="class in org.apache.spark.scheduler">SparkListenerTaskStart</a></li>
+<li><a href="org/apache/spark/scheduler/SparkListenerUnpersistRDD.html" title="class in org.apache.spark.scheduler">SparkListenerUnpersistRDD</a></li>
+<li><a href="org/apache/spark/SparkMasterRegex.html" title="class in org.apache.spark">SparkMasterRegex</a></li>
+<li><a href="org/apache/spark/api/r/SparkRDefaults.html" title="class in org.apache.spark.api.r">SparkRDefaults</a></li>
+<li><a href="org/apache/spark/sql/SparkSession.html" title="class in org.apache.spark.sql">SparkSession</a></li>
+<li><a href="org/apache/spark/sql/SparkSession.Builder.html" title="class in org.apache.spark.sql">SparkSession.Builder</a></li>
+<li><a href="org/apache/spark/sql/SparkSessionExtensions.html" title="class in org.apache.spark.sql">SparkSessionExtensions</a></li>
+<li><a href="org/apache/spark/util/SparkShutdownHook.html" title="class in org.apache.spark.util">SparkShutdownHook</a></li>
+<li><a href="org/apache/spark/SparkStageInfo.html" title="interface in org.apache.spark"><span class="interfaceName">SparkStageInfo</span></a></li>
+<li><a href="org/apache/spark/SparkStageInfoImpl.html" title="class in org.apache.spark">SparkStageInfoImpl</a></li>
+<li><a href="org/apache/spark/SparkStatusTracker.html" title="class in org.apache.spark">SparkStatusTracker</a></li>
+<li><a href="org/apache/spark/sql/expressions/SparkUserDefinedFunction.html" title="class in org.apache.spark.sql.expressions">SparkUserDefinedFunction</a></li>
+<li><a href="org/apache/spark/ml/linalg/SparseMatrix.html" title="class in org.apache.spark.ml.linalg">SparseMatrix</a></li>
+<li><a href="org/apache/spark/mllib/linalg/SparseMatrix.html" title="class in org.apache.spark.mllib.linalg">SparseMatrix</a></li>
+<li><a href="org/apache/spark/ml/linalg/SparseVector.html" title="class in org.apache.spark.ml.linalg">SparseVector</a></li>
+<li><a href="org/apache/spark/mllib/linalg/SparseVector.html" title="class in org.apache.spark.mllib.linalg">SparseVector</a></li>
+<li><a href="org/apache/spark/mllib/stat/correlation/SpearmanCorrelation.html" title="class in org.apache.spark.mllib.stat.correlation">SpearmanCorrelation</a></li>
+<li><a href="org/apache/spark/api/r/SpecialLengths.html" title="class in org.apache.spark.api.r">SpecialLengths</a></li>
+<li><a href="org/apache/spark/SpillListener.html" title="class in org.apache.spark">SpillListener</a></li>
+<li><a href="org/apache/spark/ml/tree/Split.html" title="interface in org.apache.spark.ml.tree"><span class="interfaceName">Split</span></a></li>
+<li><a href="org/apache/spark/mllib/tree/model/Split.html" title="class in org.apache.spark.mllib.tree.model">Split</a></li>
+<li><a href="org/apache/spark/scheduler/SplitInfo.html" title="class in org.apache.spark.scheduler">SplitInfo</a></li>
+<li><a href="org/apache/spark/sql/SQLContext.html" title="class in org.apache.spark.sql">SQLContext</a></li>
+<li><a href="org/apache/spark/ml/linalg/SQLDataTypes.html" title="class in org.apache.spark.ml.linalg">SQLDataTypes</a></li>
+<li><a href="org/apache/spark/sql/SQLImplicits.html" title="class in org.apache.spark.sql">SQLImplicits</a></li>
+<li><a href="org/apache/spark/ml/feature/SQLTransformer.html" title="class in org.apache.spark.ml.feature">SQLTransformer</a></li>
+<li><a href="org/apache/spark/sql/types/SQLUserDefinedType.html" title="annotation in org.apache.spark.sql.types">SQLUserDefinedType</a></li>
+<li><a href="org/apache/spark/sql/api/r/SQLUtils.html" title="class in org.apache.spark.sql.api.r">SQLUtils</a></li>
+<li><a href="org/apache/spark/mllib/tree/loss/SquaredError.html" title="class in org.apache.spark.mllib.tree.loss">SquaredError</a></li>
+<li><a href="org/apache/spark/ml/evaluation/SquaredEuclideanSilhouette.html" title="class in org.apache.spark.ml.evaluation">SquaredEuclideanSilhouette</a></li>
+<li><a href="org/apache/spark/ml/evaluation/SquaredEuclideanSilhouette.ClusterStats.html" title="class in org.apache.spark.ml.evaluation">SquaredEuclideanSilhouette.ClusterStats</a></li>
+<li><a href="org/apache/spark/ml/evaluation/SquaredEuclideanSilhouette.ClusterStats$.html" title="class in org.apache.spark.ml.evaluation">SquaredEuclideanSilhouette.ClusterStats$</a></li>
+<li><a href="org/apache/spark/mllib/optimization/SquaredL2Updater.html" title="class in org.apache.spark.mllib.optimization">SquaredL2Updater</a></li>
+<li><a href="org/apache/spark/status/api/v1/StackTrace.html" title="class in org.apache.spark.status.api.v1">StackTrace</a></li>
+<li><a href="org/apache/spark/status/api/v1/StageData.html" title="class in org.apache.spark.status.api.v1">StageData</a></li>
+<li><a href="org/apache/spark/scheduler/StageInfo.html" title="class in org.apache.spark.scheduler">StageInfo</a></li>
+<li><a href="org/apache/spark/status/api/v1/StageStatus.html" title="enum in org.apache.spark.status.api.v1">StageStatus</a></li>
+<li><a href="org/apache/spark/mllib/random/StandardNormalGenerator.html" title="class in org.apache.spark.mllib.random">StandardNormalGenerator</a></li>
+<li><a href="org/apache/spark/ml/feature/StandardScaler.html" title="class in org.apache.spark.ml.feature">StandardScaler</a></li>
+<li><a href="org/apache/spark/mllib/feature/StandardScaler.html" title="class in org.apache.spark.mllib.feature">StandardScaler</a></li>
+<li><a href="org/apache/spark/ml/feature/StandardScalerModel.html" title="class in org.apache.spark.ml.feature">StandardScalerModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/StandardScalerModel.html" title="class in org.apache.spark.mllib.feature">StandardScalerModel</a></li>
+<li><a href="org/apache/spark/util/StatCounter.html" title="class in org.apache.spark.util">StatCounter</a></li>
+<li><a href="org/apache/spark/streaming/State.html" title="class in org.apache.spark.streaming">State</a></li>
+<li><a href="org/apache/spark/sql/streaming/StateOperatorProgress.html" title="class in org.apache.spark.sql.streaming">StateOperatorProgress</a></li>
+<li><a href="org/apache/spark/streaming/StateSpec.html" title="class in org.apache.spark.streaming">StateSpec</a></li>
+<li><a href="org/apache/spark/metrics/source/StaticSources.html" title="class in org.apache.spark.metrics.source">StaticSources</a></li>
+<li><a href="org/apache/spark/mllib/stat/Statistics.html" title="class in org.apache.spark.mllib.stat">Statistics</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/Statistics.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">Statistics</span></a></li>
+<li><a href="org/apache/spark/metrics/sink/StatsdMetricType.html" title="class in org.apache.spark.metrics.sink">StatsdMetricType</a></li>
+<li><a href="org/apache/spark/scheduler/StatsReportListener.html" title="class in org.apache.spark.scheduler">StatsReportListener</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StatsReportListener.html" title="class in org.apache.spark.streaming.scheduler">StatsReportListener</a></li>
+<li><a href="org/apache/spark/scheduler/local/StatusUpdate.html" title="class in org.apache.spark.scheduler.local">StatusUpdate</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StopAllReceivers.html" title="class in org.apache.spark.streaming.scheduler">StopAllReceivers</a></li>
+<li><a href="org/apache/spark/scheduler/StopCoordinator.html" title="class in org.apache.spark.scheduler">StopCoordinator</a></li>
+<li><a href="org/apache/spark/scheduler/local/StopExecutor.html" title="class in org.apache.spark.scheduler.local">StopExecutor</a></li>
+<li><a href="org/apache/spark/StopMapOutputTracker.html" title="class in org.apache.spark">StopMapOutputTracker</a></li>
+<li><a href="org/apache/spark/streaming/receiver/StopReceiver.html" title="class in org.apache.spark.streaming.receiver">StopReceiver</a></li>
+<li><a href="org/apache/spark/ml/feature/StopWordsRemover.html" title="class in org.apache.spark.ml.feature">StopWordsRemover</a></li>
+<li><a href="org/apache/spark/storage/StorageLevel.html" title="class in org.apache.spark.storage">StorageLevel</a></li>
+<li><a href="org/apache/spark/api/java/StorageLevels.html" title="class in org.apache.spark.api.java">StorageLevels</a></li>
+<li><a href="org/apache/spark/storage/StorageUtils.html" title="class in org.apache.spark.storage">StorageUtils</a></li>
+<li><a href="org/apache/spark/mllib/tree/configuration/Strategy.html" title="class in org.apache.spark.mllib.tree.configuration">Strategy</a></li>
+<li><a href="org/apache/spark/util/random/StratifiedSamplingUtils.html" title="class in org.apache.spark.util.random">StratifiedSamplingUtils</a></li>
+<li><a href="org/apache/spark/storage/StreamBlockId.html" title="class in org.apache.spark.storage">StreamBlockId</a></li>
+<li><a href="org/apache/spark/streaming/StreamingContext.html" title="class in org.apache.spark.streaming">StreamingContext</a></li>
+<li><a href="org/apache/spark/streaming/StreamingContextPythonHelper.html" title="class in org.apache.spark.streaming">StreamingContextPythonHelper</a></li>
+<li><a href="org/apache/spark/streaming/StreamingContextState.html" title="enum in org.apache.spark.streaming">StreamingContextState</a></li>
+<li><a href="org/apache/spark/mllib/clustering/StreamingKMeans.html" title="class in org.apache.spark.mllib.clustering">StreamingKMeans</a></li>
+<li><a href="org/apache/spark/mllib/clustering/StreamingKMeansModel.html" title="class in org.apache.spark.mllib.clustering">StreamingKMeansModel</a></li>
+<li><a href="org/apache/spark/mllib/regression/StreamingLinearAlgorithm.html" title="class in org.apache.spark.mllib.regression">StreamingLinearAlgorithm</a></li>
+<li><a href="org/apache/spark/mllib/regression/StreamingLinearRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression">StreamingLinearRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListener.html" title="interface in org.apache.spark.streaming.scheduler"><span class="interfaceName">StreamingListener</span></a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerBatchCompleted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerBatchCompleted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerBatchStarted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerBatchStarted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerBatchSubmitted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerBatchSubmitted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerEvent.html" title="interface in org.apache.spark.streaming.scheduler"><span class="interfaceName">StreamingListenerEvent</span></a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerOutputOperationCompleted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerOutputOperationCompleted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerOutputOperationStarted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerOutputOperationStarted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerReceiverError.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerReceiverError</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerReceiverStarted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerReceiverStarted</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerReceiverStopped.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerReceiverStopped</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamingListenerStreamingStarted.html" title="class in org.apache.spark.streaming.scheduler">StreamingListenerStreamingStarted</a></li>
+<li><a href="org/apache/spark/mllib/classification/StreamingLogisticRegressionWithSGD.html" title="class in org.apache.spark.mllib.classification">StreamingLogisticRegressionWithSGD</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQuery.html" title="interface in org.apache.spark.sql.streaming"><span class="interfaceName">StreamingQuery</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryException.html" title="class in org.apache.spark.sql.streaming">StreamingQueryException</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.html" title="class in org.apache.spark.sql.streaming">StreamingQueryListener</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.Event.html" title="interface in org.apache.spark.sql.streaming"><span class="interfaceName">StreamingQueryListener.Event</span></a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.QueryProgressEvent.html" title="class in org.apache.spark.sql.streaming">StreamingQueryListener.QueryProgressEvent</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.QueryStartedEvent.html" title="class in org.apache.spark.sql.streaming">StreamingQueryListener.QueryStartedEvent</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryListener.QueryTerminatedEvent.html" title="class in org.apache.spark.sql.streaming">StreamingQueryListener.QueryTerminatedEvent</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryManager.html" title="class in org.apache.spark.sql.streaming">StreamingQueryManager</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryProgress.html" title="class in org.apache.spark.sql.streaming">StreamingQueryProgress</a></li>
+<li><a href="org/apache/spark/sql/streaming/StreamingQueryStatus.html" title="class in org.apache.spark.sql.streaming">StreamingQueryStatus</a></li>
+<li><a href="org/apache/spark/status/api/v1/streaming/StreamingStatistics.html" title="class in org.apache.spark.status.api.v1.streaming">StreamingStatistics</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/StreamingTest.html" title="class in org.apache.spark.mllib.stat.test">StreamingTest</a></li>
+<li><a href="org/apache/spark/streaming/scheduler/StreamInputInfo.html" title="class in org.apache.spark.streaming.scheduler">StreamInputInfo</a></li>
+<li><a href="org/apache/spark/sql/sources/StreamSinkProvider.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">StreamSinkProvider</span></a></li>
+<li><a href="org/apache/spark/sql/sources/StreamSourceProvider.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">StreamSourceProvider</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer.streaming"><span class="interfaceName">StreamWriter</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/StreamWriteSupport.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">StreamWriteSupport</span></a></li>
+<li><a href="org/apache/spark/ml/param/StringArrayParam.html" title="class in org.apache.spark.ml.param">StringArrayParam</a></li>
+<li><a href="org/apache/spark/sql/sources/StringContains.html" title="class in org.apache.spark.sql.sources">StringContains</a></li>
+<li><a href="org/apache/spark/sql/sources/StringEndsWith.html" title="class in org.apache.spark.sql.sources">StringEndsWith</a></li>
+<li><a href="org/apache/spark/ml/feature/StringIndexer.html" title="class in org.apache.spark.ml.feature">StringIndexer</a></li>
+<li><a href="org/apache/spark/ml/feature/StringIndexerModel.html" title="class in org.apache.spark.ml.feature">StringIndexerModel</a></li>
+<li><a href="org/apache/spark/api/r/StringRRDD.html" title="class in org.apache.spark.api.r">StringRRDD</a></li>
+<li><a href="org/apache/spark/sql/sources/StringStartsWith.html" title="class in org.apache.spark.sql.sources">StringStartsWith</a></li>
+<li><a href="org/apache/spark/sql/types/StringType.html" title="class in org.apache.spark.sql.types">StringType</a></li>
+<li><a href="org/apache/spark/graphx/lib/StronglyConnectedComponents.html" title="class in org.apache.spark.graphx.lib">StronglyConnectedComponents</a></li>
+<li><a href="org/apache/spark/sql/types/StructField.html" title="class in org.apache.spark.sql.types">StructField</a></li>
+<li><a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/StudentTTest.html" title="class in org.apache.spark.mllib.stat.test">StudentTTest</a></li>
+<li><a href="org/apache/spark/Success.html" title="class in org.apache.spark">Success</a></li>
+<li><a href="org/apache/spark/ml/stat/Summarizer.html" title="class in org.apache.spark.ml.stat">Summarizer</a></li>
+<li><a href="org/apache/spark/ml/stat/SummaryBuilder.html" title="class in org.apache.spark.ml.stat">SummaryBuilder</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsPushDownFilters.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">SupportsPushDownFilters</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsPushDownRequiredColumns.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">SupportsPushDownRequiredColumns</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsReportPartitioning.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">SupportsReportPartitioning</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsReportStatistics.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">SupportsReportStatistics</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/reader/SupportsScanColumnarBatch.html" title="interface in org.apache.spark.sql.sources.v2.reader"><span class="interfaceName">SupportsScanColumnarBatch</span></a></li>
+<li><a href="org/apache/spark/graphx/lib/SVDPlusPlus.html" title="class in org.apache.spark.graphx.lib">SVDPlusPlus</a></li>
+<li><a href="org/apache/spark/graphx/lib/SVDPlusPlus.Conf.html" title="class in org.apache.spark.graphx.lib">SVDPlusPlus.Conf</a></li>
+<li><a href="org/apache/spark/mllib/util/SVMDataGenerator.html" title="class in org.apache.spark.mllib.util">SVMDataGenerator</a></li>
+<li><a href="org/apache/spark/mllib/classification/SVMModel.html" title="class in org.apache.spark.mllib.classification">SVMModel</a></li>
+<li><a href="org/apache/spark/mllib/classification/SVMWithSGD.html" title="class in org.apache.spark.mllib.classification">SVMWithSGD</a></li>
+<li><a href="org/apache/spark/sql/catalog/Table.html" title="class in org.apache.spark.sql.catalog">Table</a></li>
+<li><a href="org/apache/spark/sql/sources/TableScan.html" title="interface in org.apache.spark.sql.sources"><span class="interfaceName">TableScan</span></a></li>
+<li><a href="org/apache/spark/TaskCommitDenied.html" title="class in org.apache.spark">TaskCommitDenied</a></li>
+<li><a href="org/apache/spark/util/TaskCompletionListener.html" title="interface in org.apache.spark.util"><span class="interfaceName">TaskCompletionListener</span></a></li>
+<li><a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark">TaskContext</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskData.html" title="class in org.apache.spark.status.api.v1">TaskData</a></li>
+<li><a href="org/apache/spark/ui/jobs/TaskDetailsClassNames.html" title="class in org.apache.spark.ui.jobs">TaskDetailsClassNames</a></li>
+<li><a href="org/apache/spark/TaskEndReason.html" title="interface in org.apache.spark"><span class="interfaceName">TaskEndReason</span></a></li>
+<li><a href="org/apache/spark/TaskFailedReason.html" title="interface in org.apache.spark"><span class="interfaceName">TaskFailedReason</span></a></li>
+<li><a href="org/apache/spark/util/TaskFailureListener.html" title="interface in org.apache.spark.util"><span class="interfaceName">TaskFailureListener</span></a></li>
+<li><a href="org/apache/spark/status/TaskIndexNames.html" title="class in org.apache.spark.status">TaskIndexNames</a></li>
+<li><a href="org/apache/spark/scheduler/TaskInfo.html" title="class in org.apache.spark.scheduler">TaskInfo</a></li>
+<li><a href="org/apache/spark/TaskKilled.html" title="class in org.apache.spark">TaskKilled</a></li>
+<li><a href="org/apache/spark/TaskKilledException.html" title="class in org.apache.spark">TaskKilledException</a></li>
+<li><a href="org/apache/spark/scheduler/TaskLocality.html" title="class in org.apache.spark.scheduler">TaskLocality</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskMetricDistributions.html" title="class in org.apache.spark.status.api.v1">TaskMetricDistributions</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskMetrics.html" title="class in org.apache.spark.status.api.v1">TaskMetrics</a></li>
+<li><a href="org/apache/spark/storage/TaskResultBlockId.html" title="class in org.apache.spark.storage">TaskResultBlockId</a></li>
+<li><a href="org/apache/spark/TaskResultLost.html" title="class in org.apache.spark">TaskResultLost</a></li>
+<li><a href="org/apache/spark/TaskSchedulerIsSet.html" title="class in org.apache.spark">TaskSchedulerIsSet</a></li>
+<li><a href="org/apache/spark/status/api/v1/TaskSorting.html" title="enum in org.apache.spark.status.api.v1">TaskSorting</a></li>
+<li><a href="org/apache/spark/TaskState.html" title="class in org.apache.spark">TaskState</a></li>
+<li><a href="org/apache/spark/sql/jdbc/TeradataDialect.html" title="class in org.apache.spark.sql.jdbc">TeradataDialect</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/TestResult.html" title="interface in org.apache.spark.mllib.stat.test"><span class="interfaceName">TestResult</span></a></li>
+<li><a href="org/apache/spark/TestUtils.html" title="class in org.apache.spark">TestUtils</a></li>
+<li><a href="org/apache/spark/status/api/v1/ThreadStackTrace.html" title="class in org.apache.spark.status.api.v1">ThreadStackTrace</a></li>
+<li><a href="org/apache/spark/util/ThreadUtils.html" title="class in org.apache.spark.util">ThreadUtils</a></li>
+<li><a href="org/apache/spark/streaming/Time.html" title="class in org.apache.spark.streaming">Time</a></li>
+<li><a href="org/apache/spark/sql/types/TimestampType.html" title="class in org.apache.spark.sql.types">TimestampType</a></li>
+<li><a href="org/apache/spark/storage/TimeTrackingOutputStream.html" title="class in org.apache.spark.storage">TimeTrackingOutputStream</a></li>
+<li><a href="org/apache/spark/ml/feature/Tokenizer.html" title="class in org.apache.spark.ml.feature">Tokenizer</a></li>
+<li><a href="org/apache/spark/ui/ToolTips.html" title="class in org.apache.spark.ui">ToolTips</a></li>
+<li><a href="org/apache/spark/storage/TopologyMapper.html" title="class in org.apache.spark.storage">TopologyMapper</a></li>
+<li><a href="org/apache/spark/ml/tuning/TrainValidationSplit.html" title="class in org.apache.spark.ml.tuning">TrainValidationSplit</a></li>
+<li><a href="org/apache/spark/ml/tuning/TrainValidationSplitModel.html" title="class in org.apache.spark.ml.tuning">TrainValidationSplitModel</a></li>
+<li><a href="org/apache/spark/ml/tuning/TrainValidationSplitModel.TrainValidationSplitModelWriter.html" title="class in org.apache.spark.ml.tuning">TrainValidationSplitModel.TrainValidationSplitModelWriter</a></li>
+<li><a href="org/apache/spark/ml/Transformer.html" title="class in org.apache.spark.ml">Transformer</a></li>
+<li><a href="org/apache/spark/graphx/lib/TriangleCount.html" title="class in org.apache.spark.graphx.lib">TriangleCount</a></li>
+<li><a href="org/apache/spark/sql/streaming/Trigger.html" title="class in org.apache.spark.sql.streaming">Trigger</a></li>
+<li><a href="org/apache/spark/graphx/TripletFields.html" title="class in org.apache.spark.graphx">TripletFields</a></li>
+<li><a href="org/apache/spark/sql/expressions/javalang/typed.html" title="class in org.apache.spark.sql.expressions.javalang">typed</a></li>
+<li><a href="org/apache/spark/sql/expressions/scalalang/typed.html" title="class in org.apache.spark.sql.expressions.scalalang">typed</a></li>
+<li><a href="org/apache/spark/sql/TypedColumn.html" title="class in org.apache.spark.sql">TypedColumn</a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF0.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF0</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF1.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF1</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF10.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF10</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF11.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF11</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF12.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF12</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF13.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF13</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF14.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF14</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF15.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF15</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF16.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF16</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF17.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF17</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF18.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF18</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF19.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF19</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF2.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF2</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF20.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF20</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF21.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF21</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF22.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF22</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF3.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF3</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF4.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF4</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF5.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF5</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF6.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF6</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF7.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF7</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF8.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF8</span></a></li>
+<li><a href="org/apache/spark/sql/api/java/UDF9.html" title="interface in org.apache.spark.sql.api.java"><span class="interfaceName">UDF9</span></a></li>
+<li><a href="org/apache/spark/sql/UDFRegistration.html" title="class in org.apache.spark.sql">UDFRegistration</a></li>
+<li><a href="org/apache/spark/sql/types/UDTRegistration.html" title="class in org.apache.spark.sql.types">UDTRegistration</a></li>
+<li><a href="org/apache/spark/status/api/v1/UIRootFromServletContext.html" title="class in org.apache.spark.status.api.v1">UIRootFromServletContext</a></li>
+<li><a href="org/apache/spark/streaming/ui/UIUtils.html" title="class in org.apache.spark.streaming.ui">UIUtils</a></li>
+<li><a href="org/apache/spark/ui/UIUtils.html" title="class in org.apache.spark.ui">UIUtils</a></li>
+<li><a href="org/apache/spark/ui/UIWorkloadGenerator.html" title="class in org.apache.spark.ui">UIWorkloadGenerator</a></li>
+<li><a href="org/apache/spark/ml/UnaryTransformer.html" title="class in org.apache.spark.ml">UnaryTransformer</a></li>
+<li><a href="org/apache/spark/mllib/random/UniformGenerator.html" title="class in org.apache.spark.mllib.random">UniformGenerator</a></li>
+<li><a href="org/apache/spark/rdd/UnionRDD.html" title="class in org.apache.spark.rdd">UnionRDD</a></li>
+<li><a href="org/apache/spark/UnknownReason.html" title="class in org.apache.spark">UnknownReason</a></li>
+<li><a href="org/apache/spark/storage/UnrecognizedBlockId.html" title="class in org.apache.spark.storage">UnrecognizedBlockId</a></li>
+<li><a href="org/apache/spark/ml/attribute/UnresolvedAttribute.html" title="class in org.apache.spark.ml.attribute">UnresolvedAttribute</a></li>
+<li><a href="org/apache/spark/mllib/optimization/Updater.html" title="class in org.apache.spark.mllib.optimization">Updater</a></li>
+<li><a href="org/apache/spark/sql/expressions/UserDefinedAggregateFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedAggregateFunction</a></li>
+<li><a href="org/apache/spark/sql/expressions/UserDefinedFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedFunction</a></li>
+<li><a href="org/apache/spark/ml/impl/Utils.html" title="class in org.apache.spark.ml.impl">Utils</a></li>
+<li><a href="org/apache/spark/util/Utils.html" title="class in org.apache.spark.util">Utils</a></li>
+<li><a href="org/apache/spark/storage/memory/ValuesHolder.html" title="interface in org.apache.spark.storage.memory"><span class="interfaceName">ValuesHolder</span></a></li>
+<li><a href="org/apache/spark/sql/types/VarcharType.html" title="class in org.apache.spark.sql.types">VarcharType</a></li>
+<li><a href="org/apache/spark/mllib/tree/impurity/Variance.html" title="class in org.apache.spark.mllib.tree.impurity">Variance</a></li>
+<li><a href="org/apache/spark/ml/linalg/Vector.html" title="interface in org.apache.spark.ml.linalg"><span class="interfaceName">Vector</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/Vector.html" title="interface in org.apache.spark.mllib.linalg"><span class="interfaceName">Vector</span></a></li>
+<li><a href="org/apache/spark/ml/feature/VectorAssembler.html" title="class in org.apache.spark.ml.feature">VectorAssembler</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorAttributeRewriter.html" title="class in org.apache.spark.ml.feature">VectorAttributeRewriter</a></li>
+<li><a href="org/apache/spark/mllib/linalg/VectorImplicits.html" title="class in org.apache.spark.mllib.linalg">VectorImplicits</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorIndexer.html" title="class in org.apache.spark.ml.feature">VectorIndexer</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorIndexerModel.html" title="class in org.apache.spark.ml.feature">VectorIndexerModel</a></li>
+<li><a href="org/apache/spark/ml/linalg/Vectors.html" title="class in org.apache.spark.ml.linalg">Vectors</a></li>
+<li><a href="org/apache/spark/mllib/linalg/Vectors.html" title="class in org.apache.spark.mllib.linalg">Vectors</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorSizeHint.html" title="class in org.apache.spark.ml.feature">VectorSizeHint</a></li>
+<li><a href="org/apache/spark/ml/feature/VectorSlicer.html" title="class in org.apache.spark.ml.feature">VectorSlicer</a></li>
+<li><a href="org/apache/spark/mllib/feature/VectorTransformer.html" title="interface in org.apache.spark.mllib.feature"><span class="interfaceName">VectorTransformer</span></a></li>
+<li><a href="org/apache/spark/mllib/linalg/VectorUDT.html" title="class in org.apache.spark.mllib.linalg">VectorUDT</a></li>
+<li><a href="org/apache/spark/status/api/v1/VersionInfo.html" title="class in org.apache.spark.status.api.v1">VersionInfo</a></li>
+<li><a href="org/apache/spark/util/VersionUtils.html" title="class in org.apache.spark.util">VersionUtils</a></li>
+<li><a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></li>
+<li><a href="org/apache/spark/graphx/impl/VertexRDDImpl.html" title="class in org.apache.spark.graphx.impl">VertexRDDImpl</a></li>
+<li><a href="org/apache/spark/mllib/feature/VocabWord.html" title="class in org.apache.spark.mllib.feature">VocabWord</a></li>
+<li><a href="org/apache/spark/api/java/function/VoidFunction.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">VoidFunction</span></a></li>
+<li><a href="org/apache/spark/api/java/function/VoidFunction2.html" title="interface in org.apache.spark.api.java.function"><span class="interfaceName">VoidFunction2</span></a></li>
+<li><a href="org/apache/spark/mllib/random/WeibullGenerator.html" title="class in org.apache.spark.mllib.random">WeibullGenerator</a></li>
+<li><a href="org/apache/spark/mllib/stat/test/WelchTTest.html" title="class in org.apache.spark.mllib.stat.test">WelchTTest</a></li>
+<li><a href="org/apache/spark/sql/expressions/Window.html" title="class in org.apache.spark.sql.expressions">Window</a></li>
+<li><a href="org/apache/spark/sql/expressions/WindowSpec.html" title="class in org.apache.spark.sql.expressions">WindowSpec</a></li>
+<li><a href="org/apache/spark/ml/feature/Word2Vec.html" title="class in org.apache.spark.ml.feature">Word2Vec</a></li>
+<li><a href="org/apache/spark/mllib/feature/Word2Vec.html" title="class in org.apache.spark.mllib.feature">Word2Vec</a></li>
+<li><a href="org/apache/spark/ml/feature/Word2VecModel.html" title="class in org.apache.spark.ml.feature">Word2VecModel</a></li>
+<li><a href="org/apache/spark/mllib/feature/Word2VecModel.html" title="class in org.apache.spark.mllib.feature">Word2VecModel</a></li>
+<li><a href="org/apache/spark/ml/feature/Word2VecModel.Word2VecModelWriter$.html" title="class in org.apache.spark.ml.feature">Word2VecModel.Word2VecModelWriter$</a></li>
+<li><a href="org/apache/spark/streaming/util/WriteAheadLog.html" title="class in org.apache.spark.streaming.util">WriteAheadLog</a></li>
+<li><a href="org/apache/spark/streaming/util/WriteAheadLogRecordHandle.html" title="class in org.apache.spark.streaming.util">WriteAheadLogRecordHandle</a></li>
+<li><a href="org/apache/spark/streaming/util/WriteAheadLogUtils.html" title="class in org.apache.spark.streaming.util">WriteAheadLogUtils</a></li>
+<li><a href="org/apache/spark/sql/sources/v2/writer/WriterCommitMessage.html" title="interface in org.apache.spark.sql.sources.v2.writer"><span class="interfaceName">WriterCommitMessage</span></a></li>
+<li><a href="org/apache/spark/sql/sources/v2/WriteSupport.html" title="interface in org.apache.spark.sql.sources.v2"><span class="interfaceName">WriteSupport</span></a></li>
+<li><a href="org/apache/spark/io/ZStdCompressionCodec.html" title="class in org.apache.spark.io">ZStdCompressionCodec</a></li>
+</ul>
+</div>
+<script defer="defer" type="text/javascript" src="lib/jquery.js"></script><script defer="defer" type="text/javascript" src="lib/api-javadocs.js"></script></body>
+</html>
diff --git a/site/docs/2.4.3/api/java/constant-values.html b/site/docs/2.4.3/api/java/constant-values.html
new file mode 100644
index 0000000..89a9625
--- /dev/null
+++ b/site/docs/2.4.3/api/java/constant-values.html
@@ -0,0 +1,284 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (1.8.0_121) on Tue May 07 14:11:40 PDT 2019 -->
+<title>Constant Field Values (Spark 2.4.3 JavaDoc)</title>
+<meta name="date" content="2019-05-07">
+<link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
+<script type="text/javascript" src="script.js"></script>
+</head>
+<body>
+<script type="text/javascript"><!--
+    try {
+        if (location.href.indexOf('is-external=true') == -1) {
+            parent.document.title="Constant Field Values (Spark 2.4.3 JavaDoc)";
+        }
+    }
+    catch(err) {
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar.top">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.top" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.top.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li><a href="deprecated-list.html">Deprecated</a></li>
+<li><a href="index-all.html">Index</a></li>
+<li><a href="help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?constant-values.html" target="_top">Frames</a></li>
+<li><a href="constant-values.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 title="Constant Field Values" class="title">Constant Field Values</h1>
+<h2 title="Contents">Contents</h2>
+<ul>
+<li><a href="#org.apache">org.apache.*</a></li>
+</ul>
+</div>
+<div class="constantValuesContainer"><a name="org.apache">
+<!--   -->
+</a>
+<h2 title="org.apache">org.apache.*</h2>
+<ul class="blockList">
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.CHILD_CONNECTION_TIMEOUT">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#CHILD_CONNECTION_TIMEOUT">CHILD_CONNECTION_TIMEOUT</a></code></td>
+<td class="colLast"><code>"spark.launcher.childConectionTimeout"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.CHILD_PROCESS_LOGGER_NAME">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#CHILD_PROCESS_LOGGER_NAME">CHILD_PROCESS_LOGGER_NAME</a></code></td>
+<td class="colLast"><code>"spark.launcher.childProcLoggerName"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.DEPLOY_MODE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#DEPLOY_MODE">DEPLOY_MODE</a></code></td>
+<td class="colLast"><code>"spark.submit.deployMode"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.DRIVER_EXTRA_CLASSPATH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#DRIVER_EXTRA_CLASSPATH">DRIVER_EXTRA_CLASSPATH</a></code></td>
+<td class="colLast"><code>"spark.driver.extraClassPath"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.DRIVER_EXTRA_JAVA_OPTIONS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#DRIVER_EXTRA_JAVA_OPTIONS">DRIVER_EXTRA_JAVA_OPTIONS</a></code></td>
+<td class="colLast"><code>"spark.driver.extraJavaOptions"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.DRIVER_EXTRA_LIBRARY_PATH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#DRIVER_EXTRA_LIBRARY_PATH">DRIVER_EXTRA_LIBRARY_PATH</a></code></td>
+<td class="colLast"><code>"spark.driver.extraLibraryPath"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.DRIVER_MEMORY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#DRIVER_MEMORY">DRIVER_MEMORY</a></code></td>
+<td class="colLast"><code>"spark.driver.memory"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.EXECUTOR_CORES">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#EXECUTOR_CORES">EXECUTOR_CORES</a></code></td>
+<td class="colLast"><code>"spark.executor.cores"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.EXECUTOR_EXTRA_CLASSPATH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#EXECUTOR_EXTRA_CLASSPATH">EXECUTOR_EXTRA_CLASSPATH</a></code></td>
+<td class="colLast"><code>"spark.executor.extraClassPath"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.EXECUTOR_EXTRA_JAVA_OPTIONS">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#EXECUTOR_EXTRA_JAVA_OPTIONS">EXECUTOR_EXTRA_JAVA_OPTIONS</a></code></td>
+<td class="colLast"><code>"spark.executor.extraJavaOptions"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.EXECUTOR_EXTRA_LIBRARY_PATH">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#EXECUTOR_EXTRA_LIBRARY_PATH">EXECUTOR_EXTRA_LIBRARY_PATH</a></code></td>
+<td class="colLast"><code>"spark.executor.extraLibraryPath"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.EXECUTOR_MEMORY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#EXECUTOR_MEMORY">EXECUTOR_MEMORY</a></code></td>
+<td class="colLast"><code>"spark.executor.memory"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.NO_RESOURCE">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#NO_RESOURCE">NO_RESOURCE</a></code></td>
+<td class="colLast"><code>"spark-internal"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.launcher.SparkLauncher.SPARK_MASTER">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/launcher/SparkLauncher.html#SPARK_MASTER">SPARK_MASTER</a></code></td>
+<td class="colLast"><code>"spark.master"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+<ul class="blockList">
+<li class="blockList">
+<table class="constantsSummary" border="0" cellpadding="3" cellspacing="0" summary="Constant Field Values table, listing constant fields, and values">
+<caption><span>org.apache.spark.sql.sources.v2.<a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html" title="class in org.apache.spark.sql.sources.v2">DataSourceOptions</a></span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th scope="col">Constant Field</th>
+<th class="colLast" scope="col">Value</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.sql.sources.v2.DataSourceOptions.DATABASE_KEY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html#DATABASE_KEY">DATABASE_KEY</a></code></td>
+<td class="colLast"><code>"database"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.sql.sources.v2.DataSourceOptions.PATH_KEY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html#PATH_KEY">PATH_KEY</a></code></td>
+<td class="colLast"><code>"path"</code></td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a name="org.apache.spark.sql.sources.v2.DataSourceOptions.PATHS_KEY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html#PATHS_KEY">PATHS_KEY</a></code></td>
+<td class="colLast"><code>"paths"</code></td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a name="org.apache.spark.sql.sources.v2.DataSourceOptions.TABLE_KEY">
+<!--   -->
+</a><code>public&nbsp;static&nbsp;final&nbsp;String</code></td>
+<td><code><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html#TABLE_KEY">TABLE_KEY</a></code></td>
+<td class="colLast"><code>"table"</code></td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar.bottom">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.bottom" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.bottom.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li><a href="deprecated-list.html">Deprecated</a></li>
+<li><a href="index-all.html">Index</a></li>
+<li><a href="help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?constant-values.html" target="_top">Frames</a></li>
+<li><a href="constant-values.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+<script defer="defer" type="text/javascript" src="lib/jquery.js"></script><script defer="defer" type="text/javascript" src="lib/api-javadocs.js"></script></body>
+</html>
diff --git a/site/docs/2.4.3/api/java/deprecated-list.html b/site/docs/2.4.3/api/java/deprecated-list.html
new file mode 100644
index 0000000..5c2b24e
--- /dev/null
+++ b/site/docs/2.4.3/api/java/deprecated-list.html
@@ -0,0 +1,858 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (1.8.0_121) on Tue May 07 14:11:42 PDT 2019 -->
+<title>Deprecated List (Spark 2.4.3 JavaDoc)</title>
+<meta name="date" content="2019-05-07">
+<link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
+<script type="text/javascript" src="script.js"></script>
+</head>
+<body>
+<script type="text/javascript"><!--
+    try {
+        if (location.href.indexOf('is-external=true') == -1) {
+            parent.document.title="Deprecated List (Spark 2.4.3 JavaDoc)";
+        }
+    }
+    catch(err) {
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar.top">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.top" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.top.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li class="navBarCell1Rev">Deprecated</li>
+<li><a href="index-all.html">Index</a></li>
+<li><a href="help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?deprecated-list.html" target="_top">Frames</a></li>
+<li><a href="deprecated-list.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 title="Deprecated API" class="title">Deprecated API</h1>
+<h2 title="Contents">Contents</h2>
+<ul>
+<li><a href="#interface">Deprecated Interfaces</a></li>
+<li><a href="#class">Deprecated Classes</a></li>
+<li><a href="#method">Deprecated Methods</a></li>
+<li><a href="#constructor">Deprecated Constructors</a></li>
+</ul>
+</div>
+<div class="contentContainer"><a name="interface">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<table class="deprecatedSummary" border="0" cellpadding="3" cellspacing="0" summary="Deprecated Interfaces table, listing deprecated interfaces, and an explanation">
+<caption><span>Deprecated Interfaces</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Interface and Description</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/AccumulableParam.html" title="interface in org.apache.spark">org.apache.spark.AccumulableParam</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/AccumulatorParam.html" title="interface in org.apache.spark">org.apache.spark.AccumulatorParam</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+<a name="class">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<table class="deprecatedSummary" border="0" cellpadding="3" cellspacing="0" summary="Deprecated Classes table, listing deprecated classes, and an explanation">
+<caption><span>Deprecated Classes</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Class and Description</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark">org.apache.spark.Accumulable</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark">org.apache.spark.Accumulator</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/AccumulatorParam.DoubleAccumulatorParam$.html" title="class in org.apache.spark">org.apache.spark.AccumulatorParam.DoubleAccumulatorParam$</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/AccumulatorParam.FloatAccumulatorParam$.html" title="class in org.apache.spark">org.apache.spark.AccumulatorParam.FloatAccumulatorParam$</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/AccumulatorParam.IntAccumulatorParam$.html" title="class in org.apache.spark">org.apache.spark.AccumulatorParam.IntAccumulatorParam$</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/AccumulatorParam.LongAccumulatorParam$.html" title="class in org.apache.spark">org.apache.spark.AccumulatorParam.LongAccumulatorParam$</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/AccumulatorParam.StringAccumulatorParam$.html" title="class in org.apache.spark">org.apache.spark.AccumulatorParam.StringAccumulatorParam$</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/hive/HiveContext.html" title="class in org.apache.spark.sql.hive">org.apache.spark.sql.hive.HiveContext</a>
+<div class="block"><span class="deprecationComment">Use SparkSession.builder.enableHiveSupport instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/ml/feature/OneHotEncoder.html" title="class in org.apache.spark.ml.feature">org.apache.spark.ml.feature.OneHotEncoder</a>
+<div class="block"><span class="deprecationComment"><code>OneHotEncoderEstimator</code> will be renamed <code>OneHotEncoder</code> and this <code>OneHotEncoder</code>
+ will be removed in 3.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/streaming/ProcessingTime.html" title="class in org.apache.spark.sql.streaming">org.apache.spark.sql.streaming.ProcessingTime</a>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(intervalMs). Since 2.2.0.</span></div>
+</td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+<a name="method">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<table class="deprecatedSummary" border="0" cellpadding="3" cellspacing="0" summary="Deprecated Methods table, listing deprecated methods, and an explanation">
+<caption><span>Deprecated Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Method and Description</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/SparkContext.html#accumulable-R-org.apache.spark.AccumulableParam-">org.apache.spark.SparkContext.accumulable(R, AccumulableParam&lt;R, T&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/SparkContext.html#accumulable-R-java.lang.String-org.apache.spark.AccumulableParam-">org.apache.spark.SparkContext.accumulable(R, String, AccumulableParam&lt;R, T&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulable-T-org.apache.spark.AccumulableParam-">org.apache.spark.api.java.JavaSparkContext.accumulable(T, AccumulableParam&lt;T, R&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulable-T-java.lang.String-org.apache.spark.AccumulableParam-">org.apache.spark.api.java.JavaSparkContext.accumulable(T, String, AccumulableParam&lt;T, R&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/SparkContext.html#accumulableCollection-R-scala.Function1-scala.reflect.ClassTag-">org.apache.spark.SparkContext.accumulableCollection(R, Function1&lt;R, Growable&lt;T&gt;&gt;, ClassTag&lt;R&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-double-">org.apache.spark.api.java.JavaSparkContext.accumulator(double)</a>
+<div class="block"><span class="deprecationComment">use sc().doubleAccumulator(). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-double-java.lang.String-">org.apache.spark.api.java.JavaSparkContext.accumulator(double, String)</a>
+<div class="block"><span class="deprecationComment">use sc().doubleAccumulator(String). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-int-">org.apache.spark.api.java.JavaSparkContext.accumulator(int)</a>
+<div class="block"><span class="deprecationComment">use sc().longAccumulator(). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-int-java.lang.String-">org.apache.spark.api.java.JavaSparkContext.accumulator(int, String)</a>
+<div class="block"><span class="deprecationComment">use sc().longAccumulator(String). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/SparkContext.html#accumulator-T-org.apache.spark.AccumulatorParam-">org.apache.spark.SparkContext.accumulator(T, AccumulatorParam&lt;T&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-T-org.apache.spark.AccumulatorParam-">org.apache.spark.api.java.JavaSparkContext.accumulator(T, AccumulatorParam&lt;T&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/SparkContext.html#accumulator-T-java.lang.String-org.apache.spark.AccumulatorParam-">org.apache.spark.SparkContext.accumulator(T, String, AccumulatorParam&lt;T&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-T-java.lang.String-org.apache.spark.AccumulatorParam-">org.apache.spark.api.java.JavaSparkContext.accumulator(T, String, AccumulatorParam&lt;T&gt;)</a>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/streaming/ProcessingTime.html#apply-scala.concurrent.duration.Duration-">org.apache.spark.sql.streaming.ProcessingTime.apply(Duration)</a>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(interval)</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/scheduler/AccumulableInfo.html#apply-long-java.lang.String-scala.Option-java.lang.String-">org.apache.spark.scheduler.AccumulableInfo.apply(long, String, Option&lt;String&gt;, String)</a>
+<div class="block"><span class="deprecationComment">do not create AccumulableInfo. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/scheduler/AccumulableInfo.html#apply-long-java.lang.String-scala.Option-java.lang.String-boolean-">org.apache.spark.scheduler.AccumulableInfo.apply(long, String, Option&lt;String&gt;, String, boolean)</a>
+<div class="block"><span class="deprecationComment">do not create AccumulableInfo. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/scheduler/AccumulableInfo.html#apply-long-java.lang.String-java.lang.String-">org.apache.spark.scheduler.AccumulableInfo.apply(long, String, String)</a>
+<div class="block"><span class="deprecationComment">do not create AccumulableInfo. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/streaming/ProcessingTime.html#apply-java.lang.String-">org.apache.spark.sql.streaming.ProcessingTime.apply(String)</a>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(interval)</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.api.java.JavaRDD-java.lang.Class-">org.apache.spark.sql.SQLContext.applySchema(JavaRDD&lt;?&gt;, Class&lt;?&gt;)</a>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.api.java.JavaRDD-org.apache.spark.sql.types.StructType-">org.apache.spark.sql.SQLContext.applySchema(JavaRDD&lt;Row&gt;, StructType)</a>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.rdd.RDD-java.lang.Class-">org.apache.spark.sql.SQLContext.applySchema(RDD&lt;?&gt;, Class&lt;?&gt;)</a>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.rdd.RDD-org.apache.spark.sql.types.StructType-">org.apache.spark.sql.SQLContext.applySchema(RDD&lt;Row&gt;, StructType)</a>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-org.apache.spark.sql.Column-">org.apache.spark.sql.functions.approxCountDistinct(Column)</a>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-org.apache.spark.sql.Column-double-">org.apache.spark.sql.functions.approxCountDistinct(Column, double)</a>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-java.lang.String-">org.apache.spark.sql.functions.approxCountDistinct(String)</a>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-java.lang.String-double-">org.apache.spark.sql.functions.approxCountDistinct(String, double)</a>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/scheduler/StageInfo.html#attemptId--">org.apache.spark.scheduler.StageInfo.attemptId()</a>
+<div class="block"><span class="deprecationComment">Use attemptNumber instead. Since 2.3.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#clearActive--">org.apache.spark.sql.SQLContext.clearActive()</a>
+<div class="block"><span class="deprecationComment">Use SparkSession.clearActiveSession instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/ml/clustering/KMeansModel.html#computeCost-org.apache.spark.sql.Dataset-">org.apache.spark.ml.clustering.KMeansModel.computeCost(Dataset&lt;?&gt;)</a>
+<div class="block"><span class="deprecationComment">This method is deprecated and will be removed in 3.0.0. Use ClusteringEvaluator
+             instead. You can also get the cost on the training dataset in the summary.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/streaming/ProcessingTime.html#create-long-java.util.concurrent.TimeUnit-">org.apache.spark.sql.streaming.ProcessingTime.create(long, TimeUnit)</a>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(interval, unit)</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/streaming/ProcessingTime.html#create-java.lang.String-">org.apache.spark.sql.streaming.ProcessingTime.create(String)</a>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(interval)</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#createExternalTable-java.lang.String-java.lang.String-">org.apache.spark.sql.SQLContext.createExternalTable(String, String)</a>
+<div class="block"><span class="deprecationComment">use sparkSession.catalog.createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/catalog/Catalog.html#createExternalTable-java.lang.String-java.lang.String-">org.apache.spark.sql.catalog.Catalog.createExternalTable(String, String)</a>
+<div class="block"><span class="deprecationComment">use createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#createExternalTable-java.lang.String-java.lang.String-java.util.Map-">org.apache.spark.sql.SQLContext.createExternalTable(String, String, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use sparkSession.catalog.createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#createExternalTable-java.lang.String-java.lang.String-scala.collection.immutable.Map-">org.apache.spark.sql.SQLContext.createExternalTable(String, String, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use sparkSession.catalog.createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/catalog/Catalog.html#createExternalTable-java.lang.String-java.lang.String-java.util.Map-">org.apache.spark.sql.catalog.Catalog.createExternalTable(String, String, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/catalog/Catalog.html#createExternalTable-java.lang.String-java.lang.String-scala.collection.immutable.Map-">org.apache.spark.sql.catalog.Catalog.createExternalTable(String, String, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#createExternalTable-java.lang.String-java.lang.String-java.lang.String-">org.apache.spark.sql.SQLContext.createExternalTable(String, String, String)</a>
+<div class="block"><span class="deprecationComment">use sparkSession.catalog.createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/catalog/Catalog.html#createExternalTable-java.lang.String-java.lang.String-java.lang.String-">org.apache.spark.sql.catalog.Catalog.createExternalTable(String, String, String)</a>
+<div class="block"><span class="deprecationComment">use createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#createExternalTable-java.lang.String-java.lang.String-org.apache.spark.sql.types.StructType-java.util.Map-">org.apache.spark.sql.SQLContext.createExternalTable(String, String, StructType, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use sparkSession.catalog.createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#createExternalTable-java.lang.String-java.lang.String-org.apache.spark.sql.types.StructType-scala.collection.immutable.Map-">org.apache.spark.sql.SQLContext.createExternalTable(String, String, StructType, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use sparkSession.catalog.createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/catalog/Catalog.html#createExternalTable-java.lang.String-java.lang.String-org.apache.spark.sql.types.StructType-java.util.Map-">org.apache.spark.sql.catalog.Catalog.createExternalTable(String, String, StructType, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/catalog/Catalog.html#createExternalTable-java.lang.String-java.lang.String-org.apache.spark.sql.types.StructType-scala.collection.immutable.Map-">org.apache.spark.sql.catalog.Catalog.createExternalTable(String, String, StructType, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">use createTable instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.api.java.JavaStreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-">org.apache.spark.streaming.kinesis.KinesisUtils.createStream(JavaStreamingContext, String, String, String, String, In [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.api.java.JavaStreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-org.apache.spark.api.java.function.Function-java.lang.Class-">org.apache.spark.streaming.kinesis.KinesisUtils.createStr [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.api.java.JavaStreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-org.apache.spark.api.java.function.Function-java.lang.Class-java.lang.String-java.lang.String-">org.apache.spark.stream [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.api.java.JavaStreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-org.apache.spark.api.java.function.Function-java.lang.Class-java.lang.String-java.lang.String-java.lang.String-java.lan [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.api.java.JavaStreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-java.lang.String-java.lang.String-">org.apache.spark.streaming.kinesis.KinesisUtils.createStream(JavaStreamingContext,  [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.StreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-">org.apache.spark.streaming.kinesis.KinesisUtils.createStream(StreamingContext, String, String, String, String, InitialPositionInSt [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.StreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-scala.Function1-scala.reflect.ClassTag-">org.apache.spark.streaming.kinesis.KinesisUtils.createStream(StreamingContext, String, Stri [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.StreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-scala.Function1-java.lang.String-java.lang.String-scala.reflect.ClassTag-">org.apache.spark.streaming.kinesis.KinesisUtils.createStr [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.StreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-scala.Function1-java.lang.String-java.lang.String-java.lang.String-java.lang.String-java.lang.String-scala.reflect.ClassTag-">org.ap [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/streaming/kinesis/KinesisUtils.html#createStream-org.apache.spark.streaming.StreamingContext-java.lang.String-java.lang.String-java.lang.String-java.lang.String-com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream-org.apache.spark.streaming.Duration-org.apache.spark.storage.StorageLevel-java.lang.String-java.lang.String-">org.apache.spark.streaming.kinesis.KinesisUtils.createStream(StreamingContext, String, String, S [...]
+<div class="block"><span class="deprecationComment">Use KinesisInputDStream.builder instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#currentRow--">org.apache.spark.sql.functions.currentRow()</a>
+<div class="block"><span class="deprecationComment">Use Window.currentRow. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#doubleAccumulator-double-">org.apache.spark.api.java.JavaSparkContext.doubleAccumulator(double)</a>
+<div class="block"><span class="deprecationComment">use sc().doubleAccumulator(). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#doubleAccumulator-double-java.lang.String-">org.apache.spark.api.java.JavaSparkContext.doubleAccumulator(double, String)</a>
+<div class="block"><span class="deprecationComment">use sc().doubleAccumulator(String). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/Dataset.html#explode-scala.collection.Seq-scala.Function1-scala.reflect.api.TypeTags.TypeTag-">org.apache.spark.sql.Dataset.explode(Seq&lt;Column&gt;, Function1&lt;Row, TraversableOnce&lt;A&gt;&gt;, TypeTags.TypeTag&lt;A&gt;)</a>
+<div class="block"><span class="deprecationComment">use flatMap() or select() with functions.explode() instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/Dataset.html#explode-java.lang.String-java.lang.String-scala.Function1-scala.reflect.api.TypeTags.TypeTag-">org.apache.spark.sql.Dataset.explode(String, String, Function1&lt;A, TraversableOnce&lt;B&gt;&gt;, TypeTags.TypeTag&lt;B&gt;)</a>
+<div class="block"><span class="deprecationComment">use flatMap() or select() with functions.explode() instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html#fMeasure--">org.apache.spark.mllib.evaluation.MulticlassMetrics.fMeasure()</a>
+<div class="block"><span class="deprecationComment">Use accuracy. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#getOrCreate-org.apache.spark.SparkContext-">org.apache.spark.sql.SQLContext.getOrCreate(SparkContext)</a>
+<div class="block"><span class="deprecationComment">Use SparkSession.builder instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/clustering/KMeans.html#getRuns--">org.apache.spark.mllib.clustering.KMeans.getRuns()</a>
+<div class="block"><span class="deprecationComment">This has no effect and always returns 1. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#intAccumulator-int-">org.apache.spark.api.java.JavaSparkContext.intAccumulator(int)</a>
+<div class="block"><span class="deprecationComment">use sc().longAccumulator(). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/api/java/JavaSparkContext.html#intAccumulator-int-java.lang.String-">org.apache.spark.api.java.JavaSparkContext.intAccumulator(int, String)</a>
+<div class="block"><span class="deprecationComment">use sc().longAccumulator(String). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/TaskContext.html#isRunningLocally--">org.apache.spark.TaskContext.isRunningLocally()</a>
+<div class="block"><span class="deprecationComment">Local execution was removed, so this always returns false. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jdbc-java.lang.String-java.lang.String-">org.apache.spark.sql.SQLContext.jdbc(String, String)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().jdbc()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jdbc-java.lang.String-java.lang.String-java.lang.String:A-">org.apache.spark.sql.SQLContext.jdbc(String, String, String[])</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().jdbc()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jdbc-java.lang.String-java.lang.String-java.lang.String-long-long-int-">org.apache.spark.sql.SQLContext.jdbc(String, String, String, long, long, int)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().jdbc()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/DataFrameReader.html#json-org.apache.spark.api.java.JavaRDD-">org.apache.spark.sql.DataFrameReader.json(JavaRDD&lt;String&gt;)</a>
+<div class="block"><span class="deprecationComment">Use json(Dataset[String]) instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/DataFrameReader.html#json-org.apache.spark.rdd.RDD-">org.apache.spark.sql.DataFrameReader.json(RDD&lt;String&gt;)</a>
+<div class="block"><span class="deprecationComment">Use json(Dataset[String]) instead. Since 2.2.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonFile-java.lang.String-">org.apache.spark.sql.SQLContext.jsonFile(String)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonFile-java.lang.String-double-">org.apache.spark.sql.SQLContext.jsonFile(String, double)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonFile-java.lang.String-org.apache.spark.sql.types.StructType-">org.apache.spark.sql.SQLContext.jsonFile(String, StructType)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonRDD-org.apache.spark.api.java.JavaRDD-">org.apache.spark.sql.SQLContext.jsonRDD(JavaRDD&lt;String&gt;)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonRDD-org.apache.spark.api.java.JavaRDD-double-">org.apache.spark.sql.SQLContext.jsonRDD(JavaRDD&lt;String&gt;, double)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonRDD-org.apache.spark.api.java.JavaRDD-org.apache.spark.sql.types.StructType-">org.apache.spark.sql.SQLContext.jsonRDD(JavaRDD&lt;String&gt;, StructType)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonRDD-org.apache.spark.rdd.RDD-">org.apache.spark.sql.SQLContext.jsonRDD(RDD&lt;String&gt;)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonRDD-org.apache.spark.rdd.RDD-double-">org.apache.spark.sql.SQLContext.jsonRDD(RDD&lt;String&gt;, double)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#jsonRDD-org.apache.spark.rdd.RDD-org.apache.spark.sql.types.StructType-">org.apache.spark.sql.SQLContext.jsonRDD(RDD&lt;String&gt;, StructType)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().json()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#load-java.lang.String-">org.apache.spark.sql.SQLContext.load(String)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().load(path)</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#load-java.lang.String-java.util.Map-">org.apache.spark.sql.SQLContext.load(String, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().format(source).options(options).load()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#load-java.lang.String-scala.collection.immutable.Map-">org.apache.spark.sql.SQLContext.load(String, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().format(source).options(options).load()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#load-java.lang.String-java.lang.String-">org.apache.spark.sql.SQLContext.load(String, String)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().format(source).load(path)</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#load-java.lang.String-org.apache.spark.sql.types.StructType-java.util.Map-">org.apache.spark.sql.SQLContext.load(String, StructType, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by
+            <code>read().format(source).schema(schema).options(options).load()</code>.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#load-java.lang.String-org.apache.spark.sql.types.StructType-scala.collection.immutable.Map-">org.apache.spark.sql.SQLContext.load(String, StructType, Map&lt;String, String&gt;)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by
+            <code>read().format(source).schema(schema).options(options).load()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#monotonicallyIncreasingId--">org.apache.spark.sql.functions.monotonicallyIncreasingId()</a>
+<div class="block"><span class="deprecationComment">Use monotonically_increasing_id(). Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newBooleanSeqEncoder--">org.apache.spark.sql.SQLImplicits.newBooleanSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newByteSeqEncoder--">org.apache.spark.sql.SQLImplicits.newByteSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newDoubleSeqEncoder--">org.apache.spark.sql.SQLImplicits.newDoubleSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newFloatSeqEncoder--">org.apache.spark.sql.SQLImplicits.newFloatSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newIntSeqEncoder--">org.apache.spark.sql.SQLImplicits.newIntSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newLongSeqEncoder--">org.apache.spark.sql.SQLImplicits.newLongSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newProductSeqEncoder-scala.reflect.api.TypeTags.TypeTag-">org.apache.spark.sql.SQLImplicits.newProductSeqEncoder(TypeTags.TypeTag&lt;A&gt;)</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newShortSeqEncoder--">org.apache.spark.sql.SQLImplicits.newShortSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLImplicits.html#newStringSeqEncoder--">org.apache.spark.sql.SQLImplicits.newStringSeqEncoder()</a>
+<div class="block"><span class="deprecationComment">use <code>newSequenceEncoder</code></span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#parquetFile-scala.collection.Seq-">org.apache.spark.sql.SQLContext.parquetFile(Seq&lt;String&gt;)</a>
+<div class="block"><span class="deprecationComment">Use read.parquet() instead. Since 1.4.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#parquetFile-java.lang.String...-">org.apache.spark.sql.SQLContext.parquetFile(String...)</a>
+<div class="block"><span class="deprecationComment">As of 1.4.0, replaced by <code>read().parquet()</code>.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html#precision--">org.apache.spark.mllib.evaluation.MulticlassMetrics.precision()</a>
+<div class="block"><span class="deprecationComment">Use accuracy. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/expressions/Window.html#rangeBetween-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">org.apache.spark.sql.expressions.Window.rangeBetween(Column, Column)</a>
+<div class="block"><span class="deprecationComment">Use the version with Long parameter types. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/expressions/WindowSpec.html#rangeBetween-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">org.apache.spark.sql.expressions.WindowSpec.rangeBetween(Column, Column)</a>
+<div class="block"><span class="deprecationComment">Use the version with Long parameter types. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/ml/image/ImageSchema.html#readImages-java.lang.String-">org.apache.spark.ml.image.ImageSchema.readImages(String)</a>
+<div class="block"><span class="deprecationComment">use `spark.read.format("image").load(path)` and this `readImages` will be removed in 3.0.0. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/ml/image/ImageSchema.html#readImages-java.lang.String-org.apache.spark.sql.SparkSession-boolean-int-boolean-double-long-">org.apache.spark.ml.image.ImageSchema.readImages(String, SparkSession, boolean, int, boolean, double, long)</a>
+<div class="block"><span class="deprecationComment">use `spark.read.format("image").load(path)` and this `readImages` will be removed in 3.0.0. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html#recall--">org.apache.spark.mllib.evaluation.MulticlassMetrics.recall()</a>
+<div class="block"><span class="deprecationComment">Use accuracy. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/Dataset.html#registerTempTable-java.lang.String-">org.apache.spark.sql.Dataset.registerTempTable(String)</a>
+<div class="block"><span class="deprecationComment">Use createOrReplaceTempView(viewName) instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#setActive-org.apache.spark.sql.SQLContext-">org.apache.spark.sql.SQLContext.setActive(SQLContext)</a>
+<div class="block"><span class="deprecationComment">Use SparkSession.setActiveSession instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/clustering/KMeans.html#setRuns-int-">org.apache.spark.mllib.clustering.KMeans.setRuns(int)</a>
+<div class="block"><span class="deprecationComment">This has no effect. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#toDegrees-org.apache.spark.sql.Column-">org.apache.spark.sql.functions.toDegrees(Column)</a>
+<div class="block"><span class="deprecationComment">Use degrees. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#toDegrees-java.lang.String-">org.apache.spark.sql.functions.toDegrees(String)</a>
+<div class="block"><span class="deprecationComment">Use degrees. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#toRadians-org.apache.spark.sql.Column-">org.apache.spark.sql.functions.toRadians(Column)</a>
+<div class="block"><span class="deprecationComment">Use radians. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#toRadians-java.lang.String-">org.apache.spark.sql.functions.toRadians(String)</a>
+<div class="block"><span class="deprecationComment">Use radians. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/mllib/clustering/KMeans.html#train-org.apache.spark.rdd.RDD-int-int-int-">org.apache.spark.mllib.clustering.KMeans.train(RDD&lt;Vector&gt;, int, int, int)</a>
+<div class="block"><span class="deprecationComment">Use train method without 'runs'. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/clustering/KMeans.html#train-org.apache.spark.rdd.RDD-int-int-int-java.lang.String-">org.apache.spark.mllib.clustering.KMeans.train(RDD&lt;Vector&gt;, int, int, int, String)</a>
+<div class="block"><span class="deprecationComment">Use train method without 'runs'. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/mllib/clustering/KMeans.html#train-org.apache.spark.rdd.RDD-int-int-int-java.lang.String-long-">org.apache.spark.mllib.clustering.KMeans.train(RDD&lt;Vector&gt;, int, int, int, String, long)</a>
+<div class="block"><span class="deprecationComment">Use train method without 'runs'. Since 2.1.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#unboundedFollowing--">org.apache.spark.sql.functions.unboundedFollowing()</a>
+<div class="block"><span class="deprecationComment">Use Window.unboundedFollowing. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/functions.html#unboundedPreceding--">org.apache.spark.sql.functions.unboundedPreceding()</a>
+<div class="block"><span class="deprecationComment">Use Window.unboundedPreceding. Since 2.4.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/Dataset.html#unionAll-org.apache.spark.sql.Dataset-">org.apache.spark.sql.Dataset.unionAll(Dataset&lt;T&gt;)</a>
+<div class="block"><span class="deprecationComment">use union(). Since 2.0.0.</span></div>
+</td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+<a name="constructor">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<table class="deprecatedSummary" border="0" cellpadding="3" cellspacing="0" summary="Deprecated Constructors table, listing deprecated constructors, and an explanation">
+<caption><span>Deprecated Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/regression/LassoWithSGD.html#LassoWithSGD--">org.apache.spark.mllib.regression.LassoWithSGD()</a>
+<div class="block"><span class="deprecationComment">Use ml.regression.LinearRegression with elasticNetParam = 1.0. Note the default regParam is 0.01 for LassoWithSGD, but is 0.0 for LinearRegression. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/mllib/regression/LinearRegressionWithSGD.html#LinearRegressionWithSGD--">org.apache.spark.mllib.regression.LinearRegressionWithSGD()</a>
+<div class="block"><span class="deprecationComment">Use ml.regression.LinearRegression or LBFGS. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/mllib/classification/LogisticRegressionWithSGD.html#LogisticRegressionWithSGD--">org.apache.spark.mllib.classification.LogisticRegressionWithSGD()</a>
+<div class="block"><span class="deprecationComment">Use ml.classification.LogisticRegression or LogisticRegressionWithLBFGS. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/mllib/regression/RidgeRegressionWithSGD.html#RidgeRegressionWithSGD--">org.apache.spark.mllib.regression.RidgeRegressionWithSGD()</a>
+<div class="block"><span class="deprecationComment">Use ml.regression.LinearRegression with elasticNetParam = 0.0. Note the default regParam is 0.01 for RidgeRegressionWithSGD, but is 0.0 for LinearRegression. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#SQLContext-org.apache.spark.api.java.JavaSparkContext-">org.apache.spark.sql.SQLContext(JavaSparkContext)</a>
+<div class="block"><span class="deprecationComment">Use SparkSession.builder instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colOne"><a href="org/apache/spark/sql/SQLContext.html#SQLContext-org.apache.spark.SparkContext-">org.apache.spark.sql.SQLContext(SparkContext)</a>
+<div class="block"><span class="deprecationComment">Use SparkSession.builder instead. Since 2.0.0.</span></div>
+</td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar.bottom">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.bottom" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.bottom.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li class="navBarCell1Rev">Deprecated</li>
+<li><a href="index-all.html">Index</a></li>
+<li><a href="help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?deprecated-list.html" target="_top">Frames</a></li>
+<li><a href="deprecated-list.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+<script defer="defer" type="text/javascript" src="lib/jquery.js"></script><script defer="defer" type="text/javascript" src="lib/api-javadocs.js"></script></body>
+</html>
diff --git a/site/docs/2.4.3/api/java/help-doc.html b/site/docs/2.4.3/api/java/help-doc.html
new file mode 100644
index 0000000..c3e099b
--- /dev/null
+++ b/site/docs/2.4.3/api/java/help-doc.html
@@ -0,0 +1,223 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (1.8.0_121) on Tue May 07 14:11:42 PDT 2019 -->
+<title>API Help (Spark 2.4.3 JavaDoc)</title>
+<meta name="date" content="2019-05-07">
+<link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
+<script type="text/javascript" src="script.js"></script>
+</head>
+<body>
+<script type="text/javascript"><!--
+    try {
+        if (location.href.indexOf('is-external=true') == -1) {
+            parent.document.title="API Help (Spark 2.4.3 JavaDoc)";
+        }
+    }
+    catch(err) {
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar.top">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.top" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.top.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li><a href="deprecated-list.html">Deprecated</a></li>
+<li><a href="index-all.html">Index</a></li>
+<li class="navBarCell1Rev">Help</li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?help-doc.html" target="_top">Frames</a></li>
+<li><a href="help-doc.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 class="title">How This API Document Is Organized</h1>
+<div class="subTitle">This API (Application Programming Interface) document has pages corresponding to the items in the navigation bar, described as follows.</div>
+</div>
+<div class="contentContainer">
+<ul class="blockList">
+<li class="blockList">
+<h2>Overview</h2>
+<p>The <a href="overview-summary.html">Overview</a> page is the front page of this API document and provides a list of all packages with a summary for each.  This page can also contain an overall description of the set of packages.</p>
+</li>
+<li class="blockList">
+<h2>Package</h2>
+<p>Each package has a page that contains a list of its classes and interfaces, with a summary for each. This page can contain six categories:</p>
+<ul>
+<li>Interfaces (italic)</li>
+<li>Classes</li>
+<li>Enums</li>
+<li>Exceptions</li>
+<li>Errors</li>
+<li>Annotation Types</li>
+</ul>
+</li>
+<li class="blockList">
+<h2>Class/Interface</h2>
+<p>Each class, interface, nested class and nested interface has its own separate page. Each of these pages has three sections consisting of a class/interface description, summary tables, and detailed member descriptions:</p>
+<ul>
+<li>Class inheritance diagram</li>
+<li>Direct Subclasses</li>
+<li>All Known Subinterfaces</li>
+<li>All Known Implementing Classes</li>
+<li>Class/interface declaration</li>
+<li>Class/interface description</li>
+</ul>
+<ul>
+<li>Nested Class Summary</li>
+<li>Field Summary</li>
+<li>Constructor Summary</li>
+<li>Method Summary</li>
+</ul>
+<ul>
+<li>Field Detail</li>
+<li>Constructor Detail</li>
+<li>Method Detail</li>
+</ul>
+<p>Each summary entry contains the first sentence from the detailed description for that item. The summary entries are alphabetical, while the detailed descriptions are in the order they appear in the source code. This preserves the logical groupings established by the programmer.</p>
+</li>
+<li class="blockList">
+<h2>Annotation Type</h2>
+<p>Each annotation type has its own separate page with the following sections:</p>
+<ul>
+<li>Annotation Type declaration</li>
+<li>Annotation Type description</li>
+<li>Required Element Summary</li>
+<li>Optional Element Summary</li>
+<li>Element Detail</li>
+</ul>
+</li>
+<li class="blockList">
+<h2>Enum</h2>
+<p>Each enum has its own separate page with the following sections:</p>
+<ul>
+<li>Enum declaration</li>
+<li>Enum description</li>
+<li>Enum Constant Summary</li>
+<li>Enum Constant Detail</li>
+</ul>
+</li>
+<li class="blockList">
+<h2>Tree (Class Hierarchy)</h2>
+<p>There is a <a href="overview-tree.html">Class Hierarchy</a> page for all packages, plus a hierarchy for each package. Each hierarchy page contains a list of classes and a list of interfaces. The classes are organized by inheritance structure starting with <code>java.lang.Object</code>. The interfaces do not inherit from <code>java.lang.Object</code>.</p>
+<ul>
+<li>When viewing the Overview page, clicking on "Tree" displays the hierarchy for all packages.</li>
+<li>When viewing a particular package, class or interface page, clicking "Tree" displays the hierarchy for only that package.</li>
+</ul>
+</li>
+<li class="blockList">
+<h2>Deprecated API</h2>
+<p>The <a href="deprecated-list.html">Deprecated API</a> page lists all of the API that have been deprecated. A deprecated API is not recommended for use, generally due to improvements, and a replacement API is usually given. Deprecated APIs may be removed in future implementations.</p>
+</li>
+<li class="blockList">
+<h2>Index</h2>
+<p>The <a href="index-all.html">Index</a> contains an alphabetic list of all classes, interfaces, constructors, methods, and fields.</p>
+</li>
+<li class="blockList">
+<h2>Prev/Next</h2>
+<p>These links take you to the next or previous class, interface, package, or related page.</p>
+</li>
+<li class="blockList">
+<h2>Frames/No Frames</h2>
+<p>These links show and hide the HTML frames.  All pages are available with or without frames.</p>
+</li>
+<li class="blockList">
+<h2>All Classes</h2>
+<p>The <a href="allclasses-noframe.html">All Classes</a> link shows all classes and interfaces except non-static nested types.</p>
+</li>
+<li class="blockList">
+<h2>Serialized Form</h2>
+<p>Each serializable or externalizable class has a description of its serialization fields and methods. This information is of interest to re-implementors, not to developers using the API. While there is no link in the navigation bar, you can get to this information by going to any serialized class and clicking "Serialized Form" in the "See also" section of the class description.</p>
+</li>
+<li class="blockList">
+<h2>Constant Field Values</h2>
+<p>The <a href="constant-values.html">Constant Field Values</a> page lists the static final fields and their values.</p>
+</li>
+</ul>
+<span class="emphasizedPhrase">This help file applies to API documentation generated using the standard doclet.</span></div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar.bottom">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.bottom" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.bottom.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li><a href="deprecated-list.html">Deprecated</a></li>
+<li><a href="index-all.html">Index</a></li>
+<li class="navBarCell1Rev">Help</li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?help-doc.html" target="_top">Frames</a></li>
+<li><a href="help-doc.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+<script defer="defer" type="text/javascript" src="lib/jquery.js"></script><script defer="defer" type="text/javascript" src="lib/api-javadocs.js"></script></body>
+</html>
diff --git a/site/docs/2.4.3/api/java/index-all.html b/site/docs/2.4.3/api/java/index-all.html
new file mode 100644
index 0000000..6a72b65
--- /dev/null
+++ b/site/docs/2.4.3/api/java/index-all.html
@@ -0,0 +1,52796 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (1.8.0_121) on Tue May 07 14:11:42 PDT 2019 -->
+<title>Index (Spark 2.4.3 JavaDoc)</title>
+<meta name="date" content="2019-05-07">
+<link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
+<script type="text/javascript" src="script.js"></script>
+</head>
+<body>
+<script type="text/javascript"><!--
+    try {
+        if (location.href.indexOf('is-external=true') == -1) {
+            parent.document.title="Index (Spark 2.4.3 JavaDoc)";
+        }
+    }
+    catch(err) {
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar.top">
+<!--   -->
+</a>
+<div class="skipNav"><a href="#skip.navbar.top" title="Skip navigation links">Skip navigation links</a></div>
+<a name="navbar.top.firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="overview-summary.html">Overview</a></li>
+<li>Package</li>
+<li>Class</li>
+<li><a href="overview-tree.html">Tree</a></li>
+<li><a href="deprecated-list.html">Deprecated</a></li>
+<li class="navBarCell1Rev">Index</li>
+<li><a href="help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="index.html?index-all.html" target="_top">Frames</a></li>
+<li><a href="index-all.html" target="_top">No&nbsp;Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="allclasses-noframe.html">All&nbsp;Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip.navbar.top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="contentContainer"><a href="#I:Z:Z:D">$</a>&nbsp;<a href="#I:A">A</a>&nbsp;<a href="#I:B">B</a>&nbsp;<a href="#I:C">C</a>&nbsp;<a href="#I:D">D</a>&nbsp;<a href="#I:E">E</a>&nbsp;<a href="#I:F">F</a>&nbsp;<a href="#I:G">G</a>&nbsp;<a href="#I:H">H</a>&nbsp;<a href="#I:I">I</a>&nbsp;<a href="#I:J">J</a>&nbsp;<a href="#I:K">K</a>&nbsp;<a href="#I:L">L</a>&nbsp;<a href="#I:M">M</a>&nbsp;<a href="#I:N">N</a>&nbsp;<a href="#I:O">O</a>&nbsp;<a href="#I:P">P</a>&nbsp;<a href="#I:Q">Q [...]
+<!--   -->
+</a>
+<h2 class="title">$</h2>
+<dl>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Dcolon:Dbslash-B-scala.Function2-">$colon$bslash(B, Function2&lt;A, B, B&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Dcolon:Dplus-B-scala.collection.generic.CanBuildFrom-">$colon$plus(B, CanBuildFrom&lt;Repr, B, That&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Ddiv:Dcolon-B-scala.Function2-">$div$colon(B, Function2&lt;B, A, B&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#Z:Z:Dgreater-A-">$greater(A)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/RDDInfo.html#Z:Z:Dgreater-A-">$greater(A)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/RDDInfo.html" title="class in org.apache.spark.storage">RDDInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#Z:Z:Dgreater:Deq-A-">$greater$eq(A)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/RDDInfo.html#Z:Z:Dgreater:Deq-A-">$greater$eq(A)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/RDDInfo.html" title="class in org.apache.spark.storage">RDDInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#Z:Z:Dless-A-">$less(A)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/RDDInfo.html#Z:Z:Dless-A-">$less(A)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/RDDInfo.html" title="class in org.apache.spark.storage">RDDInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#Z:Z:Dless:Deq-A-">$less$eq(A)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/RDDInfo.html#Z:Z:Dless:Deq-A-">$less$eq(A)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/RDDInfo.html" title="class in org.apache.spark.storage">RDDInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/param/DoubleParam.html#Z:Z:Dminus:Dgreater-T-">$minus$greater(T)</a></span> - Static method in class org.apache.spark.ml.param.<a href="org/apache/spark/ml/param/DoubleParam.html" title="class in org.apache.spark.ml.param">DoubleParam</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/param/FloatParam.html#Z:Z:Dminus:Dgreater-T-">$minus$greater(T)</a></span> - Static method in class org.apache.spark.ml.param.<a href="org/apache/spark/ml/param/FloatParam.html" title="class in org.apache.spark.ml.param">FloatParam</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Dplus:Dcolon-B-scala.collection.generic.CanBuildFrom-">$plus$colon(B, CanBuildFrom&lt;Repr, B, That&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/Accumulator.html#Z:Z:Dplus:Deq-T-">$plus$eq(T)</a></span> - Static method in class org.apache.spark.<a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark">Accumulator</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/r/RRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.api.r.<a href="org/apache/spark/api/r/RRDD.html" title="class in org.apache.spark.api.r">RRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/EdgeRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/EdgeRDD.html" title="class in org.apache.spark.graphx">EdgeRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/EdgeRDDImpl.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/EdgeRDDImpl.html" title="class in org.apache.spark.graphx.impl">EdgeRDDImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/VertexRDDImpl.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/VertexRDDImpl.html" title="class in org.apache.spark.graphx.impl">VertexRDDImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/VertexRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/HadoopRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/HadoopRDD.html" title="class in org.apache.spark.rdd">HadoopRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/JdbcRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/JdbcRDD.html" title="class in org.apache.spark.rdd">JdbcRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/NewHadoopRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/NewHadoopRDD.html" title="class in org.apache.spark.rdd">NewHadoopRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/PartitionPruningRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/PartitionPruningRDD.html" title="class in org.apache.spark.rdd">PartitionPruningRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/UnionRDD.html#Z:Z:Dplus:Dplus-org.apache.spark.rdd.RDD-">$plus$plus(RDD&lt;T&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/UnionRDD.html" title="class in org.apache.spark.rdd">UnionRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Dplus:Dplus-scala.collection.GenTraversableOnce-scala.collection.generic.CanBuildFrom-">$plus$plus(GenTraversableOnce&lt;B&gt;, CanBuildFrom&lt;Repr, B, That&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Dplus:Dplus:Dcolon-scala.collection.TraversableOnce-scala.collection.generic.CanBuildFrom-">$plus$plus$colon(TraversableOnce&lt;B&gt;, CanBuildFrom&lt;Repr, B, That&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#Z:Z:Dplus:Dplus:Dcolon-scala.collection.Traversable-scala.collection.generic.CanBuildFrom-">$plus$plus$colon(Traversable&lt;B&gt;, CanBuildFrom&lt;Repr, B, That&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/Accumulator.html#Z:Z:Dplus:Dplus:Deq-R-">$plus$plus$eq(R)</a></span> - Static method in class org.apache.spark.<a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark">Accumulator</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+</dl>
+<a name="I:A">
+<!--   -->
+</a>
+<h2 class="title">A</h2>
+<dl>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/sources/v2/writer/DataSourceWriter.html#abort-org.apache.spark.sql.sources.v2.writer.WriterCommitMessage:A-">abort(WriterCommitMessage[])</a></span> - Method in interface org.apache.spark.sql.sources.v2.writer.<a href="org/apache/spark/sql/sources/v2/writer/DataSourceWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer">DataSourceWriter</a></dt>
+<dd>
+<div class="block">Aborts this writing job because some data writers are failed and keep failing when retry,
+ or the Spark job fails with some unknown reasons,
+ or <a href="org/apache/spark/sql/sources/v2/writer/DataSourceWriter.html#onDataWriterCommit-org.apache.spark.sql.sources.v2.writer.WriterCommitMessage-"><code>DataSourceWriter.onDataWriterCommit(WriterCommitMessage)</code></a> fails,
+ or <a href="org/apache/spark/sql/sources/v2/writer/DataSourceWriter.html#commit-org.apache.spark.sql.sources.v2.writer.WriterCommitMessage:A-"><code>DataSourceWriter.commit(WriterCommitMessage[])</code></a> fails.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/sources/v2/writer/DataWriter.html#abort--">abort()</a></span> - Method in interface org.apache.spark.sql.sources.v2.writer.<a href="org/apache/spark/sql/sources/v2/writer/DataWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer">DataWriter</a></dt>
+<dd>
+<div class="block">Aborts this writer if it is failed.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html#abort-long-org.apache.spark.sql.sources.v2.writer.WriterCommitMessage:A-">abort(long, WriterCommitMessage[])</a></span> - Method in interface org.apache.spark.sql.sources.v2.writer.streaming.<a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer.streaming">StreamWriter</a></dt>
+<dd>
+<div class="block">Aborts this writing job because some data writers are failed and keep failing when retried, or
+ the Spark job fails with some unknown reasons, or <a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html#commit-org.apache.spark.sql.sources.v2.writer.WriterCommitMessage:A-"><code>StreamWriter.commit(WriterCommitMessage[])</code></a> fails.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html#abort-org.apache.spark.sql.sources.v2.writer.WriterCommitMessage:A-">abort(WriterCommitMessage[])</a></span> - Method in interface org.apache.spark.sql.sources.v2.writer.streaming.<a href="org/apache/spark/sql/sources/v2/writer/streaming/StreamWriter.html" title="interface in org.apache.spark.sql.sources.v2.writer.streaming">StreamWriter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/internal/io/FileCommitProtocol.html#abortJob-org.apache.hadoop.mapreduce.JobContext-">abortJob(JobContext)</a></span> - Method in class org.apache.spark.internal.io.<a href="org/apache/spark/internal/io/FileCommitProtocol.html" title="class in org.apache.spark.internal.io">FileCommitProtocol</a></dt>
+<dd>
+<div class="block">Aborts a job after the writes fail.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/internal/io/HadoopMapReduceCommitProtocol.html#abortJob-org.apache.hadoop.mapreduce.JobContext-">abortJob(JobContext)</a></span> - Method in class org.apache.spark.internal.io.<a href="org/apache/spark/internal/io/HadoopMapReduceCommitProtocol.html" title="class in org.apache.spark.internal.io">HadoopMapReduceCommitProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/internal/io/FileCommitProtocol.html#abortTask-org.apache.hadoop.mapreduce.TaskAttemptContext-">abortTask(TaskAttemptContext)</a></span> - Method in class org.apache.spark.internal.io.<a href="org/apache/spark/internal/io/FileCommitProtocol.html" title="class in org.apache.spark.internal.io">FileCommitProtocol</a></dt>
+<dd>
+<div class="block">Aborts a task after the writes have failed.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/internal/io/HadoopMapReduceCommitProtocol.html#abortTask-org.apache.hadoop.mapreduce.TaskAttemptContext-">abortTask(TaskAttemptContext)</a></span> - Method in class org.apache.spark.internal.io.<a href="org/apache/spark/internal/io/HadoopMapReduceCommitProtocol.html" title="class in org.apache.spark.internal.io">HadoopMapReduceCommitProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#abs-org.apache.spark.sql.Column-">abs(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Computes the absolute value of a numeric value.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#abs--">abs()</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/Optional.html#absent--">absent()</a></span> - Static method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/Optional.html" title="class in org.apache.spark.api.java">Optional</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/mllib/tree/loss/AbsoluteError.html" title="class in org.apache.spark.mllib.tree.loss"><span class="typeNameLink">AbsoluteError</span></a> - Class in <a href="org/apache/spark/mllib/tree/loss/package-summary.html">org.apache.spark.mllib.tree.loss</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Class for absolute error loss calculation (for regression).</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/loss/AbsoluteError.html#AbsoluteError--">AbsoluteError()</a></span> - Constructor for class org.apache.spark.mllib.tree.loss.<a href="org/apache/spark/mllib/tree/loss/AbsoluteError.html" title="class in org.apache.spark.mllib.tree.loss">AbsoluteError</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher"><span class="typeNameLink">AbstractLauncher</span></a>&lt;<a href="org/apache/spark/launcher/AbstractLauncher.html" title="type parameter in AbstractLauncher">T</a> extends <a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a>&lt;<a href="org/apache/spark/launcher/AbstractLauncher.html" title="type parameter in Abstra [...]
+<dd>
+<div class="block">Base class for launcher implementations.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/RFormulaParser.html#accept-scala.util.parsing.combinator.Parsers-">accept(Parsers)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/RFormulaParser.html#accept-ES-scala.Function1-">accept(ES, Function1&lt;ES, List&lt;Object&gt;&gt;)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/RFormulaParser.html#accept-java.lang.String-scala.PartialFunction-">accept(String, PartialFunction&lt;Object, U&gt;)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/image/SamplePathFilter.html#accept-org.apache.hadoop.fs.Path-">accept(Path)</a></span> - Method in class org.apache.spark.ml.image.<a href="org/apache/spark/ml/image/SamplePathFilter.html" title="class in org.apache.spark.ml.image">SamplePathFilter</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/RFormulaParser.html#acceptIf-scala.Function1-scala.Function1-">acceptIf(Function1&lt;Object, Object&gt;, Function1&lt;Object, String&gt;)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/RFormulaParser.html#acceptMatch-java.lang.String-scala.PartialFunction-">acceptMatch(String, PartialFunction&lt;Object, U&gt;)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/RFormulaParser.html#acceptSeq-ES-scala.Function1-">acceptSeq(ES, Function1&lt;ES, Iterable&lt;Object&gt;&gt;)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/RFormulaParser.html" title="class in org.apache.spark.ml.feature">RFormulaParser</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/ObjectType.html#acceptsType-org.apache.spark.sql.types.DataType-">acceptsType(DataType)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/ObjectType.html" title="class in org.apache.spark.sql.types">ObjectType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/CleanAccum.html#accId--">accId()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/CleanAccum.html" title="class in org.apache.spark">CleanAccum</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark"><span class="typeNameLink">Accumulable</span></a>&lt;<a href="org/apache/spark/Accumulable.html" title="type parameter in Accumulable">R</a>,<a href="org/apache/spark/Accumulable.html" title="type parameter in Accumulable">T</a>&gt; - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/Accumulable.html#Accumulable-R-org.apache.spark.AccumulableParam-">Accumulable(R, AccumulableParam&lt;R, T&gt;)</a></span> - Constructor for class org.apache.spark.<a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark">Accumulable</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulable-T-org.apache.spark.AccumulableParam-">accumulable(T, AccumulableParam&lt;T, R&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulable-T-java.lang.String-org.apache.spark.AccumulableParam-">accumulable(T, String, AccumulableParam&lt;T, R&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#accumulable-R-org.apache.spark.AccumulableParam-">accumulable(R, AccumulableParam&lt;R, T&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#accumulable-R-java.lang.String-org.apache.spark.AccumulableParam-">accumulable(R, String, AccumulableParam&lt;R, T&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#accumulableCollection-R-scala.Function1-scala.reflect.ClassTag-">accumulableCollection(R, Function1&lt;R, Growable&lt;T&gt;&gt;, ClassTag&lt;R&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/scheduler/AccumulableInfo.html" title="class in org.apache.spark.scheduler"><span class="typeNameLink">AccumulableInfo</span></a> - Class in <a href="org/apache/spark/scheduler/package-summary.html">org.apache.spark.scheduler</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Information about an <a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark"><code>Accumulable</code></a> modified during a task or stage.</div>
+</dd>
+<dt><a href="org/apache/spark/status/api/v1/AccumulableInfo.html" title="class in org.apache.spark.status.api.v1"><span class="typeNameLink">AccumulableInfo</span></a> - Class in <a href="org/apache/spark/status/api/v1/package-summary.html">org.apache.spark.status.api.v1</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#accumulableInfoFromJson-org.json4s.JsonAST.JValue-">accumulableInfoFromJson(JsonAST.JValue)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#accumulableInfoToJson-org.apache.spark.scheduler.AccumulableInfo-">accumulableInfoToJson(AccumulableInfo)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/AccumulableParam.html" title="interface in org.apache.spark"><span class="typeNameLink">AccumulableParam</span></a>&lt;<a href="org/apache/spark/AccumulableParam.html" title="type parameter in AccumulableParam">R</a>,<a href="org/apache/spark/AccumulableParam.html" title="type parameter in AccumulableParam">T</a>&gt; - Interface in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/StageInfo.html#accumulables--">accumulables()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/StageInfo.html" title="class in org.apache.spark.scheduler">StageInfo</a></dt>
+<dd>
+<div class="block">Terminal values of accumulables updated during this stage, including all the user-defined
+ accumulators.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/TaskInfo.html#accumulables--">accumulables()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/TaskInfo.html" title="class in org.apache.spark.scheduler">TaskInfo</a></dt>
+<dd>
+<div class="block">Intermediate updates to accumulables during this task.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#accumulablesToJson-scala.collection.Traversable-">accumulablesToJson(Traversable&lt;AccumulableInfo&gt;)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark"><span class="typeNameLink">Accumulator</span></a>&lt;<a href="org/apache/spark/Accumulator.html" title="type parameter in Accumulator">T</a>&gt; - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-int-">accumulator(int)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use sc().longAccumulator(). Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-int-java.lang.String-">accumulator(int, String)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use sc().longAccumulator(String). Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-double-">accumulator(double)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use sc().doubleAccumulator(). Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-double-java.lang.String-">accumulator(double, String)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use sc().doubleAccumulator(String). Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-T-org.apache.spark.AccumulatorParam-">accumulator(T, AccumulatorParam&lt;T&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#accumulator-T-java.lang.String-org.apache.spark.AccumulatorParam-">accumulator(T, String, AccumulatorParam&lt;T&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#accumulator-T-org.apache.spark.AccumulatorParam-">accumulator(T, AccumulatorParam&lt;T&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#accumulator-T-java.lang.String-org.apache.spark.AccumulatorParam-">accumulator(T, String, AccumulatorParam&lt;T&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/util/AccumulatorContext.html" title="class in org.apache.spark.util"><span class="typeNameLink">AccumulatorContext</span></a> - Class in <a href="org/apache/spark/util/package-summary.html">org.apache.spark.util</a></dt>
+<dd>
+<div class="block">An internal class used to track accumulators by Spark itself.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/AccumulatorContext.html#AccumulatorContext--">AccumulatorContext()</a></span> - Constructor for class org.apache.spark.util.<a href="org/apache/spark/util/AccumulatorContext.html" title="class in org.apache.spark.util">AccumulatorContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/AccumulatorParam.html" title="interface in org.apache.spark"><span class="typeNameLink">AccumulatorParam</span></a>&lt;<a href="org/apache/spark/AccumulatorParam.html" title="type parameter in AccumulatorParam">T</a>&gt; - Interface in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/AccumulatorParam.DoubleAccumulatorParam$.html" title="class in org.apache.spark"><span class="typeNameLink">AccumulatorParam.DoubleAccumulatorParam$</span></a> - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/AccumulatorParam.FloatAccumulatorParam$.html" title="class in org.apache.spark"><span class="typeNameLink">AccumulatorParam.FloatAccumulatorParam$</span></a> - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/AccumulatorParam.IntAccumulatorParam$.html" title="class in org.apache.spark"><span class="typeNameLink">AccumulatorParam.IntAccumulatorParam$</span></a> - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/AccumulatorParam.LongAccumulatorParam$.html" title="class in org.apache.spark"><span class="typeNameLink">AccumulatorParam.LongAccumulatorParam$</span></a> - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><a href="org/apache/spark/AccumulatorParam.StringAccumulatorParam$.html" title="class in org.apache.spark"><span class="typeNameLink">AccumulatorParam.StringAccumulatorParam$</span></a> - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use AccumulatorV2. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/TaskIndexNames.html#ACCUMULATORS--">ACCUMULATORS()</a></span> - Static method in class org.apache.spark.status.<a href="org/apache/spark/status/TaskIndexNames.html" title="class in org.apache.spark.status">TaskIndexNames</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/StageData.html#accumulatorUpdates--">accumulatorUpdates()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/StageData.html" title="class in org.apache.spark.status.api.v1">StageData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/TaskData.html#accumulatorUpdates--">accumulatorUpdates()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/TaskData.html" title="class in org.apache.spark.status.api.v1">TaskData</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/util/AccumulatorV2.html" title="class in org.apache.spark.util"><span class="typeNameLink">AccumulatorV2</span></a>&lt;<a href="org/apache/spark/util/AccumulatorV2.html" title="type parameter in AccumulatorV2">IN</a>,<a href="org/apache/spark/util/AccumulatorV2.html" title="type parameter in AccumulatorV2">OUT</a>&gt; - Class in <a href="org/apache/spark/util/package-summary.html">org.apache.spark.util</a></dt>
+<dd>
+<div class="block">The base class for accumulators, that can accumulate inputs of type <code>IN</code>, and produce output of
+ type <code>OUT</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/AccumulatorV2.html#AccumulatorV2--">AccumulatorV2()</a></span> - Constructor for class org.apache.spark.util.<a href="org/apache/spark/util/AccumulatorV2.html" title="class in org.apache.spark.util">AccumulatorV2</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ExceptionFailure.html#accumUpdates--">accumUpdates()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/ExceptionFailure.html" title="class in org.apache.spark">ExceptionFailure</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/SparkListenerExecutorMetricsUpdate.html#accumUpdates--">accumUpdates()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/SparkListenerExecutorMetricsUpdate.html" title="class in org.apache.spark.scheduler">SparkListenerExecutorMetricsUpdate</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskKilled.html#accumUpdates--">accumUpdates()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskKilled.html" title="class in org.apache.spark">TaskKilled</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/LogisticRegressionSummary.html#accuracy--">accuracy()</a></span> - Method in interface org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/LogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification">LogisticRegressionSummary</a></dt>
+<dd>
+<div class="block">Returns accuracy.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html#accuracy--">accuracy()</a></span> - Method in class org.apache.spark.mllib.evaluation.<a href="org/apache/spark/mllib/evaluation/MulticlassMetrics.html" title="class in org.apache.spark.mllib.evaluation">MulticlassMetrics</a></dt>
+<dd>
+<div class="block">Returns accuracy
+ (equals to the total number of correctly classified instances
+ out of the total number of instances.)</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/MultilabelMetrics.html#accuracy--">accuracy()</a></span> - Method in class org.apache.spark.mllib.evaluation.<a href="org/apache/spark/mllib/evaluation/MultilabelMetrics.html" title="class in org.apache.spark.mllib.evaluation">MultilabelMetrics</a></dt>
+<dd>
+<div class="block">Returns accuracy</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#acos-org.apache.spark.sql.Column-">acos(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#acos-java.lang.String-">acos(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/SparkSession.html#active--">active()</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/SparkSession.html" title="class in org.apache.spark.sql">SparkSession</a></dt>
+<dd>
+<div class="block">Returns the currently active SparkSession, otherwise the default one.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/streaming/StreamingQueryManager.html#active--">active()</a></span> - Method in class org.apache.spark.sql.streaming.<a href="org/apache/spark/sql/streaming/StreamingQueryManager.html" title="class in org.apache.spark.sql.streaming">StreamingQueryManager</a></dt>
+<dd>
+<div class="block">Returns a list of active queries associated with this SQLContext</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/scheduler/ReceiverInfo.html#active--">active()</a></span> - Method in class org.apache.spark.streaming.scheduler.<a href="org/apache/spark/streaming/scheduler/ReceiverInfo.html" title="class in org.apache.spark.streaming.scheduler">ReceiverInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/scheduler/ReceiverState.html#ACTIVE--">ACTIVE()</a></span> - Static method in class org.apache.spark.streaming.scheduler.<a href="org/apache/spark/streaming/scheduler/ReceiverState.html" title="class in org.apache.spark.streaming.scheduler">ReceiverState</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveJob.html#activeStages--">activeStages()</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveJob.html" title="class in org.apache.spark.status">LiveJob</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/ExecutorSummary.html#activeTasks--">activeTasks()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/ExecutorSummary.html" title="class in org.apache.spark.status.api.v1">ExecutorSummary</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveExecutor.html#activeTasks--">activeTasks()</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveExecutor.html" title="class in org.apache.spark.status">LiveExecutor</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveJob.html#activeTasks--">activeTasks()</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveJob.html" title="class in org.apache.spark.status">LiveJob</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveStage.html#activeTasks--">activeTasks()</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveStage.html" title="class in org.apache.spark.status">LiveStage</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveStage.html#activeTasksPerExecutor--">activeTasksPerExecutor()</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveStage.html" title="class in org.apache.spark.status">LiveStage</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/Accumulable.html#add-T-">add(T)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/Accumulable.html" title="class in org.apache.spark">Accumulable</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+<div class="block">Add more data to this accumulator / accumulable</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/Accumulator.html#add-T-">add(T)</a></span> - Static method in class org.apache.spark.<a href="org/apache/spark/Accumulator.html" title="class in org.apache.spark">Accumulator</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/clustering/ExpectationAggregator.html#add-org.apache.spark.ml.linalg.Vector-">add(Vector)</a></span> - Method in class org.apache.spark.ml.clustering.<a href="org/apache/spark/ml/clustering/ExpectationAggregator.html" title="class in org.apache.spark.ml.clustering">ExpectationAggregator</a></dt>
+<dd>
+<div class="block">Add a new training instance to this ExpectationAggregator, update the weights,
+ means and covariances for each distributions, and update the log likelihood.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTAggregator.html#add-org.apache.spark.ml.regression.AFTPoint-">add(AFTPoint)</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTAggregator.html" title="class in org.apache.spark.ml.regression">AFTAggregator</a></dt>
+<dd>
+<div class="block">Add a new training data to this AFTAggregator, and update the loss and gradient
+ of the objective function.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/clustering/ExpectationSum.html#add-double:A-org.apache.spark.mllib.stat.distribution.MultivariateGaussian:A-org.apache.spark.mllib.clustering.ExpectationSum-breeze.linalg.Vector-">add(double[], MultivariateGaussian[], ExpectationSum, Vector&lt;Object&gt;)</a></span> - Static method in class org.apache.spark.mllib.clustering.<a href="org/apache/spark/mllib/clustering/ExpectationSum.html" title="class in org.apache.spark.mlli [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/feature/IDF.DocumentFrequencyAggregator.html#add-org.apache.spark.mllib.linalg.Vector-">add(Vector)</a></span> - Method in class org.apache.spark.mllib.feature.<a href="org/apache/spark/mllib/feature/IDF.DocumentFrequencyAggregator.html" title="class in org.apache.spark.mllib.feature">IDF.DocumentFrequencyAggregator</a></dt>
+<dd>
+<div class="block">Adds a new document.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/distributed/BlockMatrix.html#add-org.apache.spark.mllib.linalg.distributed.BlockMatrix-">add(BlockMatrix)</a></span> - Method in class org.apache.spark.mllib.linalg.distributed.<a href="org/apache/spark/mllib/linalg/distributed/BlockMatrix.html" title="class in org.apache.spark.mllib.linalg.distributed">BlockMatrix</a></dt>
+<dd>
+<div class="block">Adds the given block matrix <code>other</code> to <code>this</code> block matrix: <code>this + other</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/stat/MultivariateOnlineSummarizer.html#add-org.apache.spark.mllib.linalg.Vector-">add(Vector)</a></span> - Method in class org.apache.spark.mllib.stat.<a href="org/apache/spark/mllib/stat/MultivariateOnlineSummarizer.html" title="class in org.apache.spark.mllib.stat">MultivariateOnlineSummarizer</a></dt>
+<dd>
+<div class="block">Add a new sample to this summarizer, and update the statistical summary.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-org.apache.spark.sql.types.StructField-">add(StructField)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-org.apache.spark.sql.types.DataType-">add(String, DataType)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new nullable field with no metadata.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-org.apache.spark.sql.types.DataType-boolean-">add(String, DataType, boolean)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field with no metadata.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-org.apache.spark.sql.types.DataType-boolean-org.apache.spark.sql.types.Metadata-">add(String, DataType, boolean, Metadata)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field and specifying metadata.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-org.apache.spark.sql.types.DataType-boolean-java.lang.String-">add(String, DataType, boolean, String)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field and specifying metadata.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-java.lang.String-">add(String, String)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new nullable field with no metadata where the
+ dataType is specified as a String.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-java.lang.String-boolean-">add(String, String, boolean)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field with no metadata where the
+ dataType is specified as a String.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-java.lang.String-boolean-org.apache.spark.sql.types.Metadata-">add(String, String, boolean, Metadata)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field and specifying metadata where the
+ dataType is specified as a String.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#add-java.lang.String-java.lang.String-boolean-java.lang.String-">add(String, String, boolean, String)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Creates a new <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> by adding a new field and specifying metadata where the
+ dataType is specified as a String.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/util/RawTextHelper.html#add-long-long-">add(long, long)</a></span> - Static method in class org.apache.spark.streaming.util.<a href="org/apache/spark/streaming/util/RawTextHelper.html" title="class in org.apache.spark.streaming.util">RawTextHelper</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/AccumulatorV2.html#add-IN-">add(IN)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/AccumulatorV2.html" title="class in org.apache.spark.util">AccumulatorV2</a></dt>
+<dd>
+<div class="block">Takes the inputs and accumulates.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/CollectionAccumulator.html#add-T-">add(T)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/CollectionAccumulator.html" title="class in org.apache.spark.util">CollectionAccumulator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/DoubleAccumulator.html#add-java.lang.Double-">add(Double)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/DoubleAccumulator.html" title="class in org.apache.spark.util">DoubleAccumulator</a></dt>
+<dd>
+<div class="block">Adds v to the accumulator, i.e.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/DoubleAccumulator.html#add-double-">add(double)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/DoubleAccumulator.html" title="class in org.apache.spark.util">DoubleAccumulator</a></dt>
+<dd>
+<div class="block">Adds v to the accumulator, i.e.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/LegacyAccumulatorWrapper.html#add-T-">add(T)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/LegacyAccumulatorWrapper.html" title="class in org.apache.spark.util">LegacyAccumulatorWrapper</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/LongAccumulator.html#add-java.lang.Long-">add(Long)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/LongAccumulator.html" title="class in org.apache.spark.util">LongAccumulator</a></dt>
+<dd>
+<div class="block">Adds v to the accumulator, i.e.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/LongAccumulator.html#add-long-">add(long)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/LongAccumulator.html" title="class in org.apache.spark.util">LongAccumulator</a></dt>
+<dd>
+<div class="block">Adds v to the accumulator, i.e.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#add-java.lang.Object-">add(Object)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by one.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#add-java.lang.Object-long-">add(Object, long)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by <code>count</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#add_months-org.apache.spark.sql.Column-int-">add_months(Column, int)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns the date that is <code>numMonths</code> after <code>startDate</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulableParam.html#addAccumulator-R-T-">addAccumulator(R, T)</a></span> - Method in interface org.apache.spark.<a href="org/apache/spark/AccumulableParam.html" title="interface in org.apache.spark">AccumulableParam</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+<div class="block">Add additional data to the accumulator value.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulatorParam.html#addAccumulator-T-T-">addAccumulator(T, T)</a></span> - Method in interface org.apache.spark.<a href="org/apache/spark/AccumulatorParam.html" title="interface in org.apache.spark">AccumulatorParam</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/AbstractLauncher.html#addAppArgs-java.lang.String...-">addAppArgs(String...)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></dt>
+<dd>
+<div class="block">Adds command line arguments for the application.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkLauncher.html#addAppArgs-java.lang.String...-">addAppArgs(String...)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#addBinary-byte:A-">addBinary(byte[])</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by one.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#addBinary-byte:A-long-">addBinary(byte[], long)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by <code>count</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#addFile-java.lang.String-">addFile(String)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block">Add a file to be downloaded with this Spark job on every node.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#addFile-java.lang.String-boolean-">addFile(String, boolean)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block">Add a file to be downloaded with this Spark job on every node.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/AbstractLauncher.html#addFile-java.lang.String-">addFile(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></dt>
+<dd>
+<div class="block">Adds a file to be submitted with the application.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkLauncher.html#addFile-java.lang.String-">addFile(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#addFile-java.lang.String-">addFile(String)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block">Add a file to be downloaded with this Spark job on every node.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#addFile-java.lang.String-boolean-">addFile(String, boolean)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block">Add a file to be downloaded with this Spark job on every node.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ui/JettyUtils.html#addFilters-scala.collection.Seq-org.apache.spark.SparkConf-">addFilters(Seq&lt;ServletContextHandler&gt;, SparkConf)</a></span> - Static method in class org.apache.spark.ui.<a href="org/apache/spark/ui/JettyUtils.html" title="class in org.apache.spark.ui">JettyUtils</a></dt>
+<dd>
+<div class="block">Add filters, if any, to the given list of ServletContextHandlers</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html#addGrid-org.apache.spark.ml.param.Param-scala.collection.Iterable-">addGrid(Param&lt;T&gt;, Iterable&lt;T&gt;)</a></span> - Method in class org.apache.spark.ml.tuning.<a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></dt>
+<dd>
+<div class="block">Adds a param with multiple values (overwrites if the input param exists).</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html#addGrid-org.apache.spark.ml.param.DoubleParam-double:A-">addGrid(DoubleParam, double[])</a></span> - Method in class org.apache.spark.ml.tuning.<a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></dt>
+<dd>
+<div class="block">Adds a double param with multiple values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html#addGrid-org.apache.spark.ml.param.IntParam-int:A-">addGrid(IntParam, int[])</a></span> - Method in class org.apache.spark.ml.tuning.<a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></dt>
+<dd>
+<div class="block">Adds an int param with multiple values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html#addGrid-org.apache.spark.ml.param.FloatParam-float:A-">addGrid(FloatParam, float[])</a></span> - Method in class org.apache.spark.ml.tuning.<a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></dt>
+<dd>
+<div class="block">Adds a float param with multiple values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html#addGrid-org.apache.spark.ml.param.LongParam-long:A-">addGrid(LongParam, long[])</a></span> - Method in class org.apache.spark.ml.tuning.<a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></dt>
+<dd>
+<div class="block">Adds a long param with multiple values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tuning/ParamGridBuilder.html#addGrid-org.apache.spark.ml.param.BooleanParam-">addGrid(BooleanParam)</a></span> - Method in class org.apache.spark.ml.tuning.<a href="org/apache/spark/ml/tuning/ParamGridBuilder.html" title="class in org.apache.spark.ml.tuning">ParamGridBuilder</a></dt>
+<dd>
+<div class="block">Adds a boolean param with true and false.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulableParam.html#addInPlace-R-R-">addInPlace(R, R)</a></span> - Method in interface org.apache.spark.<a href="org/apache/spark/AccumulableParam.html" title="interface in org.apache.spark">AccumulableParam</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+<div class="block">Merge two accumulated values together.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulatorParam.DoubleAccumulatorParam$.html#addInPlace-double-double-">addInPlace(double, double)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/AccumulatorParam.DoubleAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.DoubleAccumulatorParam$</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulatorParam.FloatAccumulatorParam$.html#addInPlace-float-float-">addInPlace(float, float)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/AccumulatorParam.FloatAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.FloatAccumulatorParam$</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulatorParam.IntAccumulatorParam$.html#addInPlace-int-int-">addInPlace(int, int)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/AccumulatorParam.IntAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.IntAccumulatorParam$</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulatorParam.LongAccumulatorParam$.html#addInPlace-long-long-">addInPlace(long, long)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/AccumulatorParam.LongAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.LongAccumulatorParam$</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/AccumulatorParam.StringAccumulatorParam$.html#addInPlace-java.lang.String-java.lang.String-">addInPlace(String, String)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/AccumulatorParam.StringAccumulatorParam$.html" title="class in org.apache.spark">AccumulatorParam.StringAccumulatorParam$</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span></div>
+&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#addJar-java.lang.String-">addJar(String)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>
+<div class="block">Adds a JAR dependency for all tasks to be executed on this SparkContext in the future.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/AbstractLauncher.html#addJar-java.lang.String-">addJar(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></dt>
+<dd>
+<div class="block">Adds a jar file to be submitted with the application.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkLauncher.html#addJar-java.lang.String-">addJar(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#addJar-java.lang.String-">addJar(String)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block">Adds a JAR dependency for all tasks to be executed on this <code>SparkContext</code> in the future.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/HiveSessionResourceLoader.html#addJar-java.lang.String-">addJar(String)</a></span> - Method in class org.apache.spark.sql.hive.<a href="org/apache/spark/sql/hive/HiveSessionResourceLoader.html" title="class in org.apache.spark.sql.hive">HiveSessionResourceLoader</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkAppHandle.html#addListener-org.apache.spark.launcher.SparkAppHandle.Listener-">addListener(SparkAppHandle.Listener)</a></span> - Method in interface org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkAppHandle.html" title="interface in org.apache.spark.launcher">SparkAppHandle</a></dt>
+<dd>
+<div class="block">Adds a listener to be notified of changes to the handle's information.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AsyncEventQueue.html#addListener-L-">addListener(L)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AsyncEventQueue.html" title="class in org.apache.spark.scheduler">AsyncEventQueue</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/streaming/StreamingQueryManager.html#addListener-org.apache.spark.sql.streaming.StreamingQueryListener-">addListener(StreamingQueryListener)</a></span> - Method in class org.apache.spark.sql.streaming.<a href="org/apache/spark/sql/streaming/StreamingQueryManager.html" title="class in org.apache.spark.sql.streaming">StreamingQueryManager</a></dt>
+<dd>
+<div class="block">Register a <a href="org/apache/spark/sql/streaming/StreamingQueryListener.html" title="class in org.apache.spark.sql.streaming"><code>StreamingQueryListener</code></a> to receive up-calls for life cycle events of
+ <a href="org/apache/spark/sql/streaming/StreamingQuery.html" title="interface in org.apache.spark.sql.streaming"><code>StreamingQuery</code></a>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/HadoopRDD.html#addLocalConfiguration-java.lang.String-int-int-int-org.apache.hadoop.mapred.JobConf-">addLocalConfiguration(String, int, int, int, JobConf)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/HadoopRDD.html" title="class in org.apache.spark.rdd">HadoopRDD</a></dt>
+<dd>
+<div class="block">Add Hadoop configuration specific to a single partition and attempt.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#addLong-long-">addLong(long)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by one.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#addLong-long-long-">addLong(long, long)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by <code>count</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ShuffleStatus.html#addMapOutput-int-org.apache.spark.scheduler.MapStatus-">addMapOutput(int, org.apache.spark.scheduler.MapStatus)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/ShuffleStatus.html" title="class in org.apache.spark">ShuffleStatus</a></dt>
+<dd>
+<div class="block">Register a map output.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveEntityHelpers.html#addMetrics-org.apache.spark.status.api.v1.TaskMetrics-org.apache.spark.status.api.v1.TaskMetrics-">addMetrics(TaskMetrics, TaskMetrics)</a></span> - Static method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveEntityHelpers.html" title="class in org.apache.spark.status">LiveEntityHelpers</a></dt>
+<dd>
+<div class="block">Add m2 values to m1.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/RDDPartitionSeq.html#addPartition-org.apache.spark.status.LiveRDDPartition-">addPartition(LiveRDDPartition)</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/RDDPartitionSeq.html" title="class in org.apache.spark.status">RDDPartitionSeq</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/DefaultPartitionCoalescer.html#addPartToPGroup-org.apache.spark.Partition-org.apache.spark.rdd.PartitionGroup-">addPartToPGroup(Partition, PartitionGroup)</a></span> - Method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/DefaultPartitionCoalescer.html" title="class in org.apache.spark.rdd">DefaultPartitionCoalescer</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/AbstractLauncher.html#addPyFile-java.lang.String-">addPyFile(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></dt>
+<dd>
+<div class="block">Adds a python file / zip / egg to be submitted with the application.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkLauncher.html#addPyFile-java.lang.String-">addPyFile(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/BarrierTaskInfo.html#address--">address()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/BarrierTaskInfo.html" title="class in org.apache.spark">BarrierTaskInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/RDDDataDistribution.html#address--">address()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/RDDDataDistribution.html" title="class in org.apache.spark.status.api.v1">RDDDataDistribution</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/ShutdownHookManager.html#addShutdownHook-scala.Function0-">addShutdownHook(Function0&lt;BoxedUnit&gt;)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/ShutdownHookManager.html" title="class in org.apache.spark.util">ShutdownHookManager</a></dt>
+<dd>
+<div class="block">Adds a shutdown hook with default priority.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/ShutdownHookManager.html#addShutdownHook-int-scala.Function0-">addShutdownHook(int, Function0&lt;BoxedUnit&gt;)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/ShutdownHookManager.html" title="class in org.apache.spark.util">ShutdownHookManager</a></dt>
+<dd>
+<div class="block">Adds a shutdown hook with the given priority.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/AbstractLauncher.html#addSparkArg-java.lang.String-">addSparkArg(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></dt>
+<dd>
+<div class="block">Adds a no-value argument to the Spark invocation.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/AbstractLauncher.html#addSparkArg-java.lang.String-java.lang.String-">addSparkArg(String, String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/AbstractLauncher.html" title="class in org.apache.spark.launcher">AbstractLauncher</a></dt>
+<dd>
+<div class="block">Adds an argument with a value to the Spark invocation.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkLauncher.html#addSparkArg-java.lang.String-">addSparkArg(String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/launcher/SparkLauncher.html#addSparkArg-java.lang.String-java.lang.String-">addSparkArg(String, String)</a></span> - Method in class org.apache.spark.launcher.<a href="org/apache/spark/launcher/SparkLauncher.html" title="class in org.apache.spark.launcher">SparkLauncher</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#addSparkListener-org.apache.spark.scheduler.SparkListenerInterface-">addSparkListener(org.apache.spark.scheduler.SparkListenerInterface)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Register a listener to receive up-calls from events that happen during execution.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/api/java/JavaStreamingContext.html#addStreamingListener-org.apache.spark.streaming.scheduler.StreamingListener-">addStreamingListener(StreamingListener)</a></span> - Method in class org.apache.spark.streaming.api.java.<a href="org/apache/spark/streaming/api/java/JavaStreamingContext.html" title="class in org.apache.spark.streaming.api.java">JavaStreamingContext</a></dt>
+<dd>
+<div class="block">Add a <a href="org/apache/spark/streaming/scheduler/StreamingListener.html" title="interface in org.apache.spark.streaming.scheduler"><code>StreamingListener</code></a> object for
+ receiving system events related to streaming.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/StreamingContext.html#addStreamingListener-org.apache.spark.streaming.scheduler.StreamingListener-">addStreamingListener(StreamingListener)</a></span> - Method in class org.apache.spark.streaming.<a href="org/apache/spark/streaming/StreamingContext.html" title="class in org.apache.spark.streaming">StreamingContext</a></dt>
+<dd>
+<div class="block">Add a <a href="org/apache/spark/streaming/scheduler/StreamingListener.html" title="interface in org.apache.spark.streaming.scheduler"><code>StreamingListener</code></a> object for
+ receiving system events related to streaming.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#addString-scala.collection.mutable.StringBuilder-java.lang.String-java.lang.String-java.lang.String-">addString(StringBuilder, String, String, String)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#addString-scala.collection.mutable.StringBuilder-java.lang.String-">addString(StringBuilder, String)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#addString-scala.collection.mutable.StringBuilder-">addString(StringBuilder)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#addString-java.lang.String-">addString(String)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by one.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/sketch/CountMinSketch.html#addString-java.lang.String-long-">addString(String, long)</a></span> - Method in class org.apache.spark.util.sketch.<a href="org/apache/spark/util/sketch/CountMinSketch.html" title="class in org.apache.spark.util.sketch">CountMinSketch</a></dt>
+<dd>
+<div class="block">Increments <code>item</code>'s count by <code>count</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/AnalysisException.html#addSuppressed-java.lang.Throwable-">addSuppressed(Throwable)</a></span> - Static method in exception org.apache.spark.sql.<a href="org/apache/spark/sql/AnalysisException.html" title="class in org.apache.spark.sql">AnalysisException</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/BarrierTaskContext.html#addTaskCompletionListener-org.apache.spark.util.TaskCompletionListener-">addTaskCompletionListener(TaskCompletionListener)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/BarrierTaskContext.html" title="class in org.apache.spark">BarrierTaskContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskContext.html#addTaskCompletionListener-org.apache.spark.util.TaskCompletionListener-">addTaskCompletionListener(TaskCompletionListener)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark">TaskContext</a></dt>
+<dd>
+<div class="block">Adds a (Java friendly) listener to be executed on task completion.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskContext.html#addTaskCompletionListener-scala.Function1-">addTaskCompletionListener(Function1&lt;TaskContext, U&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark">TaskContext</a></dt>
+<dd>
+<div class="block">Adds a listener in the form of a Scala closure to be executed on task completion.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/BarrierTaskContext.html#addTaskFailureListener-org.apache.spark.util.TaskFailureListener-">addTaskFailureListener(TaskFailureListener)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/BarrierTaskContext.html" title="class in org.apache.spark">BarrierTaskContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskContext.html#addTaskFailureListener-org.apache.spark.util.TaskFailureListener-">addTaskFailureListener(TaskFailureListener)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark">TaskContext</a></dt>
+<dd>
+<div class="block">Adds a listener to be executed on task failure.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskContext.html#addTaskFailureListener-scala.Function2-">addTaskFailureListener(Function2&lt;TaskContext, Throwable, BoxedUnit&gt;)</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark">TaskContext</a></dt>
+<dd>
+<div class="block">Adds a listener to be executed on task failure.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/ExecutorSummary.html#addTime--">addTime()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/ExecutorSummary.html" title="class in org.apache.spark.status.api.v1">ExecutorSummary</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/LiveExecutor.html#addTime--">addTime()</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/LiveExecutor.html" title="class in org.apache.spark.status">LiveExecutor</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/MutableURLClassLoader.html#addURL-java.net.URL-">addURL(URL)</a></span> - Method in class org.apache.spark.util.<a href="org/apache/spark/util/MutableURLClassLoader.html" title="class in org.apache.spark.util">MutableURLClassLoader</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter.html#AddWebUIFilter-java.lang.String-scala.collection.immutable.Map-java.lang.String-">AddWebUIFilter(String, Map&lt;String, String&gt;, String)</a></span> - Constructor for class org.apache.spark.scheduler.cluster.<a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrai [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter$.html#AddWebUIFilter:D--">AddWebUIFilter$()</a></span> - Constructor for class org.apache.spark.scheduler.cluster.<a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.AddWebUIFilter$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.AddWebUIFilter$</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/regression/AFTAggregator.html" title="class in org.apache.spark.ml.regression"><span class="typeNameLink">AFTAggregator</span></a> - Class in <a href="org/apache/spark/ml/regression/package-summary.html">org.apache.spark.ml.regression</a></dt>
+<dd>
+<div class="block">AFTAggregator computes the gradient and loss for a AFT loss function,
+ as used in AFT survival regression for samples in sparse or dense vector in an online fashion.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTAggregator.html#AFTAggregator-org.apache.spark.broadcast.Broadcast-boolean-org.apache.spark.broadcast.Broadcast-">AFTAggregator(Broadcast&lt;DenseVector&lt;Object&gt;&gt;, boolean, Broadcast&lt;double[]&gt;)</a></span> - Constructor for class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTAggregator.html" title="class in org.apache.spark.ml.regression">AFTAggregator</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/regression/AFTCostFun.html" title="class in org.apache.spark.ml.regression"><span class="typeNameLink">AFTCostFun</span></a> - Class in <a href="org/apache/spark/ml/regression/package-summary.html">org.apache.spark.ml.regression</a></dt>
+<dd>
+<div class="block">AFTCostFun implements Breeze's DiffFunction[T] for AFT cost.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTCostFun.html#AFTCostFun-org.apache.spark.rdd.RDD-boolean-org.apache.spark.broadcast.Broadcast-int-">AFTCostFun(RDD&lt;AFTPoint&gt;, boolean, Broadcast&lt;double[]&gt;, int)</a></span> - Constructor for class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTCostFun.html" title="class in org.apache.spark.ml.regression">AFTCostFun</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression"><span class="typeNameLink">AFTSurvivalRegression</span></a> - Class in <a href="org/apache/spark/ml/regression/package-summary.html">org.apache.spark.ml.regression</a></dt>
+<dd>
+<div class="block">:: Experimental ::
+ Fit a parametric survival regression model named accelerated failure time (AFT) model
+ (see <a href="https://en.wikipedia.org/wiki/Accelerated_failure_time_model">
+ Accelerated failure time model (Wikipedia)</a>)
+ based on the Weibull distribution of the survival time.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html#AFTSurvivalRegression-java.lang.String-">AFTSurvivalRegression(String)</a></span> - Constructor for class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression">AFTSurvivalRegression</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html#AFTSurvivalRegression--">AFTSurvivalRegression()</a></span> - Constructor for class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression">AFTSurvivalRegression</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/regression/AFTSurvivalRegressionModel.html" title="class in org.apache.spark.ml.regression"><span class="typeNameLink">AFTSurvivalRegressionModel</span></a> - Class in <a href="org/apache/spark/ml/regression/package-summary.html">org.apache.spark.ml.regression</a></dt>
+<dd>
+<div class="block">:: Experimental ::
+ Model produced by <a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression"><code>AFTSurvivalRegression</code></a>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#agg-org.apache.spark.sql.Column-org.apache.spark.sql.Column...-">agg(Column, Column...)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">Aggregates on the entire Dataset without groups.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#agg-scala.Tuple2-scala.collection.Seq-">agg(Tuple2&lt;String, String&gt;, Seq&lt;Tuple2&lt;String, String&gt;&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">(Scala-specific) Aggregates on the entire Dataset without groups.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#agg-scala.collection.immutable.Map-">agg(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">(Scala-specific) Aggregates on the entire Dataset without groups.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#agg-java.util.Map-">agg(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">(Java-specific) Aggregates on the entire Dataset without groups.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#agg-org.apache.spark.sql.Column-scala.collection.Seq-">agg(Column, Seq&lt;Column&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">Aggregates on the entire Dataset without groups.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/KeyValueGroupedDataset.html#agg-org.apache.spark.sql.TypedColumn-">agg(TypedColumn&lt;V, U1&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/KeyValueGroupedDataset.html" title="class in org.apache.spark.sql">KeyValueGroupedDataset</a></dt>
+<dd>
+<div class="block">Computes the given aggregation, returning a <a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql"><code>Dataset</code></a> of tuples for each unique key
+ and the result of computing this aggregation over all elements in the group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/KeyValueGroupedDataset.html#agg-org.apache.spark.sql.TypedColumn-org.apache.spark.sql.TypedColumn-">agg(TypedColumn&lt;V, U1&gt;, TypedColumn&lt;V, U2&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/KeyValueGroupedDataset.html" title="class in org.apache.spark.sql">KeyValueGroupedDataset</a></dt>
+<dd>
+<div class="block">Computes the given aggregations, returning a <a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql"><code>Dataset</code></a> of tuples for each unique key
+ and the result of computing these aggregations over all elements in the group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/KeyValueGroupedDataset.html#agg-org.apache.spark.sql.TypedColumn-org.apache.spark.sql.TypedColumn-org.apache.spark.sql.TypedColumn-">agg(TypedColumn&lt;V, U1&gt;, TypedColumn&lt;V, U2&gt;, TypedColumn&lt;V, U3&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/KeyValueGroupedDataset.html" title="class in org.apache.spark.sql">KeyValueGroupedDataset</a></dt>
+<dd>
+<div class="block">Computes the given aggregations, returning a <a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql"><code>Dataset</code></a> of tuples for each unique key
+ and the result of computing these aggregations over all elements in the group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/KeyValueGroupedDataset.html#agg-org.apache.spark.sql.TypedColumn-org.apache.spark.sql.TypedColumn-org.apache.spark.sql.TypedColumn-org.apache.spark.sql.TypedColumn-">agg(TypedColumn&lt;V, U1&gt;, TypedColumn&lt;V, U2&gt;, TypedColumn&lt;V, U3&gt;, TypedColumn&lt;V, U4&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/KeyValueGroupedDataset.html" title="class in org.apache.spark.sql">KeyValue [...]
+<dd>
+<div class="block">Computes the given aggregations, returning a <a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql"><code>Dataset</code></a> of tuples for each unique key
+ and the result of computing these aggregations over all elements in the group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/RelationalGroupedDataset.html#agg-org.apache.spark.sql.Column-org.apache.spark.sql.Column...-">agg(Column, Column...)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></dt>
+<dd>
+<div class="block">Compute aggregates by specifying a series of aggregate columns.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/RelationalGroupedDataset.html#agg-scala.Tuple2-scala.collection.Seq-">agg(Tuple2&lt;String, String&gt;, Seq&lt;Tuple2&lt;String, String&gt;&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></dt>
+<dd>
+<div class="block">(Scala-specific) Compute aggregates by specifying the column names and
+ aggregate methods.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/RelationalGroupedDataset.html#agg-scala.collection.immutable.Map-">agg(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></dt>
+<dd>
+<div class="block">(Scala-specific) Compute aggregates by specifying a map from column name to
+ aggregate methods.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/RelationalGroupedDataset.html#agg-java.util.Map-">agg(Map&lt;String, String&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></dt>
+<dd>
+<div class="block">(Java-specific) Compute aggregates by specifying a map from column name to
+ aggregate methods.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/RelationalGroupedDataset.html#agg-org.apache.spark.sql.Column-scala.collection.Seq-">agg(Column, Seq&lt;Column&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></dt>
+<dd>
+<div class="block">Compute aggregates by specifying a series of aggregate columns.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaDoubleRDD.html#aggregate-U-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Static method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaDoubleRDD.html" title="class in org.apache.spark.api.java">JavaDoubleRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaPairRDD.html#aggregate-U-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Static method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaPairRDD.html" title="class in org.apache.spark.api.java">JavaPairRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaRDD.html#aggregate-U-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Static method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaRDD.html" title="class in org.apache.spark.api.java">JavaRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaRDDLike.html#aggregate-U-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Method in interface org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaRDDLike.html" title="interface in org.apache.spark.api.java">JavaRDDLike</a></dt>
+<dd>
+<div class="block">Aggregate the elements of each partition, and then the results for all the partitions, using
+ given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/r/RRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.api.r.<a href="org/apache/spark/api/r/RRDD.html" title="class in org.apache.spark.api.r">RRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/EdgeRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/EdgeRDD.html" title="class in org.apache.spark.graphx">EdgeRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/EdgeRDDImpl.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/EdgeRDDImpl.html" title="class in org.apache.spark.graphx.impl">EdgeRDDImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/VertexRDDImpl.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/VertexRDDImpl.html" title="class in org.apache.spark.graphx.impl">VertexRDDImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/VertexRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/HadoopRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/HadoopRDD.html" title="class in org.apache.spark.rdd">HadoopRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/JdbcRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/JdbcRDD.html" title="class in org.apache.spark.rdd">JdbcRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/NewHadoopRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/NewHadoopRDD.html" title="class in org.apache.spark.rdd">NewHadoopRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/PartitionPruningRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/PartitionPruningRDD.html" title="class in org.apache.spark.rdd">PartitionPruningRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/RDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/RDD.html" title="class in org.apache.spark.rdd">RDD</a></dt>
+<dd>
+<div class="block">Aggregate the elements of each partition, and then the results for all the partitions, using
+ given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/UnionRDD.html#aggregate-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregate(U, Function2&lt;U, T, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/UnionRDD.html" title="class in org.apache.spark.rdd">UnionRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#aggregate-scala.Function0-scala.Function2-scala.Function2-">aggregate(Function0&lt;B&gt;, Function2&lt;B, A, B&gt;, Function2&lt;B, B, B&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaPairRDD.html#aggregateByKey-U-org.apache.spark.Partitioner-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregateByKey(U, Partitioner, Function2&lt;U, V, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaPairRDD.html" title="class in org.apache.spark.api.java">JavaPairRDD</a></dt>
+<dd>
+<div class="block">Aggregate the values of each key, using given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaPairRDD.html#aggregateByKey-U-int-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregateByKey(U, int, Function2&lt;U, V, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaPairRDD.html" title="class in org.apache.spark.api.java">JavaPairRDD</a></dt>
+<dd>
+<div class="block">Aggregate the values of each key, using given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaPairRDD.html#aggregateByKey-U-org.apache.spark.api.java.function.Function2-org.apache.spark.api.java.function.Function2-">aggregateByKey(U, Function2&lt;U, V, U&gt;, Function2&lt;U, U, U&gt;)</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaPairRDD.html" title="class in org.apache.spark.api.java">JavaPairRDD</a></dt>
+<dd>
+<div class="block">Aggregate the values of each key, using given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/PairRDDFunctions.html#aggregateByKey-U-org.apache.spark.Partitioner-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregateByKey(U, Partitioner, Function2&lt;U, V, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/PairRDDFunctions.html" title="class in org.apache.spark.rdd">PairRDDFunctions</a></dt>
+<dd>
+<div class="block">Aggregate the values of each key, using given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/PairRDDFunctions.html#aggregateByKey-U-int-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregateByKey(U, int, Function2&lt;U, V, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/PairRDDFunctions.html" title="class in org.apache.spark.rdd">PairRDDFunctions</a></dt>
+<dd>
+<div class="block">Aggregate the values of each key, using given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/PairRDDFunctions.html#aggregateByKey-U-scala.Function2-scala.Function2-scala.reflect.ClassTag-">aggregateByKey(U, Function2&lt;U, V, U&gt;, Function2&lt;U, U, U&gt;, ClassTag&lt;U&gt;)</a></span> - Method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/PairRDDFunctions.html" title="class in org.apache.spark.rdd">PairRDDFunctions</a></dt>
+<dd>
+<div class="block">Aggregate the values of each key, using given combine functions and a neutral "zero value".</div>
+</dd>
+<dt><a href="org/apache/spark/sql/jdbc/AggregatedDialect.html" title="class in org.apache.spark.sql.jdbc"><span class="typeNameLink">AggregatedDialect</span></a> - Class in <a href="org/apache/spark/sql/jdbc/package-summary.html">org.apache.spark.sql.jdbc</a></dt>
+<dd>
+<div class="block">AggregatedDialect can unify multiple dialects into one virtual Dialect.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/jdbc/AggregatedDialect.html#AggregatedDialect-scala.collection.immutable.List-">AggregatedDialect(List&lt;JdbcDialect&gt;)</a></span> - Constructor for class org.apache.spark.sql.jdbc.<a href="org/apache/spark/sql/jdbc/AggregatedDialect.html" title="class in org.apache.spark.sql.jdbc">AggregatedDialect</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/Graph.html#aggregateMessages-scala.Function1-scala.Function2-org.apache.spark.graphx.TripletFields-scala.reflect.ClassTag-">aggregateMessages(Function1&lt;EdgeContext&lt;VD, ED, A&gt;, BoxedUnit&gt;, Function2&lt;A, A, A&gt;, TripletFields, ClassTag&lt;A&gt;)</a></span> - Method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/Graph.html" title="class in org.apache.spark.graphx">Graph</a></dt>
+<dd>
+<div class="block">Aggregates values from the neighboring edges and vertices of each vertex.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/GraphImpl.html#aggregateMessages-scala.Function1-scala.Function2-org.apache.spark.graphx.TripletFields-scala.reflect.ClassTag-">aggregateMessages(Function1&lt;EdgeContext&lt;VD, ED, A&gt;, BoxedUnit&gt;, Function2&lt;A, A, A&gt;, TripletFields, ClassTag&lt;A&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/GraphImpl.html" title="class in org.apache.spark.graph [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/GraphImpl.html#aggregateMessages:Ddefault:D3--">aggregateMessages$default$3()</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/GraphImpl.html" title="class in org.apache.spark.graphx.impl">GraphImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/GraphImpl.html#aggregateMessagesWithActiveSet-scala.Function1-scala.Function2-org.apache.spark.graphx.TripletFields-scala.Option-scala.reflect.ClassTag-">aggregateMessagesWithActiveSet(Function1&lt;EdgeContext&lt;VD, ED, A&gt;, BoxedUnit&gt;, Function2&lt;A, A, A&gt;, TripletFields, Option&lt;Tuple2&lt;VertexRDD&lt;?&gt;, EdgeDirection&gt;&gt;, ClassTag&lt;A&gt;)</a></span> - Method in class org.apache.spark.graphx.im [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/VertexRDDImpl.html#aggregateUsingIndex-org.apache.spark.rdd.RDD-scala.Function2-scala.reflect.ClassTag-">aggregateUsingIndex(RDD&lt;Tuple2&lt;Object, VD2&gt;&gt;, Function2&lt;VD2, VD2, VD2&gt;, ClassTag&lt;VD2&gt;)</a></span> - Method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/VertexRDDImpl.html" title="class in org.apache.spark.graphx.impl">VertexRDDImpl</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/VertexRDD.html#aggregateUsingIndex-org.apache.spark.rdd.RDD-scala.Function2-scala.reflect.ClassTag-">aggregateUsingIndex(RDD&lt;Tuple2&lt;Object, VD2&gt;&gt;, Function2&lt;VD2, VD2, VD2&gt;, ClassTag&lt;VD2&gt;)</a></span> - Method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></dt>
+<dd>
+<div class="block">Aggregates vertices in <code>messages</code> that have the same ids using <code>reduceFunc</code>, returning a
+ VertexRDD co-indexed with <code>this</code>.</div>
+</dd>
+<dt><a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html" title="class in org.apache.spark.graphx.impl"><span class="typeNameLink">AggregatingEdgeContext</span></a>&lt;<a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html" title="type parameter in AggregatingEdgeContext">VD</a>,<a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html" title="type parameter in AggregatingEdgeContext">ED</a>,<a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html#AggregatingEdgeContext-scala.Function2-java.lang.Object-org.apache.spark.util.collection.BitSet-">AggregatingEdgeContext(Function2&lt;A, A, A&gt;, Object, BitSet)</a></span> - Constructor for class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/AggregatingEdgeContext.html" title="class in org.apache.spark.graphx.impl">AggregatingEdgeContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/LinearSVC.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/LinearSVC.html" title="class in org.apache.spark.ml.classification">LinearSVC</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/LinearSVCModel.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/LinearSVCModel.html" title="class in org.apache.spark.ml.classification">LinearSVCModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/LogisticRegression.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/LogisticRegression.html" title="class in org.apache.spark.ml.classification">LogisticRegression</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/LogisticRegressionModel.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/LogisticRegressionModel.html" title="class in org.apache.spark.ml.classification">LogisticRegressionModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/param/shared/HasAggregationDepth.html#aggregationDepth--">aggregationDepth()</a></span> - Method in interface org.apache.spark.ml.param.shared.<a href="org/apache/spark/ml/param/shared/HasAggregationDepth.html" title="interface in org.apache.spark.ml.param.shared">HasAggregationDepth</a></dt>
+<dd>
+<div class="block">Param for suggested depth for treeAggregate (&amp;gt;= 2).</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTSurvivalRegression.html" title="class in org.apache.spark.ml.regression">AFTSurvivalRegression</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/AFTSurvivalRegressionModel.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/AFTSurvivalRegressionModel.html" title="class in org.apache.spark.ml.regression">AFTSurvivalRegressionModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/LinearRegression.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/LinearRegression.html" title="class in org.apache.spark.ml.regression">LinearRegression</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/LinearRegressionModel.html#aggregationDepth--">aggregationDepth()</a></span> - Static method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/LinearRegressionModel.html" title="class in org.apache.spark.ml.regression">LinearRegressionModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/Aggregator.html" title="class in org.apache.spark"><span class="typeNameLink">Aggregator</span></a>&lt;<a href="org/apache/spark/Aggregator.html" title="type parameter in Aggregator">K</a>,<a href="org/apache/spark/Aggregator.html" title="type parameter in Aggregator">V</a>,<a href="org/apache/spark/Aggregator.html" title="type parameter in Aggregator">C</a>&gt; - Class in <a href="org/apache/spark/package-summary.html">org.apache.spark</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ A set of functions used to aggregate data.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/Aggregator.html#Aggregator-scala.Function1-scala.Function2-scala.Function2-">Aggregator(Function1&lt;V, C&gt;, Function2&lt;C, V, C&gt;, Function2&lt;C, C, C&gt;)</a></span> - Constructor for class org.apache.spark.<a href="org/apache/spark/Aggregator.html" title="class in org.apache.spark">Aggregator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ShuffleDependency.html#aggregator--">aggregator()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/ShuffleDependency.html" title="class in org.apache.spark">ShuffleDependency</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/sql/expressions/Aggregator.html" title="class in org.apache.spark.sql.expressions"><span class="typeNameLink">Aggregator</span></a>&lt;<a href="org/apache/spark/sql/expressions/Aggregator.html" title="type parameter in Aggregator">IN</a>,<a href="org/apache/spark/sql/expressions/Aggregator.html" title="type parameter in Aggregator">BUF</a>,<a href="org/apache/spark/sql/expressions/Aggregator.html" title="type parameter in Aggregator">OUT</a>&gt; - Class in < [...]
+<dd>
+<div class="block">:: Experimental ::
+ A base class for user-defined aggregations, which can be used in <code>Dataset</code> operations to take
+ all of the elements of a group and reduce them to a single value.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/Aggregator.html#Aggregator--">Aggregator()</a></span> - Constructor for class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/Aggregator.html" title="class in org.apache.spark.sql.expressions">Aggregator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Binomial$.html#aic-org.apache.spark.rdd.RDD-double-double-double-">aic(RDD&lt;Tuple3&lt;Object, Object, Object&gt;&gt;, double, double, double)</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Binomial$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Binomial$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gamma$.html#aic-org.apache.spark.rdd.RDD-double-double-double-">aic(RDD&lt;Tuple3&lt;Object, Object, Object&gt;&gt;, double, double, double)</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gamma$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Gamma$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gaussian$.html#aic-org.apache.spark.rdd.RDD-double-double-double-">aic(RDD&lt;Tuple3&lt;Object, Object, Object&gt;&gt;, double, double, double)</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Gaussian$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Gaussian$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Poisson$.html#aic-org.apache.spark.rdd.RDD-double-double-double-">aic(RDD&lt;Tuple3&lt;Object, Object, Object&gt;&gt;, double, double, double)</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.Poisson$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.Poisson$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionSummary.html#aic--">aic()</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/GeneralizedLinearRegressionSummary.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegressionSummary</a></dt>
+<dd>
+<div class="block">Akaike Information Criterion (AIC) for the fitted model.</div>
+</dd>
+<dt><a href="org/apache/spark/mllib/tree/configuration/Algo.html" title="class in org.apache.spark.mllib.tree.configuration"><span class="typeNameLink">Algo</span></a> - Class in <a href="org/apache/spark/mllib/tree/configuration/package-summary.html">org.apache.spark.mllib.tree.configuration</a></dt>
+<dd>
+<div class="block">Enum to select the algorithm for the decision tree</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/Algo.html#Algo--">Algo()</a></span> - Constructor for class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/Algo.html" title="class in org.apache.spark.mllib.tree.configuration">Algo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/Strategy.html#algo--">algo()</a></span> - Method in class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/Strategy.html" title="class in org.apache.spark.mllib.tree.configuration">Strategy</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.html#algo--">algo()</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/GradientBoostedTreesModel.html#algo--">algo()</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/GradientBoostedTreesModel.html" title="class in org.apache.spark.mllib.tree.model">GradientBoostedTreesModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/RandomForestModel.html#algo--">algo()</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/RandomForestModel.html" title="class in org.apache.spark.mllib.tree.model">RandomForestModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/regression/StreamingLinearRegressionWithSGD.html#algorithm--">algorithm()</a></span> - Method in class org.apache.spark.mllib.regression.<a href="org/apache/spark/mllib/regression/StreamingLinearRegressionWithSGD.html" title="class in org.apache.spark.mllib.regression">StreamingLinearRegressionWithSGD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#alias-java.lang.String-">alias(String)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Gives the column an alias.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#alias-java.lang.String-">alias(String)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">Returns a new Dataset with an alias set.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#alias-scala.Symbol-">alias(Symbol)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">(Scala-specific) Returns a new Dataset with an alias set.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/TripletFields.html#All">All</a></span> - Static variable in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/TripletFields.html" title="class in org.apache.spark.graphx">TripletFields</a></dt>
+<dd>
+<div class="block">Expose all the fields (source, edge, and destination).</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html#allAttributes--">allAttributes()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution">CreateHiveTableAsSelectCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html#allAttributes--">allAttributes()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveDirCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html#allAttributes--">allAttributes()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveTable</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html#allAttributes--">allAttributes()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html" title="class in org.apache.spark.sql.hive.execution">ScriptTransformationExec</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/scheduler/AllJobsCancelled.html" title="class in org.apache.spark.scheduler"><span class="typeNameLink">AllJobsCancelled</span></a> - Class in <a href="org/apache/spark/scheduler/package-summary.html">org.apache.spark.scheduler</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AllJobsCancelled.html#AllJobsCancelled--">AllJobsCancelled()</a></span> - Constructor for class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AllJobsCancelled.html" title="class in org.apache.spark.scheduler">AllJobsCancelled</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/memory/SerializedValuesHolder.html#allocator--">allocator()</a></span> - Method in class org.apache.spark.storage.memory.<a href="org/apache/spark/storage/memory/SerializedValuesHolder.html" title="class in org.apache.spark.storage.memory">SerializedValuesHolder</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/streaming/scheduler/AllReceiverIds.html" title="class in org.apache.spark.streaming.scheduler"><span class="typeNameLink">AllReceiverIds</span></a> - Class in <a href="org/apache/spark/streaming/scheduler/package-summary.html">org.apache.spark.streaming.scheduler</a></dt>
+<dd>
+<div class="block">A message used by ReceiverTracker to ask all receiver's ids still stored in
+ ReceiverTrackerEndpoint.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/scheduler/AllReceiverIds.html#AllReceiverIds--">AllReceiverIds()</a></span> - Constructor for class org.apache.spark.streaming.scheduler.<a href="org/apache/spark/streaming/scheduler/AllReceiverIds.html" title="class in org.apache.spark.streaming.scheduler">AllReceiverIds</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/metrics/source/StaticSources.html#allSources--">allSources()</a></span> - Static method in class org.apache.spark.metrics.source.<a href="org/apache/spark/metrics/source/StaticSources.html" title="class in org.apache.spark.metrics.source">StaticSources</a></dt>
+<dd>
+<div class="block">The set of all static sources.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/recommendation/ALS.html#alpha--">alpha()</a></span> - Static method in class org.apache.spark.ml.recommendation.<a href="org/apache/spark/ml/recommendation/ALS.html" title="class in org.apache.spark.ml.recommendation">ALS</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/random/WeibullGenerator.html#alpha--">alpha()</a></span> - Method in class org.apache.spark.mllib.random.<a href="org/apache/spark/mllib/random/WeibullGenerator.html" title="class in org.apache.spark.mllib.random">WeibullGenerator</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/recommendation/ALS.html" title="class in org.apache.spark.ml.recommendation"><span class="typeNameLink">ALS</span></a> - Class in <a href="org/apache/spark/ml/recommendation/package-summary.html">org.apache.spark.ml.recommendation</a></dt>
+<dd>
+<div class="block">Alternating Least Squares (ALS) matrix factorization.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/recommendation/ALS.html#ALS-java.lang.String-">ALS(String)</a></span> - Constructor for class org.apache.spark.ml.recommendation.<a href="org/apache/spark/ml/recommendation/ALS.html" title="class in org.apache.spark.ml.recommendation">ALS</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/recommendation/ALS.html#ALS--">ALS()</a></span> - Constructor for class org.apache.spark.ml.recommendation.<a href="org/apache/spark/ml/recommendation/ALS.html" title="class in org.apache.spark.ml.recommendation">ALS</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/mllib/recommendation/ALS.html" title="class in org.apache.spark.mllib.recommendation"><span class="typeNameLink">ALS</span></a> - Class in <a href="org/apache/spark/mllib/recommendation/package-summary.html">org.apache.spark.mllib.recommendation</a></dt>
+<dd>
+<div class="block">Alternating Least Squares matrix factorization.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/recommendation/ALS.html#ALS--">ALS()</a></span> - Constructor for class org.apache.spark.mllib.recommendation.<a href="org/apache/spark/mllib/recommendation/ALS.html" title="class in org.apache.spark.mllib.recommendation">ALS</a></dt>
+<dd>
+<div class="block">Constructs an ALS instance with default parameters: {numBlocks: -1, rank: 10, iterations: 10,
+ lambda: 0.01, implicitPrefs: false, alpha: 1.0}.</div>
+</dd>
+<dt><a href="org/apache/spark/ml/recommendation/ALS.InBlock$.html" title="class in org.apache.spark.ml.recommendation"><span class="typeNameLink">ALS.InBlock$</span></a> - Class in <a href="org/apache/spark/ml/recommendation/package-summary.html">org.apache.spark.ml.recommendation</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/recommendation/ALS.Rating.html" title="class in org.apache.spark.ml.recommendation"><span class="typeNameLink">ALS.Rating</span></a>&lt;<a href="org/apache/spark/ml/recommendation/ALS.Rating.html" title="type parameter in ALS.Rating">ID</a>&gt; - Class in <a href="org/apache/spark/ml/recommendation/package-summary.html">org.apache.spark.ml.recommendation</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Rating class for better code readability.</div>
+</dd>
+<dt><a href="org/apache/spark/ml/recommendation/ALS.Rating$.html" title="class in org.apache.spark.ml.recommendation"><span class="typeNameLink">ALS.Rating$</span></a> - Class in <a href="org/apache/spark/ml/recommendation/package-summary.html">org.apache.spark.ml.recommendation</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/recommendation/ALS.RatingBlock$.html" title="class in org.apache.spark.ml.recommendation"><span class="typeNameLink">ALS.RatingBlock$</span></a> - Class in <a href="org/apache/spark/ml/recommendation/package-summary.html">org.apache.spark.ml.recommendation</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/recommendation/ALSModel.html" title="class in org.apache.spark.ml.recommendation"><span class="typeNameLink">ALSModel</span></a> - Class in <a href="org/apache/spark/ml/recommendation/package-summary.html">org.apache.spark.ml.recommendation</a></dt>
+<dd>
+<div class="block">Model fitted by ALS.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterClusterManager.html#am--">am()</a></span> - Method in class org.apache.spark.scheduler.cluster.<a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.RegisterClusterManager.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.RegisterClusterManager</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/sql/AnalysisException.html" title="class in org.apache.spark.sql"><span class="typeNameLink">AnalysisException</span></a> - Exception in <a href="org/apache/spark/sql/package-summary.html">org.apache.spark.sql</a></dt>
+<dd>
+<div class="block">Thrown when a query fails to analyze, usually because the query itself is invalid.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html#analyzed--">analyzed()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution">CreateHiveTableAsSelectCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html#analyzed--">analyzed()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveDirCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html#analyzed--">analyzed()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveTable</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#and-org.apache.spark.sql.Column-">and(Column)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Boolean AND.</div>
+</dd>
+<dt><a href="org/apache/spark/sql/sources/And.html" title="class in org.apache.spark.sql.sources"><span class="typeNameLink">And</span></a> - Class in <a href="org/apache/spark/sql/sources/package-summary.html">org.apache.spark.sql.sources</a></dt>
+<dd>
+<div class="block">A filter that evaluates to <code>true</code> iff both <code>left</code> or <code>right</code> evaluate to <code>true</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/sources/And.html#And-org.apache.spark.sql.sources.Filter-org.apache.spark.sql.sources.Filter-">And(Filter, Filter)</a></span> - Constructor for class org.apache.spark.sql.sources.<a href="org/apache/spark/sql/sources/And.html" title="class in org.apache.spark.sql.sources">And</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#andThen-scala.Function1-">andThen(Function1&lt;B, C&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/fpm/AssociationRules.Rule.html#antecedent--">antecedent()</a></span> - Method in class org.apache.spark.mllib.fpm.<a href="org/apache/spark/mllib/fpm/AssociationRules.Rule.html" title="class in org.apache.spark.mllib.fpm">AssociationRules.Rule</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/TaskLocality.html#ANY--">ANY()</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/TaskLocality.html" title="class in org.apache.spark.scheduler">TaskLocality</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/sql/types/AnyDataType.html" title="class in org.apache.spark.sql.types"><span class="typeNameLink">AnyDataType</span></a> - Class in <a href="org/apache/spark/sql/types/package-summary.html">org.apache.spark.sql.types</a></dt>
+<dd>
+<div class="block">An <code>AbstractDataType</code> that matches any concrete data types.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/AnyDataType.html#AnyDataType--">AnyDataType()</a></span> - Constructor for class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/AnyDataType.html" title="class in org.apache.spark.sql.types">AnyDataType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Row.html#anyNull--">anyNull()</a></span> - Method in interface org.apache.spark.sql.<a href="org/apache/spark/sql/Row.html" title="interface in org.apache.spark.sql">Row</a></dt>
+<dd>
+<div class="block">Returns true if there are any NULL values in this row.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/vectorized/ColumnarRow.html#anyNull--">anyNull()</a></span> - Method in class org.apache.spark.sql.vectorized.<a href="org/apache/spark/sql/vectorized/ColumnarRow.html" title="class in org.apache.spark.sql.vectorized">ColumnarRow</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ui/jobs/ApiHelper.html" title="class in org.apache.spark.ui.jobs"><span class="typeNameLink">ApiHelper</span></a> - Class in <a href="org/apache/spark/ui/jobs/package-summary.html">org.apache.spark.ui.jobs</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ui/jobs/ApiHelper.html#ApiHelper--">ApiHelper()</a></span> - Constructor for class org.apache.spark.ui.jobs.<a href="org/apache/spark/ui/jobs/ApiHelper.html" title="class in org.apache.spark.ui.jobs">ApiHelper</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html#appAttemptId--">appAttemptId()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html" title="class in org.apache.spark.scheduler">SparkListenerApplicationStart</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/streaming/OutputMode.html#Append--">Append()</a></span> - Static method in class org.apache.spark.sql.streaming.<a href="org/apache/spark/sql/streaming/OutputMode.html" title="class in org.apache.spark.sql.streaming">OutputMode</a></dt>
+<dd>
+<div class="block">OutputMode in which only the new rows in the streaming DataFrame/Dataset will be
+ written to the sink.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/util/MLUtils.html#appendBias-org.apache.spark.mllib.linalg.Vector-">appendBias(Vector)</a></span> - Static method in class org.apache.spark.mllib.util.<a href="org/apache/spark/mllib/util/MLUtils.html" title="class in org.apache.spark.mllib.util">MLUtils</a></dt>
+<dd>
+<div class="block">Returns a new vector with <code>1.0</code> (bias) appended to the input vector.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/util/SchemaUtils.html#appendColumn-org.apache.spark.sql.types.StructType-java.lang.String-org.apache.spark.sql.types.DataType-boolean-">appendColumn(StructType, String, DataType, boolean)</a></span> - Static method in class org.apache.spark.ml.util.<a href="org/apache/spark/ml/util/SchemaUtils.html" title="class in org.apache.spark.ml.util">SchemaUtils</a></dt>
+<dd>
+<div class="block">Appends a new column to the input schema.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/util/SchemaUtils.html#appendColumn-org.apache.spark.sql.types.StructType-org.apache.spark.sql.types.StructField-">appendColumn(StructType, StructField)</a></span> - Static method in class org.apache.spark.ml.util.<a href="org/apache/spark/ml/util/SchemaUtils.html" title="class in org.apache.spark.ml.util">SchemaUtils</a></dt>
+<dd>
+<div class="block">Appends a new column to the input schema.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/HiveShim.html#appendReadColumns-org.apache.hadoop.conf.Configuration-scala.collection.Seq-scala.collection.Seq-">appendReadColumns(Configuration, Seq&lt;Integer&gt;, Seq&lt;String&gt;)</a></span> - Static method in class org.apache.spark.sql.hive.<a href="org/apache/spark/sql/hive/HiveShim.html" title="class in org.apache.spark.sql.hive">HiveShim</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html#appId--">appId()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html" title="class in org.apache.spark.scheduler">SparkListenerApplicationStart</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ui/ToolTips.html#APPLICATION_EXECUTOR_LIMIT--">APPLICATION_EXECUTOR_LIMIT()</a></span> - Static method in class org.apache.spark.ui.<a href="org/apache/spark/ui/ToolTips.html" title="class in org.apache.spark.ui">ToolTips</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#applicationAttemptId--">applicationAttemptId()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html" title="class in org.apache.spark.status.api.v1"><span class="typeNameLink">ApplicationAttemptInfo</span></a> - Class in <a href="org/apache/spark/status/api/v1/package-summary.html">org.apache.spark.status.api.v1</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#applicationEndFromJson-org.json4s.JsonAST.JValue-">applicationEndFromJson(JsonAST.JValue)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#applicationEndToJson-org.apache.spark.scheduler.SparkListenerApplicationEnd-">applicationEndToJson(SparkListenerApplicationEnd)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/status/api/v1/ApplicationEnvironmentInfo.html" title="class in org.apache.spark.status.api.v1"><span class="typeNameLink">ApplicationEnvironmentInfo</span></a> - Class in <a href="org/apache/spark/status/api/v1/package-summary.html">org.apache.spark.status.api.v1</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#applicationId--">applicationId()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>
+<div class="block">A unique identifier for the Spark application.</div>
+</dd>
+<dt><a href="org/apache/spark/status/api/v1/ApplicationInfo.html" title="class in org.apache.spark.status.api.v1"><span class="typeNameLink">ApplicationInfo</span></a> - Class in <a href="org/apache/spark/status/api/v1/package-summary.html">org.apache.spark.status.api.v1</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#applicationStartFromJson-org.json4s.JsonAST.JValue-">applicationStartFromJson(JsonAST.JValue)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/JsonProtocol.html#applicationStartToJson-org.apache.spark.scheduler.SparkListenerApplicationStart-">applicationStartToJson(SparkListenerApplicationStart)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/JsonProtocol.html" title="class in org.apache.spark.util">JsonProtocol</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/status/api/v1/ApplicationStatus.html" title="enum in org.apache.spark.status.api.v1"><span class="typeNameLink">ApplicationStatus</span></a> - Enum in <a href="org/apache/spark/status/api/v1/package-summary.html">org.apache.spark.status.api.v1</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/Graph.html#apply-org.apache.spark.rdd.RDD-org.apache.spark.rdd.RDD-VD-org.apache.spark.storage.StorageLevel-org.apache.spark.storage.StorageLevel-scala.reflect.ClassTag-scala.reflect.ClassTag-">apply(RDD&lt;Tuple2&lt;Object, VD&gt;&gt;, RDD&lt;Edge&lt;ED&gt;&gt;, VD, StorageLevel, StorageLevel, ClassTag&lt;VD&gt;, ClassTag&lt;ED&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/grap [...]
+<dd>
+<div class="block">Construct a graph from a collection of vertices and
+ edges with attributes.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/GraphImpl.html#apply-org.apache.spark.rdd.RDD-VD-org.apache.spark.storage.StorageLevel-org.apache.spark.storage.StorageLevel-scala.reflect.ClassTag-scala.reflect.ClassTag-">apply(RDD&lt;Edge&lt;ED&gt;&gt;, VD, StorageLevel, StorageLevel, ClassTag&lt;VD&gt;, ClassTag&lt;ED&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/GraphImpl.html" title="class in org.apac [...]
+<dd>
+<div class="block">Create a graph from edges, setting referenced vertices to <code>defaultVertexAttr</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/GraphImpl.html#apply-org.apache.spark.rdd.RDD-org.apache.spark.rdd.RDD-VD-org.apache.spark.storage.StorageLevel-org.apache.spark.storage.StorageLevel-scala.reflect.ClassTag-scala.reflect.ClassTag-">apply(RDD&lt;Tuple2&lt;Object, VD&gt;&gt;, RDD&lt;Edge&lt;ED&gt;&gt;, VD, StorageLevel, StorageLevel, ClassTag&lt;VD&gt;, ClassTag&lt;ED&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apa [...]
+<dd>
+<div class="block">Create a graph from vertices and edges, setting missing vertices to <code>defaultVertexAttr</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/impl/GraphImpl.html#apply-org.apache.spark.graphx.VertexRDD-org.apache.spark.graphx.EdgeRDD-scala.reflect.ClassTag-scala.reflect.ClassTag-">apply(VertexRDD&lt;VD&gt;, EdgeRDD&lt;ED&gt;, ClassTag&lt;VD&gt;, ClassTag&lt;ED&gt;)</a></span> - Static method in class org.apache.spark.graphx.impl.<a href="org/apache/spark/graphx/impl/GraphImpl.html" title="class in org.apache.spark.graphx.impl">GraphImpl</a></dt>
+<dd>
+<div class="block">Create a graph from a VertexRDD and an EdgeRDD with arbitrary replicated vertices.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/Pregel.html#apply-org.apache.spark.graphx.Graph-A-int-org.apache.spark.graphx.EdgeDirection-scala.Function3-scala.Function1-scala.Function2-scala.reflect.ClassTag-scala.reflect.ClassTag-scala.reflect.ClassTag-">apply(Graph&lt;VD, ED&gt;, A, int, EdgeDirection, Function3&lt;Object, VD, A, VD&gt;, Function1&lt;EdgeTriplet&lt;VD, ED&gt;, Iterator&lt;Tuple2&lt;Object, A&gt;&gt;&gt;, Function2&lt;A, A, A&gt;, ClassTag&lt;VD&gt; [...]
+<dd>
+<div class="block">Execute a Pregel-like iterative vertex-parallel abstraction.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/VertexRDD.html#apply-org.apache.spark.rdd.RDD-scala.reflect.ClassTag-">apply(RDD&lt;Tuple2&lt;Object, VD&gt;&gt;, ClassTag&lt;VD&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></dt>
+<dd>
+<div class="block">Constructs a standalone <code>VertexRDD</code> (one that is not set up for efficient joins with an
+ <a href="org/apache/spark/graphx/EdgeRDD.html" title="class in org.apache.spark.graphx"><code>EdgeRDD</code></a>) from an RDD of vertex-attribute pairs.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/VertexRDD.html#apply-org.apache.spark.rdd.RDD-org.apache.spark.graphx.EdgeRDD-VD-scala.reflect.ClassTag-">apply(RDD&lt;Tuple2&lt;Object, VD&gt;&gt;, EdgeRDD&lt;?&gt;, VD, ClassTag&lt;VD&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></dt>
+<dd>
+<div class="block">Constructs a <code>VertexRDD</code> from an RDD of vertex-attribute pairs.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/VertexRDD.html#apply-org.apache.spark.rdd.RDD-org.apache.spark.graphx.EdgeRDD-VD-scala.Function2-scala.reflect.ClassTag-">apply(RDD&lt;Tuple2&lt;Object, VD&gt;&gt;, EdgeRDD&lt;?&gt;, VD, Function2&lt;VD, VD, VD&gt;, ClassTag&lt;VD&gt;)</a></span> - Static method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/VertexRDD.html" title="class in org.apache.spark.graphx">VertexRDD</a></dt>
+<dd>
+<div class="block">Constructs a <code>VertexRDD</code> from an RDD of vertex-attribute pairs.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/ann/ApplyInPlace.html#apply-breeze.linalg.DenseMatrix-breeze.linalg.DenseMatrix-scala.Function1-">apply(DenseMatrix&lt;Object&gt;, DenseMatrix&lt;Object&gt;, Function1&lt;Object, Object&gt;)</a></span> - Static method in class org.apache.spark.ml.ann.<a href="org/apache/spark/ml/ann/ApplyInPlace.html" title="class in org.apache.spark.ml.ann">ApplyInPlace</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/ann/ApplyInPlace.html#apply-breeze.linalg.DenseMatrix-breeze.linalg.DenseMatrix-breeze.linalg.DenseMatrix-scala.Function2-">apply(DenseMatrix&lt;Object&gt;, DenseMatrix&lt;Object&gt;, DenseMatrix&lt;Object&gt;, Function2&lt;Object, Object, Object&gt;)</a></span> - Static method in class org.apache.spark.ml.ann.<a href="org/apache/spark/ml/ann/ApplyInPlace.html" title="class in org.apache.spark.ml.ann">ApplyInPlace</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/attribute/AttributeGroup.html#apply-java.lang.String-">apply(String)</a></span> - Method in class org.apache.spark.ml.attribute.<a href="org/apache/spark/ml/attribute/AttributeGroup.html" title="class in org.apache.spark.ml.attribute">AttributeGroup</a></dt>
+<dd>
+<div class="block">Gets an attribute by its name.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/attribute/AttributeGroup.html#apply-int-">apply(int)</a></span> - Method in class org.apache.spark.ml.attribute.<a href="org/apache/spark/ml/attribute/AttributeGroup.html" title="class in org.apache.spark.ml.attribute">AttributeGroup</a></dt>
+<dd>
+<div class="block">Gets an attribute by its index.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/DenseMatrix.html#apply-int-int-">apply(int, int)</a></span> - Method in class org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/DenseMatrix.html" title="class in org.apache.spark.ml.linalg">DenseMatrix</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/DenseVector.html#apply-int-">apply(int)</a></span> - Method in class org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/DenseVector.html" title="class in org.apache.spark.ml.linalg">DenseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/Matrix.html#apply-int-int-">apply(int, int)</a></span> - Method in interface org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/Matrix.html" title="interface in org.apache.spark.ml.linalg">Matrix</a></dt>
+<dd>
+<div class="block">Gets the (i, j)-th element.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/SparseMatrix.html#apply-int-int-">apply(int, int)</a></span> - Method in class org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/SparseMatrix.html" title="class in org.apache.spark.ml.linalg">SparseMatrix</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/SparseVector.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/SparseVector.html" title="class in org.apache.spark.ml.linalg">SparseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/Vector.html#apply-int-">apply(int)</a></span> - Method in interface org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/Vector.html" title="interface in org.apache.spark.ml.linalg">Vector</a></dt>
+<dd>
+<div class="block">Gets the value of the ith element.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/param/ParamMap.html#apply-org.apache.spark.ml.param.Param-">apply(Param&lt;T&gt;)</a></span> - Method in class org.apache.spark.ml.param.<a href="org/apache/spark/ml/param/ParamMap.html" title="class in org.apache.spark.ml.param">ParamMap</a></dt>
+<dd>
+<div class="block">Gets the value of the input param or its default value if it does not exist.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.FamilyAndLink$.html#apply-org.apache.spark.ml.regression.GeneralizedLinearRegressionBase-">apply(GeneralizedLinearRegressionBase)</a></span> - Method in class org.apache.spark.ml.regression.<a href="org/apache/spark/ml/regression/GeneralizedLinearRegression.FamilyAndLink$.html" title="class in org.apache.spark.ml.regression">GeneralizedLinearRegression.FamilyAndLink$</a></dt>
+<dd>
+<div class="block">Constructs the FamilyAndLink object from a parameter map</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.SplitData$.html#apply-org.apache.spark.ml.tree.Split-">apply(Split)</a></span> - Method in class org.apache.spark.ml.tree.<a href="org/apache/spark/ml/tree/DecisionTreeModelReadWrite.SplitData$.html" title="class in org.apache.spark.ml.tree">DecisionTreeModelReadWrite.SplitData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/binary/FalsePositiveRate.html#apply-org.apache.spark.mllib.evaluation.binary.BinaryConfusionMatrix-">apply(BinaryConfusionMatrix)</a></span> - Static method in class org.apache.spark.mllib.evaluation.binary.<a href="org/apache/spark/mllib/evaluation/binary/FalsePositiveRate.html" title="class in org.apache.spark.mllib.evaluation.binary">FalsePositiveRate</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/binary/Precision.html#apply-org.apache.spark.mllib.evaluation.binary.BinaryConfusionMatrix-">apply(BinaryConfusionMatrix)</a></span> - Static method in class org.apache.spark.mllib.evaluation.binary.<a href="org/apache/spark/mllib/evaluation/binary/Precision.html" title="class in org.apache.spark.mllib.evaluation.binary">Precision</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/binary/Recall.html#apply-org.apache.spark.mllib.evaluation.binary.BinaryConfusionMatrix-">apply(BinaryConfusionMatrix)</a></span> - Static method in class org.apache.spark.mllib.evaluation.binary.<a href="org/apache/spark/mllib/evaluation/binary/Recall.html" title="class in org.apache.spark.mllib.evaluation.binary">Recall</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/DenseMatrix.html#apply-int-int-">apply(int, int)</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/DenseMatrix.html" title="class in org.apache.spark.mllib.linalg">DenseMatrix</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/DenseVector.html#apply-int-">apply(int)</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/DenseVector.html" title="class in org.apache.spark.mllib.linalg">DenseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Matrix.html#apply-int-int-">apply(int, int)</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Matrix.html" title="interface in org.apache.spark.mllib.linalg">Matrix</a></dt>
+<dd>
+<div class="block">Gets the (i, j)-th element.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/SparseMatrix.html#apply-int-int-">apply(int, int)</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/SparseMatrix.html" title="class in org.apache.spark.mllib.linalg">SparseMatrix</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/SparseVector.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/SparseVector.html" title="class in org.apache.spark.mllib.linalg">SparseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Vector.html#apply-int-">apply(int)</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Vector.html" title="interface in org.apache.spark.mllib.linalg">Vector</a></dt>
+<dd>
+<div class="block">Gets the value of the ith element.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/Algo.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/Algo.html" title="class in org.apache.spark.mllib.tree.configuration">Algo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/EnsembleCombiningStrategy.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/EnsembleCombiningStrategy.html" title="class in org.apache.spark.mllib.tree.configuration">EnsembleCombiningStrategy</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/FeatureType.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/FeatureType.html" title="class in org.apache.spark.mllib.tree.configuration">FeatureType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/QuantileStrategy.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/QuantileStrategy.html" title="class in org.apache.spark.mllib.tree.configuration">QuantileStrategy</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData$.html#apply-int-org.apache.spark.mllib.tree.model.Node-">apply(int, Node)</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.NodeData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData$.html#apply-org.apache.spark.sql.Row-">apply(Row)</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.NodeData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData.html#apply-int-org.apache.spark.mllib.tree.model.Node-">apply(int, Node)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.NodeData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData.html#apply-org.apache.spark.sql.Row-">apply(Row)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.NodeData.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.NodeData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData$.html#apply-org.apache.spark.mllib.tree.model.Predict-">apply(Predict)</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.PredictData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData$.html#apply-org.apache.spark.sql.Row-">apply(Row)</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.PredictData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData.html#apply-org.apache.spark.mllib.tree.model.Predict-">apply(Predict)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.PredictData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData.html#apply-org.apache.spark.sql.Row-">apply(Row)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.PredictData.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.PredictData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData$.html#apply-org.apache.spark.mllib.tree.model.Split-">apply(Split)</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.SplitData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData$.html#apply-org.apache.spark.sql.Row-">apply(Row)</a></span> - Method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData$.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.SplitData$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData.html#apply-org.apache.spark.mllib.tree.model.Split-">apply(Split)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.SplitData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData.html#apply-org.apache.spark.sql.Row-">apply(Row)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/DecisionTreeModel.SaveLoadV1_0$.SplitData.html" title="class in org.apache.spark.mllib.tree.model">DecisionTreeModel.SaveLoadV1_0$.SplitData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/model/Node.html#apply-int-org.apache.spark.mllib.tree.model.Predict-double-boolean-">apply(int, Predict, double, boolean)</a></span> - Static method in class org.apache.spark.mllib.tree.model.<a href="org/apache/spark/mllib/tree/model/Node.html" title="class in org.apache.spark.mllib.tree.model">Node</a></dt>
+<dd>
+<div class="block">Construct a node with nodeIndex, predict, impurity and isLeaf parameters.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/CheckpointState.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/CheckpointState.html" title="class in org.apache.spark.rdd">CheckpointState</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/DeterministicLevel.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.rdd.<a href="org/apache/spark/rdd/DeterministicLevel.html" title="class in org.apache.spark.rdd">DeterministicLevel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AccumulableInfo.html#apply-long-java.lang.String-scala.Option-java.lang.String-boolean-">apply(long, String, Option&lt;String&gt;, String, boolean)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AccumulableInfo.html" title="class in org.apache.spark.scheduler">AccumulableInfo</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">do not create AccumulableInfo. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AccumulableInfo.html#apply-long-java.lang.String-scala.Option-java.lang.String-">apply(long, String, Option&lt;String&gt;, String)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AccumulableInfo.html" title="class in org.apache.spark.scheduler">AccumulableInfo</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">do not create AccumulableInfo. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AccumulableInfo.html#apply-long-java.lang.String-java.lang.String-">apply(long, String, String)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AccumulableInfo.html" title="class in org.apache.spark.scheduler">AccumulableInfo</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">do not create AccumulableInfo. Since 2.0.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StatusUpdate$.html#apply-java.lang.String-long-scala.Enumeration.Value-java.nio.ByteBuffer-">apply(String, long, Enumeration.Value, ByteBuffer)</a></span> - Method in class org.apache.spark.scheduler.cluster.<a href="org/apache/spark/scheduler/cluster/CoarseGrainedClusterMessages.StatusUpdate$.html" title="class in org.apache.spark.scheduler.cluster">CoarseGrainedClusterMessages.Stat [...]
+<dd>
+<div class="block">Alternate factory method that takes a ByteBuffer directly for the data field</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/RuntimePercentage.html#apply-long-org.apache.spark.executor.TaskMetrics-">apply(long, TaskMetrics)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/RuntimePercentage.html" title="class in org.apache.spark.scheduler">RuntimePercentage</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/SchedulingMode.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/SchedulingMode.html" title="class in org.apache.spark.scheduler">SchedulingMode</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/TaskLocality.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/TaskLocality.html" title="class in org.apache.spark.scheduler">TaskLocality</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#apply-java.lang.Object-">apply(Object)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Extracts a value or values from a complex type.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#apply-java.lang.String-">apply(String)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">Selects column based on the column name and returns it as a <a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql"><code>Column</code></a>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/UserDefinedAggregateFunction.html#apply-org.apache.spark.sql.Column...-">apply(Column...)</a></span> - Method in class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/UserDefinedAggregateFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedAggregateFunction</a></dt>
+<dd>
+<div class="block">Creates a <code>Column</code> for this UDAF using given <code>Column</code>s as input arguments.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/UserDefinedAggregateFunction.html#apply-scala.collection.Seq-">apply(Seq&lt;Column&gt;)</a></span> - Method in class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/UserDefinedAggregateFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedAggregateFunction</a></dt>
+<dd>
+<div class="block">Creates a <code>Column</code> for this UDAF using given <code>Column</code>s as input arguments.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/UserDefinedFunction.html#apply-org.apache.spark.sql.Column...-">apply(Column...)</a></span> - Method in class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/UserDefinedFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedFunction</a></dt>
+<dd>
+<div class="block">Returns an expression that invokes the UDF, using the given arguments.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/UserDefinedFunction.html#apply-scala.collection.Seq-">apply(Seq&lt;Column&gt;)</a></span> - Method in class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/UserDefinedFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedFunction</a></dt>
+<dd>
+<div class="block">Returns an expression that invokes the UDF, using the given arguments.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/DetermineTableStats.html#apply-org.apache.spark.sql.catalyst.plans.logical.LogicalPlan-">apply(LogicalPlan)</a></span> - Method in class org.apache.spark.sql.hive.<a href="org/apache/spark/sql/hive/DetermineTableStats.html" title="class in org.apache.spark.sql.hive">DetermineTableStats</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution">CreateHiveTableAsSelectCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/HiveScriptIOSchema.html#apply-org.apache.spark.sql.catalyst.plans.logical.ScriptInputOutputSchema-">apply(ScriptInputOutputSchema)</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/HiveScriptIOSchema.html" title="class in org.apache.spark.sql.hive.execution">HiveScriptIOSchema</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveDirCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveTable</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html" title="class in org.apache.spark.sql.hive.execution">ScriptTransformationExec</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/HiveAnalysis.html#apply-org.apache.spark.sql.catalyst.plans.logical.LogicalPlan-">apply(LogicalPlan)</a></span> - Static method in class org.apache.spark.sql.hive.<a href="org/apache/spark/sql/hive/HiveAnalysis.html" title="class in org.apache.spark.sql.hive">HiveAnalysis</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/RelationConversions.html#apply-org.apache.spark.sql.catalyst.plans.logical.LogicalPlan-">apply(LogicalPlan)</a></span> - Method in class org.apache.spark.sql.hive.<a href="org/apache/spark/sql/hive/RelationConversions.html" title="class in org.apache.spark.sql.hive">RelationConversions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/ResolveHiveSerdeTable.html#apply-org.apache.spark.sql.catalyst.plans.logical.LogicalPlan-">apply(LogicalPlan)</a></span> - Method in class org.apache.spark.sql.hive.<a href="org/apache/spark/sql/hive/ResolveHiveSerdeTable.html" title="class in org.apache.spark.sql.hive">ResolveHiveSerdeTable</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/RelationalGroupedDataset.html#apply-org.apache.spark.sql.Dataset-scala.collection.Seq-org.apache.spark.sql.RelationalGroupedDataset.GroupType-">apply(Dataset&lt;Row&gt;, Seq&lt;Expression&gt;, RelationalGroupedDataset.GroupType)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/RelationalGroupedDataset.html" title="class in org.apache.spark.sql">RelationalGroupedDataset</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Row.html#apply-int-">apply(int)</a></span> - Method in interface org.apache.spark.sql.<a href="org/apache/spark/sql/Row.html" title="interface in org.apache.spark.sql">Row</a></dt>
+<dd>
+<div class="block">Returns the value at position i.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/streaming/ProcessingTime.html#apply-java.lang.String-">apply(String)</a></span> - Static method in class org.apache.spark.sql.streaming.<a href="org/apache/spark/sql/streaming/ProcessingTime.html" title="class in org.apache.spark.sql.streaming">ProcessingTime</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(interval)</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/streaming/ProcessingTime.html#apply-scala.concurrent.duration.Duration-">apply(Duration)</a></span> - Static method in class org.apache.spark.sql.streaming.<a href="org/apache/spark/sql/streaming/ProcessingTime.html" title="class in org.apache.spark.sql.streaming">ProcessingTime</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">use Trigger.ProcessingTime(interval)</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/ArrayType.html#apply-org.apache.spark.sql.types.DataType-">apply(DataType)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/ArrayType.html" title="class in org.apache.spark.sql.types">ArrayType</a></dt>
+<dd>
+<div class="block">Construct a <a href="org/apache/spark/sql/types/ArrayType.html" title="class in org.apache.spark.sql.types"><code>ArrayType</code></a> object with the given element type.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-double-">apply(double)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-long-">apply(long)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-scala.math.BigDecimal-">apply(BigDecimal)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-java.math.BigDecimal-">apply(BigDecimal)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-java.math.BigInteger-">apply(BigInteger)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-scala.math.BigInt-">apply(BigInt)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-scala.math.BigDecimal-int-int-">apply(BigDecimal, int, int)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-java.math.BigDecimal-int-int-">apply(BigDecimal, int, int)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-long-int-int-">apply(long, int, int)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/Decimal.html#apply-java.lang.String-">apply(String)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/Decimal.html" title="class in org.apache.spark.sql.types">Decimal</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/MapType.html#apply-org.apache.spark.sql.types.DataType-org.apache.spark.sql.types.DataType-">apply(DataType, DataType)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/MapType.html" title="class in org.apache.spark.sql.types">MapType</a></dt>
+<dd>
+<div class="block">Construct a <a href="org/apache/spark/sql/types/MapType.html" title="class in org.apache.spark.sql.types"><code>MapType</code></a> object with the given key type and value type.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#apply-java.lang.String-">apply(String)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Extracts the <a href="org/apache/spark/sql/types/StructField.html" title="class in org.apache.spark.sql.types"><code>StructField</code></a> with the given name.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#apply-scala.collection.immutable.Set-">apply(Set&lt;String&gt;)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>
+<div class="block">Returns a <a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types"><code>StructType</code></a> containing <a href="org/apache/spark/sql/types/StructField.html" title="class in org.apache.spark.sql.types"><code>StructField</code></a>s of the given names, preserving the
+ original order of fields.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#apply-int-">apply(int)</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/RDDPartitionSeq.html#apply-int-">apply(int)</a></span> - Method in class org.apache.spark.status.<a href="org/apache/spark/status/RDDPartitionSeq.html" title="class in org.apache.spark.status">RDDPartitionSeq</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BlockId.html#apply-java.lang.String-">apply(String)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BlockId.html" title="class in org.apache.spark.storage">BlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BlockManagerId.html#apply-java.lang.String-java.lang.String-int-scala.Option-">apply(String, String, int, Option&lt;String&gt;)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BlockManagerId.html" title="class in org.apache.spark.storage">BlockManagerId</a></dt>
+<dd>
+<div class="block">Returns a <a href="org/apache/spark/storage/BlockManagerId.html" title="class in org.apache.spark.storage"><code>BlockManagerId</code></a> for the given configuration.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BlockManagerId.html#apply-java.io.ObjectInput-">apply(ObjectInput)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BlockManagerId.html" title="class in org.apache.spark.storage">BlockManagerId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/StorageLevel.html#apply-boolean-boolean-boolean-boolean-int-">apply(boolean, boolean, boolean, boolean, int)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/StorageLevel.html" title="class in org.apache.spark.storage">StorageLevel</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Create a new StorageLevel object.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/StorageLevel.html#apply-boolean-boolean-boolean-int-">apply(boolean, boolean, boolean, int)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/StorageLevel.html" title="class in org.apache.spark.storage">StorageLevel</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Create a new StorageLevel object without setting useOffHeap.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/StorageLevel.html#apply-int-int-">apply(int, int)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/StorageLevel.html" title="class in org.apache.spark.storage">StorageLevel</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Create a new StorageLevel object from its integer representation.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/StorageLevel.html#apply-java.io.ObjectInput-">apply(ObjectInput)</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/StorageLevel.html" title="class in org.apache.spark.storage">StorageLevel</a></dt>
+<dd>
+<div class="block">:: DeveloperApi ::
+ Read StorageLevel object from ObjectInput stream.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/Milliseconds.html#apply-long-">apply(long)</a></span> - Static method in class org.apache.spark.streaming.<a href="org/apache/spark/streaming/Milliseconds.html" title="class in org.apache.spark.streaming">Milliseconds</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/Minutes.html#apply-long-">apply(long)</a></span> - Static method in class org.apache.spark.streaming.<a href="org/apache/spark/streaming/Minutes.html" title="class in org.apache.spark.streaming">Minutes</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/scheduler/ReceiverState.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.streaming.scheduler.<a href="org/apache/spark/streaming/scheduler/ReceiverState.html" title="class in org.apache.spark.streaming.scheduler">ReceiverState</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/Seconds.html#apply-long-">apply(long)</a></span> - Static method in class org.apache.spark.streaming.<a href="org/apache/spark/streaming/Seconds.html" title="class in org.apache.spark.streaming">Seconds</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskState.html#apply-int-">apply(int)</a></span> - Static method in class org.apache.spark.<a href="org/apache/spark/TaskState.html" title="class in org.apache.spark">TaskState</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/StatCounter.html#apply-scala.collection.TraversableOnce-">apply(TraversableOnce&lt;Object&gt;)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/StatCounter.html" title="class in org.apache.spark.util">StatCounter</a></dt>
+<dd>
+<div class="block">Build a StatCounter from a list of values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/StatCounter.html#apply-scala.collection.Seq-">apply(Seq&lt;Object&gt;)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/StatCounter.html" title="class in org.apache.spark.util">StatCounter</a></dt>
+<dd>
+<div class="block">Build a StatCounter from a list of values passed as variable-length arguments.</div>
+</dd>
+<dt><a href="org/apache/spark/ml/ann/ApplyInPlace.html" title="class in org.apache.spark.ml.ann"><span class="typeNameLink">ApplyInPlace</span></a> - Class in <a href="org/apache/spark/ml/ann/package-summary.html">org.apache.spark.ml.ann</a></dt>
+<dd>
+<div class="block">Implements in-place application of functions in the arrays</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/ann/ApplyInPlace.html#ApplyInPlace--">ApplyInPlace()</a></span> - Constructor for class org.apache.spark.ml.ann.<a href="org/apache/spark/ml/ann/ApplyInPlace.html" title="class in org.apache.spark.ml.ann">ApplyInPlace</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/StructType.html#applyOrElse-A1-scala.Function1-">applyOrElse(A1, Function1&lt;A1, B1&gt;)</a></span> - Static method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/StructType.html" title="class in org.apache.spark.sql.types">StructType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.rdd.RDD-org.apache.spark.sql.types.StructType-">applySchema(RDD&lt;Row&gt;, StructType)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/SQLContext.html" title="class in org.apache.spark.sql">SQLContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.api.java.JavaRDD-org.apache.spark.sql.types.StructType-">applySchema(JavaRDD&lt;Row&gt;, StructType)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/SQLContext.html" title="class in org.apache.spark.sql">SQLContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.rdd.RDD-java.lang.Class-">applySchema(RDD&lt;?&gt;, Class&lt;?&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/SQLContext.html" title="class in org.apache.spark.sql">SQLContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/SQLContext.html#applySchema-org.apache.spark.api.java.JavaRDD-java.lang.Class-">applySchema(JavaRDD&lt;?&gt;, Class&lt;?&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/SQLContext.html" title="class in org.apache.spark.sql">SQLContext</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use createDataFrame instead. Since 1.3.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/java/JavaSparkContext.html#appName--">appName()</a></span> - Method in class org.apache.spark.api.java.<a href="org/apache/spark/api/java/JavaSparkContext.html" title="class in org.apache.spark.api.java">JavaSparkContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html#appName--">appName()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/SparkListenerApplicationStart.html" title="class in org.apache.spark.scheduler">SparkListenerApplicationStart</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/SparkContext.html#appName--">appName()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/SparkContext.html" title="class in org.apache.spark">SparkContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/SparkSession.Builder.html#appName-java.lang.String-">appName(String)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/SparkSession.Builder.html" title="class in org.apache.spark.sql">SparkSession.Builder</a></dt>
+<dd>
+<div class="block">Sets a name for the application, which will be shown in the Spark web UI.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approx_count_distinct-org.apache.spark.sql.Column-">approx_count_distinct(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Aggregate function: returns the approximate number of distinct items in a group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approx_count_distinct-java.lang.String-">approx_count_distinct(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Aggregate function: returns the approximate number of distinct items in a group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approx_count_distinct-org.apache.spark.sql.Column-double-">approx_count_distinct(Column, double)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Aggregate function: returns the approximate number of distinct items in a group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approx_count_distinct-java.lang.String-double-">approx_count_distinct(String, double)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Aggregate function: returns the approximate number of distinct items in a group.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-org.apache.spark.sql.Column-">approxCountDistinct(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-java.lang.String-">approxCountDistinct(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-org.apache.spark.sql.Column-double-">approxCountDistinct(Column, double)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#approxCountDistinct-java.lang.String-double-">approxCountDistinct(String, double)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use approx_count_distinct. Since 2.1.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/tree/configuration/QuantileStrategy.html#ApproxHist--">ApproxHist()</a></span> - Static method in class org.apache.spark.mllib.tree.configuration.<a href="org/apache/spark/mllib/tree/configuration/QuantileStrategy.html" title="class in org.apache.spark.mllib.tree.configuration">QuantileStrategy</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html#approxNearestNeighbors-org.apache.spark.sql.Dataset-org.apache.spark.ml.linalg.Vector-int-java.lang.String-">approxNearestNeighbors(Dataset&lt;?&gt;, Vector, int, String)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html" title="class in org.apache.spark.ml.feature">BucketedRandomProjectionLSHM [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html#approxNearestNeighbors-org.apache.spark.sql.Dataset-org.apache.spark.ml.linalg.Vector-int-">approxNearestNeighbors(Dataset&lt;?&gt;, Vector, int)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html" title="class in org.apache.spark.ml.feature">BucketedRandomProjectionLSHModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/MinHashLSHModel.html#approxNearestNeighbors-org.apache.spark.sql.Dataset-org.apache.spark.ml.linalg.Vector-int-java.lang.String-">approxNearestNeighbors(Dataset&lt;?&gt;, Vector, int, String)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/MinHashLSHModel.html" title="class in org.apache.spark.ml.feature">MinHashLSHModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/MinHashLSHModel.html#approxNearestNeighbors-org.apache.spark.sql.Dataset-org.apache.spark.ml.linalg.Vector-int-">approxNearestNeighbors(Dataset&lt;?&gt;, Vector, int)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/MinHashLSHModel.html" title="class in org.apache.spark.ml.feature">MinHashLSHModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/DataFrameStatFunctions.html#approxQuantile-java.lang.String-double:A-double-">approxQuantile(String, double[], double)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/DataFrameStatFunctions.html" title="class in org.apache.spark.sql">DataFrameStatFunctions</a></dt>
+<dd>
+<div class="block">Calculates the approximate quantiles of a numerical column of a DataFrame.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/DataFrameStatFunctions.html#approxQuantile-java.lang.String:A-double:A-double-">approxQuantile(String[], double[], double)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/DataFrameStatFunctions.html" title="class in org.apache.spark.sql">DataFrameStatFunctions</a></dt>
+<dd>
+<div class="block">Calculates the approximate quantiles of numerical columns of a DataFrame.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html#approxSimilarityJoin-org.apache.spark.sql.Dataset-org.apache.spark.sql.Dataset-double-java.lang.String-">approxSimilarityJoin(Dataset&lt;?&gt;, Dataset&lt;?&gt;, double, String)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html" title="class in org.apache.spark.ml.feature">BucketedRandomProject [...]
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html#approxSimilarityJoin-org.apache.spark.sql.Dataset-org.apache.spark.sql.Dataset-double-">approxSimilarityJoin(Dataset&lt;?&gt;, Dataset&lt;?&gt;, double)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/BucketedRandomProjectionLSHModel.html" title="class in org.apache.spark.ml.feature">BucketedRandomProjectionLSHModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/MinHashLSHModel.html#approxSimilarityJoin-org.apache.spark.sql.Dataset-org.apache.spark.sql.Dataset-double-java.lang.String-">approxSimilarityJoin(Dataset&lt;?&gt;, Dataset&lt;?&gt;, double, String)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/MinHashLSHModel.html" title="class in org.apache.spark.ml.feature">MinHashLSHModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/feature/MinHashLSHModel.html#approxSimilarityJoin-org.apache.spark.sql.Dataset-org.apache.spark.sql.Dataset-double-">approxSimilarityJoin(Dataset&lt;?&gt;, Dataset&lt;?&gt;, double)</a></span> - Static method in class org.apache.spark.ml.feature.<a href="org/apache/spark/ml/feature/MinHashLSHModel.html" title="class in org.apache.spark.ml.feature">MinHashLSHModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html#appSparkVersion--">appSparkVersion()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html" title="class in org.apache.spark.status.api.v1">ApplicationAttemptInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/status/AppStatusUtils.html" title="class in org.apache.spark.status"><span class="typeNameLink">AppStatusUtils</span></a> - Class in <a href="org/apache/spark/status/package-summary.html">org.apache.spark.status</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/AppStatusUtils.html#AppStatusUtils--">AppStatusUtils()</a></span> - Constructor for class org.apache.spark.status.<a href="org/apache/spark/status/AppStatusUtils.html" title="class in org.apache.spark.status">AppStatusUtils</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/mllib/evaluation/AreaUnderCurve.html" title="class in org.apache.spark.mllib.evaluation"><span class="typeNameLink">AreaUnderCurve</span></a> - Class in <a href="org/apache/spark/mllib/evaluation/package-summary.html">org.apache.spark.mllib.evaluation</a></dt>
+<dd>
+<div class="block">Computes the area under the curve (AUC) using the trapezoidal rule.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/AreaUnderCurve.html#AreaUnderCurve--">AreaUnderCurve()</a></span> - Constructor for class org.apache.spark.mllib.evaluation.<a href="org/apache/spark/mllib/evaluation/AreaUnderCurve.html" title="class in org.apache.spark.mllib.evaluation">AreaUnderCurve</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/BinaryClassificationMetrics.html#areaUnderPR--">areaUnderPR()</a></span> - Method in class org.apache.spark.mllib.evaluation.<a href="org/apache/spark/mllib/evaluation/BinaryClassificationMetrics.html" title="class in org.apache.spark.mllib.evaluation">BinaryClassificationMetrics</a></dt>
+<dd>
+<div class="block">Computes the area under the precision-recall curve.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/BinaryLogisticRegressionSummary.html#areaUnderROC--">areaUnderROC()</a></span> - Method in interface org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/BinaryLogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification">BinaryLogisticRegressionSummary</a></dt>
+<dd>
+<div class="block">Computes the area under the receiver operating characteristic (ROC) curve.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/evaluation/BinaryClassificationMetrics.html#areaUnderROC--">areaUnderROC()</a></span> - Method in class org.apache.spark.mllib.evaluation.<a href="org/apache/spark/mllib/evaluation/BinaryClassificationMetrics.html" title="class in org.apache.spark.mllib.evaluation">BinaryClassificationMetrics</a></dt>
+<dd>
+<div class="block">Computes the area under the receiver operating characteristic (ROC) curve.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/DenseVector.html#argmax--">argmax()</a></span> - Method in class org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/DenseVector.html" title="class in org.apache.spark.ml.linalg">DenseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/SparseVector.html#argmax--">argmax()</a></span> - Method in class org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/SparseVector.html" title="class in org.apache.spark.ml.linalg">SparseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/Vector.html#argmax--">argmax()</a></span> - Method in interface org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/Vector.html" title="interface in org.apache.spark.ml.linalg">Vector</a></dt>
+<dd>
+<div class="block">Find the index of a maximal element.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/DenseVector.html#argmax--">argmax()</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/DenseVector.html" title="class in org.apache.spark.mllib.linalg">DenseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/SparseVector.html#argmax--">argmax()</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/SparseVector.html" title="class in org.apache.spark.mllib.linalg">SparseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Vector.html#argmax--">argmax()</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Vector.html" title="interface in org.apache.spark.mllib.linalg">Vector</a></dt>
+<dd>
+<div class="block">Find the index of a maximal element.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html#argString--">argString()</a></span> - Method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution">CreateHiveTableAsSelectCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html#argString--">argString()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveDirCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html#argString--">argString()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveTable</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html#argString--">argString()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html" title="class in org.apache.spark.sql.hive.execution">ScriptTransformationExec</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/ColumnName.html#array-org.apache.spark.sql.types.DataType-">array(DataType)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/ColumnName.html" title="class in org.apache.spark.sql">ColumnName</a></dt>
+<dd>
+<div class="block">Creates a new <code>StructField</code> of type array.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array-org.apache.spark.sql.Column...-">array(Column...)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Creates a new array column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array-java.lang.String-java.lang.String...-">array(String, String...)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Creates a new array column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array-scala.collection.Seq-">array(Seq&lt;Column&gt;)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Creates a new array column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array-java.lang.String-scala.collection.Seq-">array(String, Seq&lt;String&gt;)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Creates a new array column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/vectorized/ColumnarArray.html#array--">array()</a></span> - Method in class org.apache.spark.sql.vectorized.<a href="org/apache/spark/sql/vectorized/ColumnarArray.html" title="class in org.apache.spark.sql.vectorized">ColumnarArray</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_contains-org.apache.spark.sql.Column-java.lang.Object-">array_contains(Column, Object)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns null if the array is null, true if the array contains <code>value</code>, and false otherwise.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_distinct-org.apache.spark.sql.Column-">array_distinct(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Removes duplicate values from the array.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_except-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">array_except(Column, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns an array of the elements in the first array but not in the second array,
+ without duplicates.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_intersect-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">array_intersect(Column, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns an array of the elements in the intersection of the given two arrays,
+ without duplicates.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_join-org.apache.spark.sql.Column-java.lang.String-java.lang.String-">array_join(Column, String, String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Concatenates the elements of <code>column</code> using the <code>delimiter</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_join-org.apache.spark.sql.Column-java.lang.String-">array_join(Column, String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Concatenates the elements of <code>column</code> using the <code>delimiter</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_max-org.apache.spark.sql.Column-">array_max(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns the maximum value in the array.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_min-org.apache.spark.sql.Column-">array_min(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns the minimum value in the array.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_position-org.apache.spark.sql.Column-java.lang.Object-">array_position(Column, Object)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Locates the position of the first occurrence of the value in the given array as long.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_remove-org.apache.spark.sql.Column-java.lang.Object-">array_remove(Column, Object)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Remove all elements that equal to element from the given array.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_repeat-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">array_repeat(Column, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Creates an array containing the left argument repeated the number of times given by the
+ right argument.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_repeat-org.apache.spark.sql.Column-int-">array_repeat(Column, int)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Creates an array containing the left argument repeated the number of times given by the
+ right argument.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_sort-org.apache.spark.sql.Column-">array_sort(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Sorts the input array in ascending order.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#array_union-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">array_union(Column, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns an array of the elements in the union of the given two arrays, without duplicates.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/param/ParamValidators.html#arrayLengthGt-double-">arrayLengthGt(double)</a></span> - Static method in class org.apache.spark.ml.param.<a href="org/apache/spark/ml/param/ParamValidators.html" title="class in org.apache.spark.ml.param">ParamValidators</a></dt>
+<dd>
+<div class="block">Check that the array length is greater than lowerBound.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#arrays_overlap-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">arrays_overlap(Column, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns <code>true</code> if <code>a1</code> and <code>a2</code> have at least one non-null element in common.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#arrays_zip-org.apache.spark.sql.Column...-">arrays_zip(Column...)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns a merged array of structs in which the N-th struct contains all N-th values of input
+ arrays.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#arrays_zip-scala.collection.Seq-">arrays_zip(Seq&lt;Column&gt;)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns a merged array of structs in which the N-th struct contains all N-th values of input
+ arrays.</div>
+</dd>
+<dt><a href="org/apache/spark/sql/types/ArrayType.html" title="class in org.apache.spark.sql.types"><span class="typeNameLink">ArrayType</span></a> - Class in <a href="org/apache/spark/sql/types/package-summary.html">org.apache.spark.sql.types</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/ArrayType.html#ArrayType-org.apache.spark.sql.types.DataType-boolean-">ArrayType(DataType, boolean)</a></span> - Constructor for class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/ArrayType.html" title="class in org.apache.spark.sql.types">ArrayType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/memory/DeserializedValuesHolder.html#arrayValues--">arrayValues()</a></span> - Method in class org.apache.spark.storage.memory.<a href="org/apache/spark/storage/memory/DeserializedValuesHolder.html" title="class in org.apache.spark.storage.memory">DeserializedValuesHolder</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/sql/vectorized/ArrowColumnVector.html" title="class in org.apache.spark.sql.vectorized"><span class="typeNameLink">ArrowColumnVector</span></a> - Class in <a href="org/apache/spark/sql/vectorized/package-summary.html">org.apache.spark.sql.vectorized</a></dt>
+<dd>
+<div class="block">A column vector backed by Apache Arrow.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/vectorized/ArrowColumnVector.html#ArrowColumnVector-org.apache.arrow.vector.ValueVector-">ArrowColumnVector(ValueVector)</a></span> - Constructor for class org.apache.spark.sql.vectorized.<a href="org/apache/spark/sql/vectorized/ArrowColumnVector.html" title="class in org.apache.spark.sql.vectorized">ArrowColumnVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#as-org.apache.spark.sql.Encoder-">as(Encoder&lt;U&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Provides a type hint about the expected return value of this column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#as-java.lang.String-">as(String)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Gives the column an alias.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#as-scala.collection.Seq-">as(Seq&lt;String&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">(Scala-specific) Assigns the given aliases to the results of a table generating function.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#as-java.lang.String:A-">as(String[])</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Assigns the given aliases to the results of a table generating function.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#as-scala.Symbol-">as(Symbol)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Gives the column an alias.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#as-java.lang.String-org.apache.spark.sql.types.Metadata-">as(String, Metadata)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Gives the column an alias with metadata.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#as-org.apache.spark.sql.Encoder-">as(Encoder&lt;U&gt;)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">:: Experimental ::
+ Returns a new Dataset where each record has been mapped on to the specified type.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#as-java.lang.String-">as(String)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">Returns a new Dataset with an alias set.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Dataset.html#as-scala.Symbol-">as(Symbol)</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Dataset.html" title="class in org.apache.spark.sql">Dataset</a></dt>
+<dd>
+<div class="block">(Scala-specific) Returns a new Dataset with an alias set.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/classification/LogisticRegressionSummary.html#asBinary--">asBinary()</a></span> - Method in interface org.apache.spark.ml.classification.<a href="org/apache/spark/ml/classification/LogisticRegressionSummary.html" title="interface in org.apache.spark.ml.classification">LogisticRegressionSummary</a></dt>
+<dd>
+<div class="block">Convenient method for casting to binary logistic regression summary.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/Matrix.html#asBreeze--">asBreeze()</a></span> - Method in interface org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/Matrix.html" title="interface in org.apache.spark.ml.linalg">Matrix</a></dt>
+<dd>
+<div class="block">Converts to a breeze matrix.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/linalg/Vector.html#asBreeze--">asBreeze()</a></span> - Method in interface org.apache.spark.ml.linalg.<a href="org/apache/spark/ml/linalg/Vector.html" title="interface in org.apache.spark.ml.linalg">Vector</a></dt>
+<dd>
+<div class="block">Converts the instance to a breeze vector.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Matrix.html#asBreeze--">asBreeze()</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Matrix.html" title="interface in org.apache.spark.mllib.linalg">Matrix</a></dt>
+<dd>
+<div class="block">Converts to a breeze matrix.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Vector.html#asBreeze--">asBreeze()</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Vector.html" title="interface in org.apache.spark.mllib.linalg">Vector</a></dt>
+<dd>
+<div class="block">Converts the instance to a breeze vector.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#asc--">asc()</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Returns a sort expression based on ascending order of the column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#asc-java.lang.String-">asc(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns a sort expression based on ascending order of the column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#asc_nulls_first--">asc_nulls_first()</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Returns a sort expression based on ascending order of the column,
+ and null values return before non-null values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#asc_nulls_first-java.lang.String-">asc_nulls_first(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns a sort expression based on ascending order of the column,
+ and null values return before non-null values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/Column.html#asc_nulls_last--">asc_nulls_last()</a></span> - Method in class org.apache.spark.sql.<a href="org/apache/spark/sql/Column.html" title="class in org.apache.spark.sql">Column</a></dt>
+<dd>
+<div class="block">Returns a sort expression based on ascending order of the column,
+ and null values appear after non-null values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#asc_nulls_last-java.lang.String-">asc_nulls_last(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Returns a sort expression based on ascending order of the column,
+ and null values appear after non-null values.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#ascii-org.apache.spark.sql.Column-">ascii(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>
+<div class="block">Computes the numeric value of the first character of the string column, and returns the
+ result as an int column.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html#asCode--">asCode()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/CreateHiveTableAsSelectCommand.html" title="class in org.apache.spark.sql.hive.execution">CreateHiveTableAsSelectCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html#asCode--">asCode()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveDirCommand.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveDirCommand</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html#asCode--">asCode()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/InsertIntoHiveTable.html" title="class in org.apache.spark.sql.hive.execution">InsertIntoHiveTable</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html#asCode--">asCode()</a></span> - Static method in class org.apache.spark.sql.hive.execution.<a href="org/apache/spark/sql/hive/execution/ScriptTransformationExec.html" title="class in org.apache.spark.sql.hive.execution">ScriptTransformationExec</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#asin-org.apache.spark.sql.Column-">asin(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#asin-java.lang.String-">asin(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/serializer/DeserializationStream.html#asIterator--">asIterator()</a></span> - Method in class org.apache.spark.serializer.<a href="org/apache/spark/serializer/DeserializationStream.html" title="class in org.apache.spark.serializer">DeserializationStream</a></dt>
+<dd>
+<div class="block">Read the elements of this stream through an iterator.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/r/PairwiseRRDD.html#asJavaPairRDD--">asJavaPairRDD()</a></span> - Method in class org.apache.spark.api.r.<a href="org/apache/spark/api/r/PairwiseRRDD.html" title="class in org.apache.spark.api.r">PairwiseRRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/r/RRDD.html#asJavaRDD--">asJavaRDD()</a></span> - Method in class org.apache.spark.api.r.<a href="org/apache/spark/api/r/RRDD.html" title="class in org.apache.spark.api.r">RRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/api/r/StringRRDD.html#asJavaRDD--">asJavaRDD()</a></span> - Method in class org.apache.spark.api.r.<a href="org/apache/spark/api/r/StringRRDD.html" title="class in org.apache.spark.api.r">StringRRDD</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/serializer/DeserializationStream.html#asKeyValueIterator--">asKeyValueIterator()</a></span> - Method in class org.apache.spark.serializer.<a href="org/apache/spark/serializer/DeserializationStream.html" title="class in org.apache.spark.serializer">DeserializationStream</a></dt>
+<dd>
+<div class="block">Read the elements of this stream through an iterator over key-value pairs.</div>
+</dd>
+<dt><a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html" title="class in org.apache.spark.scheduler"><span class="typeNameLink">AskPermissionToCommitOutput</span></a> - Class in <a href="org/apache/spark/scheduler/package-summary.html">org.apache.spark.scheduler</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html#AskPermissionToCommitOutput-int-int-int-int-">AskPermissionToCommitOutput(int, int, int, int)</a></span> - Constructor for class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html" title="class in org.apache.spark.scheduler">AskPermissionToCommitOutput</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/util/RpcUtils.html#askRpcTimeout-org.apache.spark.SparkConf-">askRpcTimeout(SparkConf)</a></span> - Static method in class org.apache.spark.util.<a href="org/apache/spark/util/RpcUtils.html" title="class in org.apache.spark.util">RpcUtils</a></dt>
+<dd>
+<div class="block">Returns the default Spark timeout to use for RPC ask operations.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BlockManagerMessages.GetBlockStatus.html#askSlaves--">askSlaves()</a></span> - Method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BlockManagerMessages.GetBlockStatus.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetBlockStatus</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BlockManagerMessages.GetMatchingBlockIds.html#askSlaves--">askSlaves()</a></span> - Method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BlockManagerMessages.GetMatchingBlockIds.html" title="class in org.apache.spark.storage">BlockManagerMessages.GetMatchingBlockIds</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html#asMap--">asMap()</a></span> - Method in class org.apache.spark.sql.sources.v2.<a href="org/apache/spark/sql/sources/v2/DataSourceOptions.html" title="class in org.apache.spark.sql.sources.v2">DataSourceOptions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/DenseMatrix.html#asML--">asML()</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/DenseMatrix.html" title="class in org.apache.spark.mllib.linalg">DenseMatrix</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/DenseVector.html#asML--">asML()</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/DenseVector.html" title="class in org.apache.spark.mllib.linalg">DenseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Matrix.html#asML--">asML()</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Matrix.html" title="interface in org.apache.spark.mllib.linalg">Matrix</a></dt>
+<dd>
+<div class="block">Convert this matrix to the new mllib-local representation.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/SparseMatrix.html#asML--">asML()</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/SparseMatrix.html" title="class in org.apache.spark.mllib.linalg">SparseMatrix</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/SparseVector.html#asML--">asML()</a></span> - Method in class org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/SparseVector.html" title="class in org.apache.spark.mllib.linalg">SparseVector</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/linalg/Vector.html#asML--">asML()</a></span> - Method in interface org.apache.spark.mllib.linalg.<a href="org/apache/spark/mllib/linalg/Vector.html" title="interface in org.apache.spark.mllib.linalg">Vector</a></dt>
+<dd>
+<div class="block">Convert this vector to the new mllib-local representation.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/UserDefinedFunction.html#asNondeterministic--">asNondeterministic()</a></span> - Method in class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/UserDefinedFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedFunction</a></dt>
+<dd>
+<div class="block">Updates UserDefinedFunction to nondeterministic.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/expressions/UserDefinedFunction.html#asNonNullable--">asNonNullable()</a></span> - Method in class org.apache.spark.sql.expressions.<a href="org/apache/spark/sql/expressions/UserDefinedFunction.html" title="class in org.apache.spark.sql.expressions">UserDefinedFunction</a></dt>
+<dd>
+<div class="block">Updates UserDefinedFunction to non-nullable.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/types/ObjectType.html#asNullable--">asNullable()</a></span> - Method in class org.apache.spark.sql.types.<a href="org/apache/spark/sql/types/ObjectType.html" title="class in org.apache.spark.sql.types">ObjectType</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BlockId.html#asRDDId--">asRDDId()</a></span> - Method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BlockId.html" title="class in org.apache.spark.storage">BlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/BroadcastBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/BroadcastBlockId.html" title="class in org.apache.spark.storage">BroadcastBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/RDDBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/RDDBlockId.html" title="class in org.apache.spark.storage">RDDBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/ShuffleBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/ShuffleBlockId.html" title="class in org.apache.spark.storage">ShuffleBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/ShuffleDataBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/ShuffleDataBlockId.html" title="class in org.apache.spark.storage">ShuffleDataBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/ShuffleIndexBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/ShuffleIndexBlockId.html" title="class in org.apache.spark.storage">ShuffleIndexBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/StreamBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/StreamBlockId.html" title="class in org.apache.spark.storage">StreamBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/storage/TaskResultBlockId.html#asRDDId--">asRDDId()</a></span> - Static method in class org.apache.spark.storage.<a href="org/apache/spark/storage/TaskResultBlockId.html" title="class in org.apache.spark.storage">TaskResultBlockId</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/internal/io/HadoopWriteConfigUtil.html#assertConf-org.apache.hadoop.mapreduce.JobContext-org.apache.spark.SparkConf-">assertConf(JobContext, SparkConf)</a></span> - Method in class org.apache.spark.internal.io.<a href="org/apache/spark/internal/io/HadoopWriteConfigUtil.html" title="class in org.apache.spark.internal.io">HadoopWriteConfigUtil</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TestUtils.html#assertNotSpilled-org.apache.spark.SparkContext-java.lang.String-scala.Function0-">assertNotSpilled(SparkContext, String, Function0&lt;BoxedUnit&gt;)</a></span> - Static method in class org.apache.spark.<a href="org/apache/spark/TestUtils.html" title="class in org.apache.spark">TestUtils</a></dt>
+<dd>
+<div class="block">Run some code involving jobs submitted to the given context and assert that the jobs
+ did not spill.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TestUtils.html#assertSpilled-org.apache.spark.SparkContext-java.lang.String-scala.Function0-">assertSpilled(SparkContext, String, Function0&lt;BoxedUnit&gt;)</a></span> - Static method in class org.apache.spark.<a href="org/apache/spark/TestUtils.html" title="class in org.apache.spark">TestUtils</a></dt>
+<dd>
+<div class="block">Run some code involving jobs submitted to the given context and assert that the jobs spilled.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/clustering/PowerIterationClustering.html#assignClusters-org.apache.spark.sql.Dataset-">assignClusters(Dataset&lt;?&gt;)</a></span> - Method in class org.apache.spark.ml.clustering.<a href="org/apache/spark/ml/clustering/PowerIterationClustering.html" title="class in org.apache.spark.ml.clustering">PowerIterationClustering</a></dt>
+<dd>
+<div class="block">Run the PIC algorithm and returns a cluster assignment for each input vertex.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment.html#Assignment-long-int-">Assignment(long, int)</a></span> - Constructor for class org.apache.spark.mllib.clustering.<a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClustering.Assignment</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment$.html#Assignment:D--">Assignment$()</a></span> - Constructor for class org.apache.spark.mllib.clustering.<a href="org/apache/spark/mllib/clustering/PowerIterationClustering.Assignment$.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClustering.Assignment$</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/clustering/PowerIterationClusteringModel.html#assignments--">assignments()</a></span> - Method in class org.apache.spark.mllib.clustering.<a href="org/apache/spark/mllib/clustering/PowerIterationClusteringModel.html" title="class in org.apache.spark.mllib.clustering">PowerIterationClusteringModel</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/ml/fpm/AssociationRules.html" title="class in org.apache.spark.ml.fpm"><span class="typeNameLink">AssociationRules</span></a> - Class in <a href="org/apache/spark/ml/fpm/package-summary.html">org.apache.spark.ml.fpm</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/fpm/AssociationRules.html#AssociationRules--">AssociationRules()</a></span> - Constructor for class org.apache.spark.ml.fpm.<a href="org/apache/spark/ml/fpm/AssociationRules.html" title="class in org.apache.spark.ml.fpm">AssociationRules</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/ml/fpm/FPGrowthModel.html#associationRules--">associationRules()</a></span> - Method in class org.apache.spark.ml.fpm.<a href="org/apache/spark/ml/fpm/FPGrowthModel.html" title="class in org.apache.spark.ml.fpm">FPGrowthModel</a></dt>
+<dd>
+<div class="block">Get association rules fitted using the minConfidence.</div>
+</dd>
+<dt><a href="org/apache/spark/mllib/fpm/AssociationRules.html" title="class in org.apache.spark.mllib.fpm"><span class="typeNameLink">AssociationRules</span></a> - Class in <a href="org/apache/spark/mllib/fpm/package-summary.html">org.apache.spark.mllib.fpm</a></dt>
+<dd>
+<div class="block">Generates association rules from a <code>RDD[FreqItemset[Item}</code>.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/mllib/fpm/AssociationRules.html#AssociationRules--">AssociationRules()</a></span> - Constructor for class org.apache.spark.mllib.fpm.<a href="org/apache/spark/mllib/fpm/AssociationRules.html" title="class in org.apache.spark.mllib.fpm">AssociationRules</a></dt>
+<dd>
+<div class="block">Constructs a default instance with default parameters {minConfidence = 0.8}.</div>
+</dd>
+<dt><a href="org/apache/spark/mllib/fpm/AssociationRules.Rule.html" title="class in org.apache.spark.mllib.fpm"><span class="typeNameLink">AssociationRules.Rule</span></a>&lt;<a href="org/apache/spark/mllib/fpm/AssociationRules.Rule.html" title="type parameter in AssociationRules.Rule">Item</a>&gt; - Class in <a href="org/apache/spark/mllib/fpm/package-summary.html">org.apache.spark.mllib.fpm</a></dt>
+<dd>
+<div class="block">An association rule between sets of items.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/config.html#ASYNC_TRACKING_ENABLED--">ASYNC_TRACKING_ENABLED()</a></span> - Static method in class org.apache.spark.status.<a href="org/apache/spark/status/config.html" title="class in org.apache.spark.status">config</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/scheduler/AsyncEventQueue.html" title="class in org.apache.spark.scheduler"><span class="typeNameLink">AsyncEventQueue</span></a> - Class in <a href="org/apache/spark/scheduler/package-summary.html">org.apache.spark.scheduler</a></dt>
+<dd>
+<div class="block">An asynchronous queue for events.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AsyncEventQueue.html#AsyncEventQueue-java.lang.String-org.apache.spark.SparkConf-org.apache.spark.scheduler.LiveListenerBusMetrics-org.apache.spark.scheduler.LiveListenerBus-">AsyncEventQueue(String, SparkConf, LiveListenerBusMetrics, LiveListenerBus)</a></span> - Constructor for class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AsyncEventQueue.html" title="class in org.apache.spark.scheduler">AsyncEv [...]
+<dd>&nbsp;</dd>
+<dt><a href="org/apache/spark/rdd/AsyncRDDActions.html" title="class in org.apache.spark.rdd"><span class="typeNameLink">AsyncRDDActions</span></a>&lt;<a href="org/apache/spark/rdd/AsyncRDDActions.html" title="type parameter in AsyncRDDActions">T</a>&gt; - Class in <a href="org/apache/spark/rdd/package-summary.html">org.apache.spark.rdd</a></dt>
+<dd>
+<div class="block">A set of asynchronous RDD actions available through an implicit conversion.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/rdd/AsyncRDDActions.html#AsyncRDDActions-org.apache.spark.rdd.RDD-scala.reflect.ClassTag-">AsyncRDDActions(RDD&lt;T&gt;, ClassTag&lt;T&gt;)</a></span> - Constructor for class org.apache.spark.rdd.<a href="org/apache/spark/rdd/AsyncRDDActions.html" title="class in org.apache.spark.rdd">AsyncRDDActions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan-org.apache.spark.sql.Column-">atan(Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan-java.lang.String-">atan(String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-org.apache.spark.sql.Column-org.apache.spark.sql.Column-">atan2(Column, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-org.apache.spark.sql.Column-java.lang.String-">atan2(Column, String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-java.lang.String-org.apache.spark.sql.Column-">atan2(String, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-java.lang.String-java.lang.String-">atan2(String, String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-org.apache.spark.sql.Column-double-">atan2(Column, double)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-java.lang.String-double-">atan2(String, double)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-double-org.apache.spark.sql.Column-">atan2(double, Column)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/sql/functions.html#atan2-double-java.lang.String-">atan2(double, String)</a></span> - Static method in class org.apache.spark.sql.<a href="org/apache/spark/sql/functions.html" title="class in org.apache.spark.sql">functions</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/TaskData.html#attempt--">attempt()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/TaskData.html" title="class in org.apache.spark.status.api.v1">TaskData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/TaskIndexNames.html#ATTEMPT--">ATTEMPT()</a></span> - Static method in class org.apache.spark.status.<a href="org/apache/spark/status/TaskIndexNames.html" title="class in org.apache.spark.status">TaskIndexNames</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/StageInfo.html#attemptId--">attemptId()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/StageInfo.html" title="class in org.apache.spark.scheduler">StageInfo</a></dt>
+<dd>
+<div class="block"><span class="deprecatedLabel">Deprecated.</span>
+<div class="block"><span class="deprecationComment">Use attemptNumber instead. Since 2.3.0.</span></div>
+</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html#attemptId--">attemptId()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/ApplicationAttemptInfo.html" title="class in org.apache.spark.status.api.v1">ApplicationAttemptInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/StageData.html#attemptId--">attemptId()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/StageData.html" title="class in org.apache.spark.status.api.v1">StageData</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/BarrierTaskContext.html#attemptNumber--">attemptNumber()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/BarrierTaskContext.html" title="class in org.apache.spark">BarrierTaskContext</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html#attemptNumber--">attemptNumber()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/AskPermissionToCommitOutput.html" title="class in org.apache.spark.scheduler">AskPermissionToCommitOutput</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/StageInfo.html#attemptNumber--">attemptNumber()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/StageInfo.html" title="class in org.apache.spark.scheduler">StageInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/scheduler/TaskInfo.html#attemptNumber--">attemptNumber()</a></span> - Method in class org.apache.spark.scheduler.<a href="org/apache/spark/scheduler/TaskInfo.html" title="class in org.apache.spark.scheduler">TaskInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskCommitDenied.html#attemptNumber--">attemptNumber()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskCommitDenied.html" title="class in org.apache.spark">TaskCommitDenied</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/TaskContext.html#attemptNumber--">attemptNumber()</a></span> - Method in class org.apache.spark.<a href="org/apache/spark/TaskContext.html" title="class in org.apache.spark">TaskContext</a></dt>
+<dd>
+<div class="block">How many times this task has been attempted.</div>
+</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/status/api/v1/ApplicationInfo.html#attempts--">attempts()</a></span> - Method in class org.apache.spark.status.api.v1.<a href="org/apache/spark/status/api/v1/ApplicationInfo.html" title="class in org.apache.spark.status.api.v1">ApplicationInfo</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.AtTimestamp.html#AtTimestamp-java.util.Date-">AtTimestamp(Date)</a></span> - Constructor for class org.apache.spark.streaming.kinesis.<a href="org/apache/spark/streaming/kinesis/KinesisInitialPositions.AtTimestamp.html" title="class in org.apache.spark.streaming.kinesis">KinesisInitialPositions.AtTimestamp</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/Edge.html#attr--">attr()</a></span> - Method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/Edge.html" title="class in org.apache.spark.graphx">Edge</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/spark/graphx/EdgeContext.html#attr--">attr()</a></span> - Method in class org.apache.spark.graphx.<a href="org/apache/spark/graphx/EdgeContext.html" title="class in org.apache.spark.graphx">EdgeContext</a></dt>
+<dd>
+<div class="block">The attribute associated with the edge.</div>
+</dd>
... 2070251 lines suppressed ...


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