class icon trait icon trait icon trait icon
  1. focushideorg.apache.spark
    1. Accumulable
    2. AccumulableParam
    3. Accumulator
    4. AccumulatorParam
    5. Aggregator
    6. ComplexFutureAction
    7. Dependency
    8. ExceptionFailure
    9. ExecutorLostFailure
    10. FetchFailed
    11. FutureAction
    12. HashPartitioner
    13. InterruptibleIterator
    14. JobExecutionStatus
    15. JobSubmitter
    16. NarrowDependency
    17. OneToOneDependency
    18. Partition
    19. Partitioner
    20. RangeDependency
    21. RangePartitioner
    22. Resubmitted
    23. SerializableWritable
    24. ShuffleDependency
    25. SimpleFutureAction
    26. SparkConf
    27. SparkContext
    28. SparkEnv
    29. SparkException
    30. SparkExecutorInfo
    31. SparkFiles
    32. SparkFirehoseListener
    33. SparkJobInfo
    34. SparkStageInfo
    35. SparkStatusTracker
    36. Success
    37. TaskCommitDenied
    38. TaskContext
    39. TaskEndReason
    40. TaskFailedReason
    41. TaskKilled
    42. TaskKilledException
    43. TaskResultLost
    44. UnknownReason
    45. WritableConverter
    46. WritableFactory
  1. focushideorg.apache.spark.api.java
    1. JavaDoubleRDD
    2. JavaFutureAction
    3. JavaHadoopRDD
    4. JavaNewHadoopRDD
    5. JavaPairRDD
    6. JavaRDD
    7. JavaRDDLike
    8. JavaSparkContext
    9. JavaSparkStatusTracker
    10. Optional
    11. StorageLevels
  1. focushideorg.apache.spark.api.java.function
    1. CoGroupFunction
    2. DoubleFlatMapFunction
    3. DoubleFunction
    4. FilterFunction
    5. FlatMapFunction
    6. FlatMapFunction2
    7. FlatMapGroupsFunction
    8. FlatMapGroupsWithStateFunction
    9. ForeachFunction
    10. ForeachPartitionFunction
    11. Function
    12. Function0
    13. Function2
    14. Function3
    15. Function4
    16. MapFunction
    17. MapGroupsFunction
    18. MapGroupsWithStateFunction
    19. MapPartitionsFunction
    20. PairFlatMapFunction
    21. PairFunction
    22. ReduceFunction
    23. VoidFunction
    24. VoidFunction2
  1. focushideorg.apache.spark.broadcast
    1. Broadcast
  1. focushideorg.apache.spark.graphx
    1. Edge
    2. EdgeContext
    3. EdgeDirection
    4. EdgeRDD
    5. EdgeTriplet
    6. Graph
    7. GraphLoader
    8. GraphOps
    9. GraphXUtils
    10. PartitionStrategy
    11. Pregel
    12. TripletFields
    13. VertexRDD
  1. focushideorg.apache.spark.graphx.impl
    1. EdgeActiveness
    2. EdgeRDDImpl
    3. GraphImpl
    4. VertexRDDImpl
  1. focushideorg.apache.spark.graphx.lib
    1. ConnectedComponents
    2. LabelPropagation
    3. PageRank
    4. ShortestPaths
    5. StronglyConnectedComponents
    6. SVDPlusPlus
    7. TriangleCount
  1. focushideorg.apache.spark.graphx.util
    1. GraphGenerators
  1. focushideorg.apache.spark.input
    1. PortableDataStream
  1. focushideorg.apache.spark.internal
    1. Logging
  1. focushideorg.apache.spark.internal.io
    1. FileCommitProtocol
    2. HadoopMapReduceCommitProtocol
  1. focushideorg.apache.spark.io
    1. CompressionCodec
    2. LZ4BlockInputStream
    3. LZ4CompressionCodec
    4. LZFCompressionCodec
    5. NioBufferedFileInputStream
    6. SnappyCompressionCodec
  1. focushideorg.apache.spark.launcher
    1. SparkAppHandle
    2. SparkLauncher
  1. focushideorg.apache.spark.mapred
    1. SparkHadoopMapRedUtil
  1. focushideorg.apache.spark.metrics.source
    1. CodegenMetrics
    2. HiveCatalogMetrics
  1. focushideorg.apache.spark.ml
    1. Estimator
    2. Model
    3. Pipeline
    4. PipelineModel
    5. PipelineStage
    6. PredictionModel
    7. Predictor
    8. Transformer
    9. UnaryTransformer
  1. focushideorg.apache.spark.ml.attribute
    1. Attribute
    2. AttributeGroup
    3. AttributeType
    4. BinaryAttribute
    5. NominalAttribute
    6. NumericAttribute
    7. UnresolvedAttribute
  1. focushideorg.apache.spark.ml.classification
    1. BinaryLogisticRegressionSummary
    2. BinaryLogisticRegressionTrainingSummary
    3. ClassificationModel
    4. Classifier
    5. DecisionTreeClassificationModel
    6. DecisionTreeClassifier
    7. GBTClassificationModel
    8. GBTClassifier
    9. LinearSVC
    10. LinearSVCModel
    11. LogisticRegression
    12. LogisticRegressionModel
    13. LogisticRegressionSummary
    14. LogisticRegressionTrainingSummary
    15. MultilayerPerceptronClassificationModel
    16. MultilayerPerceptronClassifier
    17. NaiveBayes
    18. NaiveBayesModel
    19. OneVsRest
    20. OneVsRestModel
    21. ProbabilisticClassificationModel
    22. ProbabilisticClassifier
    23. RandomForestClassificationModel
    24. RandomForestClassifier
  1. focushideorg.apache.spark.ml.clustering
    1. BisectingKMeans
    2. BisectingKMeansModel
    3. BisectingKMeansSummary
    4. ClusteringSummary
    5. DistributedLDAModel
    6. GaussianMixture
    7. GaussianMixtureModel
    8. GaussianMixtureSummary
    9. KMeans
    10. KMeansModel
    11. KMeansSummary
    12. LDA
    13. LDAModel
    14. LocalLDAModel
  1. focushideorg.apache.spark.ml.evaluation
    1. BinaryClassificationEvaluator
    2. Evaluator
    3. MulticlassClassificationEvaluator
    4. RegressionEvaluator
  1. focushideorg.apache.spark.ml.feature
    1. Binarizer
    2. BucketedRandomProjectionLSH
    3. BucketedRandomProjectionLSHModel
    4. Bucketizer
    5. ChiSqSelector
    6. ChiSqSelectorModel
    7. CountVectorizer
    8. CountVectorizerModel
    9. DCT
    10. ElementwiseProduct
    11. HashingTF
    12. IDF
    13. IDFModel
    14. Imputer
    15. ImputerModel
    16. IndexToString
    17. Interaction
    18. LabeledPoint
    19. MaxAbsScaler
    20. MaxAbsScalerModel
    21. MinHashLSH
    22. MinHashLSHModel
    23. MinMaxScaler
    24. MinMaxScalerModel
    25. NGram
    26. Normalizer
    27. OneHotEncoder
    28. PCA
    29. PCAModel
    30. PolynomialExpansion
    31. QuantileDiscretizer
    32. RegexTokenizer
    33. RFormula
    34. RFormulaModel
    35. SQLTransformer
    36. StandardScaler
    37. StandardScalerModel
    38. StopWordsRemover
    39. StringIndexer
    40. StringIndexerModel
    41. Tokenizer
    42. VectorAssembler
    43. VectorIndexer
    44. VectorIndexerModel
    45. VectorSlicer
    46. Word2Vec
    47. Word2VecModel
  1. focushideorg.apache.spark.ml.fpm
    1. FPGrowth
    2. FPGrowthModel
  1. focushideorg.apache.spark.ml.linalg
    1. DenseMatrix
    2. DenseVector
    3. Matrices
    4. Matrix
    5. SparseMatrix
    6. SparseVector
    7. SQLDataTypes
    8. Vector
    9. Vectors
  1. focushideorg.apache.spark.ml.param
    1. BooleanParam
    2. DoubleArrayParam
    3. DoubleParam
    4. FloatParam
    5. IntArrayParam
    6. IntParam
    7. JavaParams
    8. LongParam
    9. Param
    10. ParamMap
    11. ParamPair
    12. Params
    13. ParamValidators
    14. StringArrayParam
  1. focushideorg.apache.spark.ml.recommendation
    1. ALS
    2. ALSModel
  1. focushideorg.apache.spark.ml.regression
    1. AFTSurvivalRegression
    2. AFTSurvivalRegressionModel
    3. DecisionTreeRegressionModel
    4. DecisionTreeRegressor
    5. GBTRegressionModel
    6. GBTRegressor
    7. GeneralizedLinearRegression
    8. GeneralizedLinearRegressionModel
    9. GeneralizedLinearRegressionSummary
    10. GeneralizedLinearRegressionTrainingSummary
    11. IsotonicRegression
    12. IsotonicRegressionModel
    13. LinearRegression
    14. LinearRegressionModel
    15. LinearRegressionSummary
    16. LinearRegressionTrainingSummary
    17. RandomForestRegressionModel
    18. RandomForestRegressor
    19. RegressionModel
  1. focushideorg.apache.spark.ml.source.libsvm
    1. LibSVMDataSource
  1. focushideorg.apache.spark.ml.stat
    1. ChiSquareTest
    2. Correlation
  1. focushideorg.apache.spark.ml.stat.distribution
    1. MultivariateGaussian