#
A
B
C
D
E
F
G
H
I
J
K
L
M
N
O
P
Q
R
S
T
U
V
W
X
Y
Z
display packages only
focused on
focus
hide
org.apache.spark
Accumulable
AccumulableParam
Accumulator
AccumulatorParam
Aggregator
ComplexFutureAction
Dependency
ExceptionFailure
ExecutorLostFailure
FetchFailed
FutureAction
HashPartitioner
InterruptibleIterator
Logging
NarrowDependency
OneToOneDependency
Partition
Partitioner
RangeDependency
RangePartitioner
Resubmitted
SerializableWritable
ShuffleDependency
SimpleFutureAction
SparkConf
SparkContext
SparkEnv
SparkException
SparkFiles
Success
TaskContext
TaskEndReason
TaskFailedReason
TaskKilled
TaskKilledException
TaskResultLost
UnknownReason
focus
hide
org.apache.spark.annotation
AlphaComponent
DeveloperApi
Experimental
focus
hide
org.apache.spark.api.java
JavaDoubleRDD
JavaHadoopRDD
JavaNewHadoopRDD
JavaPairRDD
JavaRDD
JavaRDDLike
JavaSparkContext
StorageLevels
focus
hide
org.apache.spark.api.java.function
DoubleFlatMapFunction
DoubleFunction
FlatMapFunction
FlatMapFunction2
Function
Function2
Function3
PairFlatMapFunction
PairFunction
VoidFunction
focus
hide
org.apache.spark.api.python
Converter
TestWritable
WriteInputFormatTestDataGenerator
focus
hide
org.apache.spark.bagel
Aggregator
Bagel
Combiner
DefaultCombiner
Message
Vertex
focus
hide
org.apache.spark.broadcast
Broadcast
BroadcastFactory
HttpBroadcastFactory
TorrentBroadcastFactory
focus
hide
org.apache.spark.deploy
Client
ClientArguments
PythonRunner
SparkHadoopUtil
SparkSubmit
focus
hide
org.apache.spark.deploy.history
HistoryServer
focus
hide
org.apache.spark.deploy.master
ApplicationSource
MasterMessages
SparkCuratorUtil
ZooKeeperPersistenceEngine
focus
hide
org.apache.spark.deploy.worker
DriverWrapper
focus
hide
org.apache.spark.examples.streaming
JavaKinesisWordCountASL
focus
hide
org.apache.spark.executor
DataReadMethod
InputMetrics
ShuffleReadMetrics
ShuffleWriteMetrics
TaskMetrics
focus
hide
org.apache.spark.graphx
Edge
EdgeDirection
EdgeRDD
EdgeTriplet
Graph
GraphKryoRegistrator
GraphLoader
GraphOps
PartitionStrategy
Pregel
VertexRDD
focus
hide
org.apache.spark.graphx.impl
GraphImpl
focus
hide
org.apache.spark.graphx.lib
Analytics
ConnectedComponents
LabelPropagation
PageRank
ShortestPaths
StronglyConnectedComponents
SVDPlusPlus
TriangleCount
focus
hide
org.apache.spark.graphx.util
GraphGenerators
focus
hide
org.apache.spark.io
CompressionCodec
LZ4CompressionCodec
LZFCompressionCodec
SnappyCompressionCodec
focus
hide
org.apache.spark.mllib.api.python
MultivariateStatisticalSummarySerialized
PythonMLLibAPI
focus
hide
org.apache.spark.mllib.classification
ClassificationModel
LogisticRegressionModel
LogisticRegressionWithLBFGS
LogisticRegressionWithSGD
NaiveBayes
NaiveBayesModel
SVMModel
SVMWithSGD
focus
hide
org.apache.spark.mllib.clustering
KMeans
KMeansModel
focus
hide
org.apache.spark.mllib.evaluation
BinaryClassificationMetrics
MulticlassMetrics
focus
hide
org.apache.spark.mllib.feature
HashingTF
IDF
IDFModel
Normalizer
StandardScaler
StandardScalerModel
VectorTransformer
Word2Vec
Word2VecModel
focus
hide
org.apache.spark.mllib.linalg
DenseMatrix
DenseVector
Matrices
Matrix
SingularValueDecomposition
SparseVector
Vector
Vectors
focus
hide
org.apache.spark.mllib.linalg.distributed
CoordinateMatrix
DistributedMatrix
IndexedRow
IndexedRowMatrix
MatrixEntry
RowMatrix
focus
hide
org.apache.spark.mllib.optimization
Gradient
GradientDescent
HingeGradient
L1Updater
LBFGS
LeastSquaresGradient
LogisticGradient
Optimizer
SimpleUpdater
SquaredL2Updater
Updater
focus
hide
org.apache.spark.mllib.random
PoissonGenerator
RandomDataGenerator
RandomRDDs
StandardNormalGenerator
UniformGenerator
focus
hide
org.apache.spark.mllib.recommendation
ALS
MatrixFactorizationModel
Rating
focus
hide
org.apache.spark.mllib.regression
GeneralizedLinearAlgorithm
GeneralizedLinearModel
LabeledPoint
LassoModel
LassoWithSGD
LinearRegressionModel
LinearRegressionWithSGD
RegressionModel
RidgeRegressionModel
RidgeRegressionWithSGD
StreamingLinearAlgorithm
StreamingLinearRegressionWithSGD
focus
hide
org.apache.spark.mllib.stat
MultivariateOnlineSummarizer
MultivariateStatisticalSummary
Statistics
focus
hide
org.apache.spark.mllib.stat.test
ChiSqTestResult
TestResult
focus
hide
org.apache.spark.mllib.tree
DecisionTree
focus
hide
org.apache.spark.mllib.tree.configuration
Algo
FeatureType
QuantileStrategy
Strategy
focus
hide
org.apache.spark.mllib.tree.impurity
Entropy
Gini
Impurity
Variance
focus
hide
org.apache.spark.mllib.tree.model
DecisionTreeModel
InformationGainStats
Node
Split
focus
hide
org.apache.spark.mllib.util
DataValidators
KMeansDataGenerator
LinearDataGenerator
LogisticRegressionDataGenerator
MFDataGenerator
MLUtils
SVMDataGenerator
focus
hide
org.apache.spark.network.netty
PathResolver
focus
hide
org.apache.spark.network.netty.client
BlockClientListener
focus
hide
org.apache.spark.partial
BoundedDouble
PartialResult
focus
hide
org.apache.spark.rdd
AsyncRDDActions
CoGroupedRDD
DoubleRDDFunctions
HadoopRDD
JdbcRDD
NewHadoopRDD
OrderedRDDFunctions
PairRDDFunctions
PartitionPruningRDD
RDD
SequenceFileRDDFunctions
ShuffledRDD
UnionRDD
focus
hide
org.apache.spark.scheduler
AccumulableInfo
InputFormatInfo
JobLogger
JobResult
JobSucceeded
SchedulingMode
SparkListener
SparkListenerApplicationEnd
SparkListenerApplicationStart
SparkListenerBlockManagerAdded
SparkListenerBlockManagerRemoved
SparkListenerEnvironmentUpdate
SparkListenerEvent
SparkListenerExecutorMetricsUpdate
SparkListenerJobEnd
SparkListenerJobStart
SparkListenerStageCompleted
SparkListenerStageSubmitted
SparkListenerTaskEnd
SparkListenerTaskGettingResult
SparkListenerTaskStart
SparkListenerUnpersistRDD
SplitInfo
StageInfo
StatsReportListener
TaskInfo
TaskLocality
focus
hide
org.apache.spark.serializer
DeserializationStream
JavaSerializer
KryoRegistrator
KryoSerializer
SerializationStream
Serializer
SerializerInstance
focus
hide
org.apache.spark.sql
SchemaRDD
SQLContext
focus
hide
org.apache.spark.sql.api.java
ArrayType
BinaryType
BooleanType
ByteType
DataType
DecimalType
DoubleType
FloatType
IntegerType
JavaSchemaRDD
JavaSQLContext
LongType
MapType
Row
ShortType
StringType
StructField
StructType
TimestampType
UDF1
UDF10
UDF11
UDF12
UDF13
UDF14
UDF15
UDF16
UDF17
UDF18
UDF19
UDF2
UDF20
UDF21
UDF22
UDF3
UDF4
UDF5
UDF6
UDF7
UDF8
UDF9
focus
hide
org.apache.spark.sql.execution
Aggregate
AggregateEvaluation
BatchPythonEvaluation
BroadcastHashJoin
BroadcastNestedLoopJoin
BuildLeft
BuildRight
BuildSide
CacheCommand
CartesianProduct
Command
DescribeCommand
Distinct
EvaluatePython
Except
Exchange
ExistingRdd
ExplainCommand
Filter
Generate
GeneratedAggregate
HashJoin
HashOuterJoin
Intersect
LeftSemiJoinBNL
LeftSemiJoinHash
Limit
OutputFaker
Project
QueryExecutionException
Sample
SetCommand
ShuffledHashJoin
Sort
SparkLogicalPlan
SparkPlan
TakeOrdered
Union
focus
hide
org.apache.spark.sql.execution.debug
DebugQuery