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. Logging
    15. NarrowDependency
    16. OneToOneDependency
    17. Partition
    18. Partitioner
    19. RangeDependency
    20. RangePartitioner
    21. Resubmitted
    22. SerializableWritable
    23. ShuffleDependency
    24. SimpleFutureAction
    25. SparkConf
    26. SparkContext
    27. SparkEnv
    28. SparkException
    29. SparkFiles
    30. Success
    31. TaskContext
    32. TaskEndReason
    33. TaskFailedReason
    34. TaskKilled
    35. TaskKilledException
    36. TaskResultLost
    37. UnknownReason
  1. focushideorg.apache.spark.annotation
    1. AlphaComponent
    2. DeveloperApi
    3. Experimental
  1. focushideorg.apache.spark.api.java
    1. JavaDoubleRDD
    2. JavaHadoopRDD
    3. JavaNewHadoopRDD
    4. JavaPairRDD
    5. JavaRDD
    6. JavaRDDLike
    7. JavaSparkContext
    8. StorageLevels
  1. focushideorg.apache.spark.api.java.function
    1. DoubleFlatMapFunction
    2. DoubleFunction
    3. FlatMapFunction
    4. FlatMapFunction2
    5. Function
    6. Function2
    7. Function3
    8. PairFlatMapFunction
    9. PairFunction
    10. VoidFunction
  1. focushideorg.apache.spark.api.python
    1. Converter
    2. TestWritable
    3. WriteInputFormatTestDataGenerator
  1. focushideorg.apache.spark.bagel
    1. Aggregator
    2. Bagel
    3. Combiner
    4. DefaultCombiner
    5. Message
    6. Vertex
  1. focushideorg.apache.spark.broadcast
    1. Broadcast
    2. BroadcastFactory
    3. HttpBroadcastFactory
    4. TorrentBroadcastFactory
  1. focushideorg.apache.spark.deploy
    1. Client
    2. ClientArguments
    3. PythonRunner
    4. SparkHadoopUtil
    5. SparkSubmit
  1. focushideorg.apache.spark.deploy.history
    1. HistoryServer
  1. focushideorg.apache.spark.deploy.master
    1. ApplicationSource
    2. MasterMessages
    3. SparkCuratorUtil
    4. ZooKeeperPersistenceEngine
  1. focushideorg.apache.spark.deploy.worker
    1. DriverWrapper
  1. focushideorg.apache.spark.examples.streaming
    1. JavaKinesisWordCountASL
  1. focushideorg.apache.spark.executor
    1. DataReadMethod
    2. InputMetrics
    3. ShuffleReadMetrics
    4. ShuffleWriteMetrics
    5. TaskMetrics
  1. focushideorg.apache.spark.graphx
    1. Edge
    2. EdgeDirection
    3. EdgeRDD
    4. EdgeTriplet
    5. Graph
    6. GraphKryoRegistrator
    7. GraphLoader
    8. GraphOps
    9. PartitionStrategy
    10. Pregel
    11. VertexRDD
  1. focushideorg.apache.spark.graphx.impl
    1. GraphImpl
  1. focushideorg.apache.spark.graphx.lib
    1. Analytics
    2. ConnectedComponents
    3. LabelPropagation
    4. PageRank
    5. ShortestPaths
    6. StronglyConnectedComponents
    7. SVDPlusPlus
    8. TriangleCount
  1. focushideorg.apache.spark.graphx.util
    1. GraphGenerators
  1. focushideorg.apache.spark.io
    1. CompressionCodec
    2. LZ4CompressionCodec
    3. LZFCompressionCodec
    4. SnappyCompressionCodec
  1. focushideorg.apache.spark.mllib.api.python
    1. MultivariateStatisticalSummarySerialized
    2. PythonMLLibAPI
  1. focushideorg.apache.spark.mllib.classification
    1. ClassificationModel
    2. LogisticRegressionModel
    3. LogisticRegressionWithLBFGS
    4. LogisticRegressionWithSGD
    5. NaiveBayes
    6. NaiveBayesModel
    7. SVMModel
    8. SVMWithSGD
  1. focushideorg.apache.spark.mllib.clustering
    1. KMeans
    2. KMeansModel
  1. focushideorg.apache.spark.mllib.evaluation
    1. BinaryClassificationMetrics
    2. MulticlassMetrics
  1. focushideorg.apache.spark.mllib.feature
    1. HashingTF
    2. IDF
    3. IDFModel
    4. Normalizer
    5. StandardScaler
    6. StandardScalerModel
    7. VectorTransformer
    8. Word2Vec
    9. Word2VecModel
  1. focushideorg.apache.spark.mllib.linalg
    1. DenseMatrix
    2. DenseVector
    3. Matrices
    4. Matrix
    5. SingularValueDecomposition
    6. SparseVector
    7. Vector
    8. Vectors
  1. focushideorg.apache.spark.mllib.linalg.distributed
    1. CoordinateMatrix
    2. DistributedMatrix
    3. IndexedRow
    4. IndexedRowMatrix
    5. MatrixEntry
    6. RowMatrix
  1. focushideorg.apache.spark.mllib.optimization
    1. Gradient
    2. GradientDescent
    3. HingeGradient
    4. L1Updater
    5. LBFGS
    6. LeastSquaresGradient
    7. LogisticGradient
    8. Optimizer
    9. SimpleUpdater
    10. SquaredL2Updater
    11. Updater
  1. focushideorg.apache.spark.mllib.random
    1. PoissonGenerator
    2. RandomDataGenerator
    3. RandomRDDs
    4. StandardNormalGenerator
    5. UniformGenerator
  1. focushideorg.apache.spark.mllib.recommendation
    1. ALS
    2. MatrixFactorizationModel
    3. Rating
  1. focushideorg.apache.spark.mllib.regression
    1. GeneralizedLinearAlgorithm
    2. GeneralizedLinearModel
    3. LabeledPoint
    4. LassoModel
    5. LassoWithSGD
    6. LinearRegressionModel
    7. LinearRegressionWithSGD
    8. RegressionModel
    9. RidgeRegressionModel
    10. RidgeRegressionWithSGD
    11. StreamingLinearAlgorithm
    12. StreamingLinearRegressionWithSGD
  1. focushideorg.apache.spark.mllib.stat
    1. MultivariateOnlineSummarizer
    2. MultivariateStatisticalSummary
    3. Statistics
  1. focushideorg.apache.spark.mllib.stat.test
    1. ChiSqTestResult
    2. TestResult
  1. focushideorg.apache.spark.mllib.tree
    1. DecisionTree
  1. focushideorg.apache.spark.mllib.tree.configuration
    1. Algo
    2. FeatureType
    3. QuantileStrategy
    4. Strategy
  1. focushideorg.apache.spark.mllib.tree.impurity
    1. Entropy
    2. Gini
    3. Impurity
    4. Variance
  1. focushideorg.apache.spark.mllib.tree.model
    1. DecisionTreeModel
    2. InformationGainStats
    3. Node
    4. Split
  1. focushideorg.apache.spark.mllib.util
    1. DataValidators
    2. KMeansDataGenerator
    3. LinearDataGenerator
    4. LogisticRegressionDataGenerator
    5. MFDataGenerator
    6. MLUtils
    7. SVMDataGenerator
  1. focushideorg.apache.spark.network.netty
    1. PathResolver
  1. focushideorg.apache.spark.network.netty.client
    1. BlockClientListener
  1. focushideorg.apache.spark.partial
    1. BoundedDouble
    2. PartialResult
  1. focushideorg.apache.spark.rdd
    1. AsyncRDDActions
    2. CoGroupedRDD
    3. DoubleRDDFunctions
    4. HadoopRDD
    5. JdbcRDD
    6. NewHadoopRDD
    7. OrderedRDDFunctions
    8. PairRDDFunctions
    9. PartitionPruningRDD
    10. RDD
    11. SequenceFileRDDFunctions
    12. ShuffledRDD
    13. UnionRDD
  1. focushideorg.apache.spark.scheduler
    1. AccumulableInfo
    2. InputFormatInfo
    3. JobLogger
    4. JobResult
    5. JobSucceeded
    6. SchedulingMode
    7. SparkListener
    8. SparkListenerApplicationEnd
    9. SparkListenerApplicationStart
    10. SparkListenerBlockManagerAdded
    11. SparkListenerBlockManagerRemoved
    12. SparkListenerEnvironmentUpdate
    13. SparkListenerEvent
    14. SparkListenerExecutorMetricsUpdate
    15. SparkListenerJobEnd
    16. SparkListenerJobStart
    17. SparkListenerStageCompleted
    18. SparkListenerStageSubmitted
    19. SparkListenerTaskEnd
    20. SparkListenerTaskGettingResult
    21. SparkListenerTaskStart
    22. SparkListenerUnpersistRDD
    23. SplitInfo
    24. StageInfo
    25. StatsReportListener
    26. TaskInfo
    27. TaskLocality
  1. focushideorg.apache.spark.serializer
    1. DeserializationStream
    2. JavaSerializer
    3. KryoRegistrator
    4. KryoSerializer
    5. SerializationStream
    6. Serializer
    7. SerializerInstance
  1. focushideorg.apache.spark.sql
    1. SchemaRDD
    2. SQLContext
  1. focushideorg.apache.spark.sql.api.java
    1. ArrayType
    2. BinaryType
    3. BooleanType
    4. ByteType
    5. DataType
    6. DecimalType
    7. DoubleType
    8. FloatType
    9. IntegerType
    10. JavaSchemaRDD
    11. JavaSQLContext
    12. LongType
    13. MapType
    14. Row
    15. ShortType
    16. StringType
    17. StructField
    18. StructType
    19. TimestampType
    20. UDF1
    21. UDF10
    22. UDF11
    23. UDF12
    24. UDF13
    25. UDF14
    26. UDF15
    27. UDF16
    28. UDF17
    29. UDF18
    30. UDF19
    31. UDF2
    32. UDF20
    33. UDF21
    34. UDF22
    35. UDF3
    36. UDF4
    37. UDF5
    38. UDF6
    39. UDF7
    40. UDF8
    41. UDF9
  1. focushideorg.apache.spark.sql.execution
    1. Aggregate
    2. AggregateEvaluation
    3. BatchPythonEvaluation
    4. BroadcastHashJoin
    5. BroadcastNestedLoopJoin
    6. BuildLeft
    7. BuildRight
    8. BuildSide
    9. CacheCommand
    10. CartesianProduct
    11. Command
    12. DescribeCommand
    13. Distinct
    14. EvaluatePython
    15. Except
    16. Exchange
    17. ExistingRdd
    18. ExplainCommand
    19. Filter
    20. Generate
    21. GeneratedAggregate
    22. HashJoin
    23. HashOuterJoin
    24. Intersect
    25. LeftSemiJoinBNL
    26. LeftSemiJoinHash
    27. Limit
    28. OutputFaker
    29. Project
    30. QueryExecutionException
    31. Sample
    32. SetCommand
    33. ShuffledHashJoin
    34. Sort
    35. SparkLogicalPlan
    36. SparkPlan
    37. TakeOrdered
    38. Union
  1. focushideorg.apache.spark.sql.execution.debug
    1. DebugQuery