:: DeveloperApi ::
Groups input data by groupingExpressions
and computes the aggregateExpressions
for each
group.
:: DeveloperApi :: Uses PythonRDD to evaluate a PythonUDF, one partition of tuples at a time.
:: DeveloperApi ::
:: DeveloperApi :: Converts UnsafeRows back into Java-object-based rows.
:: DeveloperApi :: Converts Java-object-based rows into UnsafeRows.
:: DeveloperApi ::
A command for users to get the usage of a registered function.
:: DeveloperApi :: Evaluates a PythonUDF, appending the result to the end of the input tuple.
:: DeveloperApi :: Returns a table with the elements from left that are not in right using the built-in spark subtract function.
:: DeveloperApi ::
Performs a shuffle that will result in the desired newPartitioning
.
Apply the all of the GroupExpressions to every input row, hence we will get multiple output rows for a input row.
An explain command for users to see how a command will be executed.
Performs a sort, spilling to disk as needed.
:: DeveloperApi ::
:: DeveloperApi :: Applies a Generator to a stream of input rows, combining the output of each into a new stream of rows.
:: DeveloperApi :: Returns the rows in left that also appear in right using the built in spark intersection function.
:: DeveloperApi :: Take the first limit elements.
:: DeveloperApi :: A plan node that does nothing but lie about the output of its child.
:: DeveloperApi ::
:: DeveloperApi ::
Return a new RDD that has exactly numPartitions
partitions.
:: DeveloperApi :: Sample the dataset.
:: DeveloperApi ::
A command for users to list all of the registered functions.
A command for users to get tables in the given database.
This is a specialized version of org.apache.spark.rdd.ShuffledRDD that is optimized for shuffling rows instead of Java key-value pairs.
Performs a sort on-heap.
:: DeveloperApi ::
:: DeveloperApi :: Take the first limit elements as defined by the sortOrder, and do projection if needed.
A variant of Project that returns UnsafeRows.
Optimized version of ExternalSort that operates on binary data (implemented as part of Project Tungsten).
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi :: This class calculates and outputs (windowed) aggregates over the rows in a single (sorted) partition.
:: DeveloperApi :: Clear all cached data from the in-memory cache.
:: DeveloperApi ::
Contains methods for debugging query execution.
:: DeveloperApi :: Physical execution operators for join operations.
The physical execution component of Spark SQL. Note that this is a private package.