#
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
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.bagel
Aggregator
Bagel
Combiner
DefaultCombiner
Message
Vertex
focus
hide
org.apache.spark.broadcast
Broadcast
BroadcastFactory
HttpBroadcastFactory
TorrentBroadcastFactory
focus
hide
org.apache.spark.executor
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
PageRank
ShortestPaths
StronglyConnectedComponents
SVDPlusPlus
TriangleCount
focus
hide
org.apache.spark.graphx.util
GraphGenerators
focus
hide
org.apache.spark.io
CompressionCodec
LZFCompressionCodec
SnappyCompressionCodec
focus
hide
org.apache.spark.metrics.sink
GangliaSink
focus
hide
org.apache.spark.mllib.api.python
PythonMLLibAPI
focus
hide
org.apache.spark.mllib.classification
ClassificationModel
LogisticRegressionModel
LogisticRegressionWithSGD
NaiveBayes
NaiveBayesModel
SVMModel
SVMWithSGD
focus
hide
org.apache.spark.mllib.clustering
KMeans
KMeansModel
focus
hide
org.apache.spark.mllib.evaluation
BinaryClassificationMetrics
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.recommendation
ALS
MatrixFactorizationModel
Rating
focus
hide
org.apache.spark.mllib.regression
GeneralizedLinearAlgorithm
GeneralizedLinearModel
LabeledPoint
LassoModel
LassoWithSGD
LinearRegressionModel
LinearRegressionWithSGD
RegressionModel
RidgeRegressionModel
RidgeRegressionWithSGD
focus
hide
org.apache.spark.mllib.stat
MultivariateStatisticalSummary
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.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
InputFormatInfo
JobLogger
JobResult
JobSucceeded
SchedulingMode
SparkListener
SparkListenerApplicationEnd
SparkListenerApplicationStart
SparkListenerBlockManagerAdded
SparkListenerBlockManagerRemoved
SparkListenerEnvironmentUpdate
SparkListenerEvent
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
SQLConf
SQLContext
focus
hide
org.apache.spark.sql.api.java
JavaSchemaRDD
JavaSQLContext
Row
focus
hide
org.apache.spark.sql.columnar
InMemoryRelation
focus
hide
org.apache.spark.sql.execution
Aggregate
BroadcastNestedLoopJoin
BuildLeft
BuildRight
BuildSide
CacheCommand
CartesianProduct
Command
DescribeCommand
Exchange
ExistingRdd
ExplainCommand
Filter
Generate
HashJoin
LeftSemiJoinBNL
LeftSemiJoinHash
Limit
Project
QueryExecutionException
Sample
SetCommand
Sort
SparkLogicalPlan
SparkPlan
TakeOrdered
Union
focus
hide
org.apache.spark.sql.execution.debug
DebugQuery
focus
hide
org.apache.spark.sql.hive
HiveContext
HiveMetastoreTypes
LocalHiveContext
focus
hide
org.apache.spark.sql.hive.api.java
JavaHiveContext
focus
hide
org.apache.spark.sql.hive.execution
DescribeHiveTableCommand
HiveTableScan
InsertIntoHiveTable
NativeCommand
ScriptTransformation
focus
hide
org.apache.spark.sql.hive.test
TestHive
TestHiveContext
focus
hide
org.apache.spark.sql.parquet
CatalystArrayConverter
InsertIntoParquetTable
ParquetFilters
ParquetTableScan
focus
hide
org.apache.spark.sql.test
TestSQLContext
focus
hide
org.apache.spark.storage
BlockId
BlockManagerId
BlockStatus
BroadcastBlockId
RDDBlockId
RDDInfo
ShuffleBlockId
StorageLevel
StorageStatus
StorageStatusListener
StreamBlockId
TaskResultBlockId
focus
hide
org.apache.spark.streaming
Duration
Milliseconds
Minutes
Seconds
StreamingContext
Time
focus
hide
org.apache.spark.streaming.api.java
JavaDStream
JavaDStreamLike
JavaInputDStream
JavaPairDStream
JavaPairInputDStream
JavaPairReceiverInputDStream
JavaReceiverInputDStream
JavaStreamingContext
JavaStreamingContextFactory
focus
hide
org.apache.spark.streaming.dstream
ConstantInputDStream
DStream
InputDStream
PairDStreamFunctions
ReceiverInputDStream
focus
hide
org.apache.spark.streaming.flume
FlumeUtils
SparkFlumeEvent
focus
hide
org.apache.spark.streaming.kafka
KafkaUtils
focus
hide
org.apache.spark.streaming.mqtt
MQTTUtils
focus
hide
org.apache.spark.streaming.receiver
ActorHelper
ActorSupervisorStrategy
Receiver
Statistics
focus
hide
org.apache.spark.streaming.scheduler
BatchInfo
ReceiverInfo
StatsReportListener
StreamingListener
StreamingListenerBatchCompleted
StreamingListenerBatchStarted
StreamingListenerBatchSubmitted
StreamingListenerEvent
StreamingListenerReceiverError
StreamingListenerReceiverStarted
StreamingListenerReceiverStopped
focus
hide
org.apache.spark.streaming.twitter
TwitterUtils
focus
hide
org.apache.spark.streaming.zeromq
ZeroMQUtils
focus
hide
org.apache.spark.ui.env
EnvironmentListener
focus
hide
org.apache.spark.ui.exec
ExecutorsListener
focus
hide
org.apache.spark.ui.jobs
ExecutorSummary
JobProgressListener
TaskUIData
focus
hide
org.apache.spark.ui.storage
StorageListener
focus
hide
org.apache.spark.util
MutablePair
StatCounter
Vector
focus
hide
org.apache.spark.util.random
BernoulliSampler
PoissonSampler
Pseudorandom
RandomSampler