JavaScript is disabled on your browser.
Overview
Package
Class
Tree
Deprecated
Index
Help
Prev
Next
Frames
No Frames
All Classes
Hierarchy For All Packages
Package Hierarchies:
org.apache.spark
,
org.apache.spark.annotation
,
org.apache.spark.api.java
,
org.apache.spark.api.java.function
,
org.apache.spark.broadcast
,
org.apache.spark.io
,
org.apache.spark.mllib.classification
,
org.apache.spark.mllib.clustering
,
org.apache.spark.mllib.evaluation
,
org.apache.spark.mllib.linalg
,
org.apache.spark.mllib.linalg.distributed
,
org.apache.spark.mllib.optimization
,
org.apache.spark.mllib.recommendation
,
org.apache.spark.mllib.regression
,
org.apache.spark.mllib.stat
,
org.apache.spark.mllib.tree
,
org.apache.spark.mllib.tree.configuration
,
org.apache.spark.mllib.tree.impurity
,
org.apache.spark.mllib.tree.model
,
org.apache.spark.mllib.util
,
org.apache.spark.partial
,
org.apache.spark.rdd
,
org.apache.spark.scheduler
,
org.apache.spark.serializer
,
org.apache.spark.sql
,
org.apache.spark.sql.api.java
,
org.apache.spark.sql.execution
,
org.apache.spark.sql.hive
,
org.apache.spark.sql.hive.api.java
,
org.apache.spark.sql.hive.execution
,
org.apache.spark.sql.hive.test
,
org.apache.spark.sql.parquet
,
org.apache.spark.sql.test
,
org.apache.spark.storage
,
org.apache.spark.streaming
,
org.apache.spark.streaming.api.java
,
org.apache.spark.streaming.dstream
,
org.apache.spark.streaming.flume
,
org.apache.spark.streaming.kafka
,
org.apache.spark.streaming.mqtt
,
org.apache.spark.streaming.receiver
,
org.apache.spark.streaming.scheduler
,
org.apache.spark.streaming.twitter
,
org.apache.spark.streaming.zeromq
,
org.apache.spark.ui.env
,
org.apache.spark.ui.exec
,
org.apache.spark.ui.jobs
,
org.apache.spark.ui.storage
,
org.apache.spark.util
,
org.apache.spark.util.random
Class Hierarchy
Object
scala.runtime.AbstractFunction3<T1,T2,T3,R> (implements scala.Function3<T1,T2,T3,R>)
org.apache.spark.sql.execution.
Aggregate.ComputedAggregate$
(implements scala.Serializable)
org.apache.spark.
Accumulable
<R,T> (implements java.io.Serializable)
org.apache.spark.
Accumulator
<T>
org.apache.spark.streaming.receiver.
ActorSupervisorStrategy
org.apache.spark.sql.execution.
Aggregate.ComputedAggregate
(implements scala.Product, scala.Serializable)
org.apache.spark.
Aggregator
<K,V,C> (implements scala.Product, scala.Serializable)
org.apache.spark.mllib.recommendation.
ALS
(implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.rdd.
AsyncRDDActions
<T> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.streaming.scheduler.
BatchInfo
(implements scala.Product, scala.Serializable)
org.apache.spark.util.random.
BernoulliSampler
<T> (implements org.apache.spark.util.random.
RandomSampler
<T,U>)
org.apache.spark.mllib.evaluation.
BinaryClassificationMetrics
(implements org.apache.spark.
Logging
)
org.apache.spark.storage.
BlockId
org.apache.spark.storage.
BroadcastBlockId
(implements scala.Product, scala.Serializable)
org.apache.spark.storage.
RDDBlockId
(implements scala.Product, scala.Serializable)
org.apache.spark.storage.
ShuffleBlockId
(implements scala.Product, scala.Serializable)
org.apache.spark.storage.
StreamBlockId
(implements scala.Product, scala.Serializable)
org.apache.spark.storage.
TaskResultBlockId
(implements scala.Product, scala.Serializable)
org.apache.spark.storage.
BlockManagerId
(implements java.io.Externalizable)
org.apache.spark.storage.
BlockStatus
(implements scala.Product, scala.Serializable)
org.apache.spark.partial.
BoundedDouble
org.apache.spark.broadcast.
Broadcast
<T> (implements java.io.Serializable)
org.apache.spark.sql.execution.
BuildSide
org.apache.spark.sql.execution.
BuildLeft
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
BuildRight
(implements scala.Product, scala.Serializable)
org.apache.spark.
ComplexFutureAction
<T> (implements org.apache.spark.
FutureAction
<T>)
org.apache.spark.mllib.linalg.distributed.
CoordinateMatrix
(implements org.apache.spark.mllib.linalg.distributed.
DistributedMatrix
)
org.apache.spark.mllib.util.
DataValidators
(implements org.apache.spark.
Logging
)
org.apache.spark.mllib.tree.
DecisionTree
(implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.mllib.tree.model.
DecisionTreeModel
(implements scala.Serializable)
org.apache.spark.mllib.linalg.
DenseMatrix
(implements org.apache.spark.mllib.linalg.
Matrix
)
org.apache.spark.mllib.linalg.
DenseVector
(implements org.apache.spark.mllib.linalg.
Vector
)
org.apache.spark.
Dependency
<T> (implements scala.Serializable)
org.apache.spark.
NarrowDependency
<T>
org.apache.spark.
OneToOneDependency
<T>
org.apache.spark.
RangeDependency
<T>
org.apache.spark.
ShuffleDependency
<K,V>
org.apache.spark.rdd.
DoubleRDDFunctions
(implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.streaming.dstream.
DStream
<T> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.streaming.dstream.
InputDStream
<T>
org.apache.spark.streaming.dstream.
ConstantInputDStream
<T>
org.apache.spark.streaming.dstream.
ReceiverInputDStream
<T>
org.apache.spark.streaming.
Duration
(implements scala.Product, scala.Serializable)
org.apache.spark.mllib.tree.impurity.
Entropy
(implements org.apache.spark.mllib.tree.impurity.
Impurity
)
scala.Enumeration (implements scala.Serializable)
org.apache.spark.mllib.tree.configuration.
Algo
org.apache.spark.mllib.tree.configuration.
FeatureType
org.apache.spark.mllib.tree.configuration.
QuantileStrategy
org.apache.spark.scheduler.
SchedulingMode
org.apache.spark.scheduler.
TaskLocality
org.apache.spark.ui.env.
EnvironmentListener
(implements org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.
ExceptionFailure
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.
ExecutorLostFailure
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.ui.exec.
ExecutorsListener
(implements org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.ui.jobs.
ExecutorSummary
org.apache.spark.
FetchFailed
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.streaming.flume.
FlumeUtils
org.apache.spark.mllib.regression.
GeneralizedLinearAlgorithm
<M> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.mllib.regression.
LassoWithSGD
(implements scala.Serializable)
org.apache.spark.mllib.regression.
LinearRegressionWithSGD
(implements scala.Serializable)
org.apache.spark.mllib.classification.
LogisticRegressionWithSGD
(implements scala.Serializable)
org.apache.spark.mllib.regression.
RidgeRegressionWithSGD
(implements scala.Serializable)
org.apache.spark.mllib.classification.
SVMWithSGD
(implements scala.Serializable)
org.apache.spark.mllib.regression.
GeneralizedLinearModel
(implements scala.Serializable)
org.apache.spark.mllib.regression.
LassoModel
(implements org.apache.spark.mllib.regression.
RegressionModel
, scala.Serializable)
org.apache.spark.mllib.regression.
LinearRegressionModel
(implements org.apache.spark.mllib.regression.
RegressionModel
, scala.Serializable)
org.apache.spark.mllib.classification.
LogisticRegressionModel
(implements org.apache.spark.mllib.classification.
ClassificationModel
, scala.Serializable)
org.apache.spark.mllib.regression.
RidgeRegressionModel
(implements org.apache.spark.mllib.regression.
RegressionModel
, scala.Serializable)
org.apache.spark.mllib.classification.
SVMModel
(implements org.apache.spark.mllib.classification.
ClassificationModel
, scala.Serializable)
org.apache.spark.mllib.tree.impurity.
Gini
(implements org.apache.spark.mllib.tree.impurity.
Impurity
)
org.apache.spark.mllib.optimization.
Gradient
(implements scala.Serializable)
org.apache.spark.mllib.optimization.
HingeGradient
org.apache.spark.mllib.optimization.
LeastSquaresGradient
org.apache.spark.mllib.optimization.
LogisticGradient
org.apache.spark.mllib.optimization.
GradientDescent
(implements org.apache.spark.
Logging
, org.apache.spark.mllib.optimization.
Optimizer
)
org.apache.spark.sql.hive.
HiveMetastoreTypes
(implements scala.util.parsing.combinator.RegexParsers)
org.apache.spark.broadcast.
HttpBroadcastFactory
(implements org.apache.spark.broadcast.
BroadcastFactory
)
org.apache.spark.mllib.linalg.distributed.
IndexedRow
(implements scala.Product, scala.Serializable)
org.apache.spark.mllib.linalg.distributed.
IndexedRowMatrix
(implements org.apache.spark.mllib.linalg.distributed.
DistributedMatrix
)
org.apache.spark.mllib.tree.model.
InformationGainStats
(implements scala.Serializable)
org.apache.spark.scheduler.
InputFormatInfo
(implements org.apache.spark.
Logging
)
org.apache.spark.
InterruptibleIterator
<T> (implements scala.collection.Iterator<A>)
org.apache.spark.api.java.
JavaDoubleRDD
(implements org.apache.spark.api.java.
JavaRDDLike
<T,This>)
org.apache.spark.streaming.api.java.
JavaDStream
<T> (implements org.apache.spark.streaming.api.java.
JavaDStreamLike
<T,This,R>)
org.apache.spark.streaming.api.java.
JavaInputDStream
<T>
org.apache.spark.streaming.api.java.
JavaReceiverInputDStream
<T>
org.apache.spark.streaming.api.java.
JavaPairDStream
<K,V> (implements org.apache.spark.streaming.api.java.
JavaDStreamLike
<T,This,R>)
org.apache.spark.streaming.api.java.
JavaPairInputDStream
<K,V>
org.apache.spark.streaming.api.java.
JavaPairReceiverInputDStream
<K,V>
org.apache.spark.api.java.
JavaPairRDD
<K,V> (implements org.apache.spark.api.java.
JavaRDDLike
<T,This>)
org.apache.spark.api.java.
JavaRDD
<T> (implements org.apache.spark.api.java.
JavaRDDLike
<T,This>)
org.apache.spark.sql.api.java.
JavaSchemaRDD
(implements org.apache.spark.api.java.
JavaRDDLike
<T,This>)
org.apache.spark.serializer.
JavaSerializer
(implements java.io.Externalizable, org.apache.spark.serializer.
Serializer
)
org.apache.spark.api.java.
JavaSparkContext
org.apache.spark.sql.api.java.
JavaSQLContext
org.apache.spark.sql.hive.api.java.
JavaHiveContext
org.apache.spark.streaming.api.java.
JavaStreamingContext
org.apache.spark.scheduler.
JobLogger
(implements org.apache.spark.
Logging
, org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.ui.jobs.
JobProgressListener
(implements org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.scheduler.
JobSucceeded
(implements org.apache.spark.scheduler.
JobResult
, scala.Product, scala.Serializable)
org.apache.spark.streaming.kafka.
KafkaUtils
org.apache.spark.mllib.clustering.
KMeans
(implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.mllib.util.
KMeansDataGenerator
org.apache.spark.mllib.clustering.
KMeansModel
(implements scala.Serializable)
org.apache.spark.serializer.
KryoSerializer
(implements org.apache.spark.
Logging
, scala.Serializable, org.apache.spark.serializer.
Serializer
)
org.apache.spark.mllib.regression.
LabeledPoint
(implements scala.Product, scala.Serializable)
org.apache.spark.mllib.optimization.
LBFGS
(implements org.apache.spark.
Logging
, org.apache.spark.mllib.optimization.
Optimizer
)
org.apache.spark.mllib.util.
LinearDataGenerator
org.apache.spark.mllib.util.
LogisticRegressionDataGenerator
org.apache.spark.io.
LZFCompressionCodec
(implements org.apache.spark.io.
CompressionCodec
)
org.apache.spark.mllib.linalg.
Matrices
org.apache.spark.mllib.linalg.distributed.
MatrixEntry
(implements scala.Product, scala.Serializable)
org.apache.spark.mllib.recommendation.
MatrixFactorizationModel
(implements scala.Serializable)
org.apache.spark.mllib.util.
MFDataGenerator
org.apache.spark.streaming.
Milliseconds
org.apache.spark.streaming.
Minutes
org.apache.spark.mllib.util.
MLUtils
org.apache.spark.streaming.mqtt.
MQTTUtils
org.apache.spark.util.
MutablePair
<T1,T2> (implements scala.Product, scala.Product2<T1,T2>, scala.Serializable)
org.apache.spark.mllib.classification.
NaiveBayes
(implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.mllib.classification.
NaiveBayesModel
(implements org.apache.spark.mllib.classification.
ClassificationModel
, scala.Serializable)
org.apache.spark.mllib.tree.model.
Node
(implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.rdd.
OrderedRDDFunctions
<K,V,P> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.streaming.dstream.
PairDStreamFunctions
<K,V> (implements scala.Serializable)
org.apache.spark.rdd.
PairRDDFunctions
<K,V> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.sql.parquet.
ParquetFilters
org.apache.spark.partial.
PartialResult
<R>
org.apache.spark.
Partitioner
(implements scala.Serializable)
org.apache.spark.
HashPartitioner
org.apache.spark.
RangePartitioner
<K,V>
org.apache.spark.util.random.
PoissonSampler
<T> (implements org.apache.spark.util.random.
RandomSampler
<T,U>)
org.apache.spark.mllib.recommendation.
Rating
(implements scala.Product, scala.Serializable)
org.apache.spark.rdd.
RDD
<T> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.rdd.
CoGroupedRDD
<K>
org.apache.spark.rdd.
HadoopRDD
<K,V> (implements org.apache.spark.
Logging
)
org.apache.spark.rdd.
JdbcRDD
<T> (implements org.apache.spark.
Logging
)
org.apache.spark.rdd.
NewHadoopRDD
<K,V> (implements org.apache.spark.
Logging
)
org.apache.spark.rdd.
PartitionPruningRDD
<T>
org.apache.spark.sql.
SchemaRDD
org.apache.spark.rdd.
ShuffledRDD
<K,V,P>
org.apache.spark.rdd.
UnionRDD
<T>
org.apache.spark.storage.
RDDInfo
(implements scala.math.Ordered<A>)
org.apache.spark.streaming.receiver.
Receiver
<T> (implements scala.Serializable)
org.apache.spark.streaming.scheduler.
ReceiverInfo
(implements scala.Product, scala.Serializable)
org.apache.spark.
Resubmitted
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.sql.api.java.
Row
(implements scala.Serializable)
org.apache.spark.mllib.linalg.distributed.
RowMatrix
(implements org.apache.spark.mllib.linalg.distributed.
DistributedMatrix
, org.apache.spark.
Logging
)
org.apache.spark.streaming.
Seconds
org.apache.spark.rdd.
SequenceFileRDDFunctions
<K,V> (implements org.apache.spark.
Logging
, scala.Serializable)
org.apache.spark.
SerializableWritable
<T> (implements java.io.Serializable)
org.apache.spark.
SimpleFutureAction
<T> (implements org.apache.spark.
FutureAction
<T>)
org.apache.spark.mllib.linalg.
SingularValueDecomposition
<UType,VType> (implements scala.Product, scala.Serializable)
org.apache.spark.io.
SnappyCompressionCodec
(implements org.apache.spark.io.
CompressionCodec
)
org.apache.spark.
SparkConf
(implements scala.Cloneable, org.apache.spark.
Logging
)
org.apache.spark.
SparkContext
(implements org.apache.spark.
Logging
)
org.apache.spark.
SparkContext.DoubleAccumulatorParam$
(implements org.apache.spark.
AccumulatorParam
<T>)
org.apache.spark.
SparkContext.FloatAccumulatorParam$
(implements org.apache.spark.
AccumulatorParam
<T>)
org.apache.spark.
SparkContext.IntAccumulatorParam$
(implements org.apache.spark.
AccumulatorParam
<T>)
org.apache.spark.
SparkContext.LongAccumulatorParam$
(implements org.apache.spark.
AccumulatorParam
<T>)
org.apache.spark.
SparkEnv
(implements org.apache.spark.
Logging
)
org.apache.spark.
SparkFiles
org.apache.spark.streaming.flume.
SparkFlumeEvent
(implements java.io.Externalizable)
org.apache.spark.scheduler.
SparkListenerApplicationEnd
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerApplicationStart
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerBlockManagerAdded
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerBlockManagerRemoved
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerEnvironmentUpdate
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerJobEnd
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerJobStart
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerStageCompleted
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerStageSubmitted
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerTaskEnd
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerTaskGettingResult
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerTaskStart
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.scheduler.
SparkListenerUnpersistRDD
(implements scala.Product, scala.Serializable, org.apache.spark.scheduler.
SparkListenerEvent
)
org.apache.spark.mllib.linalg.
SparseVector
(implements org.apache.spark.mllib.linalg.
Vector
)
org.apache.spark.mllib.tree.model.
Split
(implements scala.Product, scala.Serializable)
org.apache.spark.scheduler.
SplitInfo
org.apache.spark.sql.
SQLContext
(implements com.typesafe.scalalogging.slf4j.Logging, scala.Serializable, org.apache.spark.sql.
SQLConf
)
org.apache.spark.sql.hive.
HiveContext
org.apache.spark.sql.hive.
LocalHiveContext
org.apache.spark.sql.hive.test.
TestHiveContext
org.apache.spark.sql.hive.test.
TestHive
org.apache.spark.sql.test.
TestSQLContext
org.apache.spark.scheduler.
StageInfo
org.apache.spark.util.
StatCounter
(implements scala.Serializable)
org.apache.spark.streaming.receiver.
Statistics
(implements scala.Product, scala.Serializable)
org.apache.spark.scheduler.
StatsReportListener
(implements org.apache.spark.
Logging
, org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.streaming.scheduler.
StatsReportListener
(implements org.apache.spark.streaming.scheduler.
StreamingListener
)
org.apache.spark.storage.
StorageLevel
(implements java.io.Externalizable)
org.apache.spark.api.java.
StorageLevels
org.apache.spark.ui.storage.
StorageListener
(implements org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.storage.
StorageStatus
org.apache.spark.storage.
StorageStatusListener
(implements org.apache.spark.scheduler.
SparkListener
)
org.apache.spark.mllib.tree.configuration.
Strategy
(implements scala.Serializable)
org.apache.spark.streaming.
StreamingContext
(implements org.apache.spark.
Logging
)
org.apache.spark.streaming.scheduler.
StreamingListenerBatchCompleted
(implements scala.Product, scala.Serializable, org.apache.spark.streaming.scheduler.
StreamingListenerEvent
)
org.apache.spark.streaming.scheduler.
StreamingListenerBatchStarted
(implements scala.Product, scala.Serializable, org.apache.spark.streaming.scheduler.
StreamingListenerEvent
)
org.apache.spark.streaming.scheduler.
StreamingListenerBatchSubmitted
(implements scala.Product, scala.Serializable, org.apache.spark.streaming.scheduler.
StreamingListenerEvent
)
org.apache.spark.streaming.scheduler.
StreamingListenerReceiverError
(implements scala.Product, scala.Serializable, org.apache.spark.streaming.scheduler.
StreamingListenerEvent
)
org.apache.spark.streaming.scheduler.
StreamingListenerReceiverStarted
(implements scala.Product, scala.Serializable, org.apache.spark.streaming.scheduler.
StreamingListenerEvent
)
org.apache.spark.streaming.scheduler.
StreamingListenerReceiverStopped
(implements scala.Product, scala.Serializable, org.apache.spark.streaming.scheduler.
StreamingListenerEvent
)
org.apache.spark.
Success
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskEndReason
)
org.apache.spark.mllib.util.
SVMDataGenerator
org.apache.spark.
TaskContext
(implements scala.Serializable)
org.apache.spark.scheduler.
TaskInfo
org.apache.spark.
TaskKilled
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.
TaskResultLost
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.ui.jobs.
TaskUIData
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.hive.test.
TestHiveContext.QueryExecution
org.apache.spark.sql.hive.test.
TestHiveContext.TestTable
(implements scala.Product, scala.Serializable)
Throwable (implements java.io.Serializable)
Exception
org.apache.spark.sql.execution.
QueryExecutionException
RuntimeException
org.apache.spark.
TaskKilledException
org.apache.spark.
SparkException
org.apache.spark.streaming.
Time
(implements scala.Product, scala.Serializable)
org.apache.spark.broadcast.
TorrentBroadcastFactory
(implements org.apache.spark.broadcast.
BroadcastFactory
)
org.apache.spark.sql.catalyst.trees.TreeNode<BaseType>
org.apache.spark.sql.catalyst.plans.QueryPlan<PlanType>
org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
org.apache.spark.sql.execution.
SparkLogicalPlan
(implements org.apache.spark.sql.catalyst.analysis.MultiInstanceRelation, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
SparkPlan
(implements com.typesafe.scalalogging.slf4j.Logging)
org.apache.spark.sql.execution.
Aggregate
(implements org.apache.spark.sql.catalyst.expressions.NoBind, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
BroadcastNestedLoopJoin
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
CacheCommand
(implements org.apache.spark.sql.execution.
Command
, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
CartesianProduct
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
DescribeCommand
(implements org.apache.spark.sql.execution.
Command
, scala.Product, scala.Serializable)
org.apache.spark.sql.hive.execution.
DescribeHiveTableCommand
(implements org.apache.spark.sql.execution.
Command
, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Exchange
(implements org.apache.spark.sql.catalyst.expressions.NoBind, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
ExistingRdd
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
ExplainCommand
(implements org.apache.spark.sql.execution.
Command
, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Filter
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Generate
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
HashJoin
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.hive.execution.
HiveTableScan
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.hive.execution.
InsertIntoHiveTable
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.parquet.
InsertIntoParquetTable
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
LeftSemiJoinBNL
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
LeftSemiJoinHash
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Limit
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.hive.execution.
NativeCommand
(implements org.apache.spark.sql.execution.
Command
, scala.Product, scala.Serializable)
org.apache.spark.sql.parquet.
ParquetTableScan
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Project
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Sample
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.hive.execution.
ScriptTransformation
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
SetCommand
(implements org.apache.spark.sql.execution.
Command
, scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Sort
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
TakeOrdered
(implements scala.Product, scala.Serializable)
org.apache.spark.sql.execution.
Union
(implements scala.Product, scala.Serializable)
org.apache.spark.streaming.twitter.
TwitterUtils
org.apache.spark.
UnknownReason
(implements scala.Product, scala.Serializable, org.apache.spark.
TaskFailedReason
)
org.apache.spark.mllib.optimization.
Updater
(implements scala.Serializable)
org.apache.spark.mllib.optimization.
L1Updater
org.apache.spark.mllib.optimization.
SimpleUpdater
org.apache.spark.mllib.optimization.
SquaredL2Updater
org.apache.spark.mllib.tree.impurity.
Variance
(implements org.apache.spark.mllib.tree.impurity.
Impurity
)
org.apache.spark.util.
Vector
(implements scala.Serializable)
org.apache.spark.util.
Vector.Multiplier
org.apache.spark.util.
Vector.VectorAccumParam$
(implements org.apache.spark.
AccumulatorParam
<T>)
org.apache.spark.mllib.linalg.
Vectors
org.apache.spark.streaming.zeromq.
ZeroMQUtils
Interface Hierarchy
org.apache.spark.streaming.receiver.
ActorHelper
scala.concurrent.Awaitable<T>
scala.concurrent.Future<T>
org.apache.spark.
FutureAction
<T>
org.apache.spark.broadcast.
BroadcastFactory
Cloneable
scala.Cloneable
org.apache.spark.util.random.
RandomSampler
<T,U> (also extends org.apache.spark.util.random.
Pseudorandom
, scala.Serializable)
org.apache.spark.sql.execution.
Command
org.apache.spark.io.
CompressionCodec
org.apache.spark.serializer.
DeserializationStream
org.apache.spark.streaming.api.java.
JavaStreamingContextFactory
org.apache.spark.scheduler.
JobResult
org.apache.spark.serializer.
KryoRegistrator
org.apache.spark.
Logging
org.apache.spark.mllib.stat.
MultivariateStatisticalSummary
org.apache.spark.util.random.
Pseudorandom
org.apache.spark.util.random.
RandomSampler
<T,U> (also extends scala.Cloneable, scala.Serializable)
java.io.Serializable
org.apache.spark.
AccumulableParam
<R,T>
org.apache.spark.
AccumulatorParam
<T>
org.apache.spark.api.java.function.
DoubleFlatMapFunction
<T>
org.apache.spark.api.java.function.
DoubleFunction
<T>
org.apache.spark.api.java.function.
FlatMapFunction
<T,R>
org.apache.spark.api.java.function.
FlatMapFunction2
<T1,T2,R>
org.apache.spark.api.java.function.
Function
<T1,R>
org.apache.spark.api.java.function.
Function2
<T1,T2,R>
org.apache.spark.api.java.function.
Function3
<T1,T2,T3,R>
org.apache.spark.api.java.function.
PairFlatMapFunction
<T,K,V>
org.apache.spark.api.java.function.
PairFunction
<T,K,V>
scala.Serializable
org.apache.spark.mllib.classification.
ClassificationModel
org.apache.spark.mllib.linalg.distributed.
DistributedMatrix
org.apache.spark.mllib.tree.impurity.
Impurity
org.apache.spark.streaming.api.java.
JavaDStreamLike
<T,This,R>
org.apache.spark.api.java.
JavaRDDLike
<T,This>
org.apache.spark.mllib.linalg.
Matrix
org.apache.spark.mllib.optimization.
Optimizer
org.apache.spark.
Partition
org.apache.spark.util.random.
RandomSampler
<T,U> (also extends scala.Cloneable, org.apache.spark.util.random.
Pseudorandom
)
org.apache.spark.mllib.regression.
RegressionModel
org.apache.spark.mllib.linalg.
Vector
org.apache.spark.api.java.function.
VoidFunction
<T>
org.apache.spark.serializer.
SerializationStream
org.apache.spark.serializer.
Serializer
org.apache.spark.serializer.
SerializerInstance
org.apache.spark.scheduler.
SparkListener
org.apache.spark.scheduler.
SparkListenerEvent
org.apache.spark.sql.
SQLConf
org.apache.spark.streaming.scheduler.
StreamingListener
org.apache.spark.streaming.scheduler.
StreamingListenerEvent
org.apache.spark.
TaskEndReason
org.apache.spark.
TaskFailedReason
Annotation Type Hierarchy
org.apache.spark.annotation.
AlphaComponent
(implements java.lang.annotation.Annotation)
org.apache.spark.annotation.
DeveloperApi
(implements java.lang.annotation.Annotation)
org.apache.spark.annotation.
Experimental
(implements java.lang.annotation.Annotation)
Overview
Package
Class
Tree
Deprecated
Index
Help
Prev
Next
Frames
No Frames
All Classes