:: DeveloperApi ::
Groups input data by groupingExpressions
and computes the aggregateExpressions
for each
group.
:: DeveloperApi ::
Groups input data by groupingExpressions
and computes the aggregateExpressions
for each
group.
if true then aggregation is done partially on local data without shuffling to
ensure all values where groupingExpressions
are equal are present.
expressions that are evaluated to determine grouping.
expressions that are computed for each group.
the input data source.
:: DeveloperApi :: Uses PythonRDD to evaluate a PythonUDF, one partition of tuples at a time.
:: DeveloperApi :: Uses PythonRDD to evaluate a PythonUDF, one partition of tuples at a time.
Python evaluation works by sending the necessary (projected) input data via a socket to an external Python process, and combine the result from the Python process with the original row.
For each row we send to Python, we also put it in a queue. For each output row from Python, we drain the queue to find the original input row. Note that if the Python process is way too slow, this could lead to the queue growing unbounded and eventually run out of memory.
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi :: Converts UnsafeRows back into Java-object-based rows.
:: DeveloperApi :: Converts UnsafeRows back into Java-object-based rows.
:: DeveloperApi :: Converts Java-object-based rows into UnsafeRows.
:: DeveloperApi :: Converts Java-object-based rows into UnsafeRows.
:: DeveloperApi ::
:: DeveloperApi ::
A command for users to get the usage of a registered function.
A command for users to get the usage of a registered function. The syntax of using this command in SQL is
DESCRIBE FUNCTION [EXTENDED] upper;
:: DeveloperApi :: Evaluates a PythonUDF, appending the result to the end of the input tuple.
:: 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 :: 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
.
:: 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.
Apply the all of the GroupExpressions to every input row, hence we will get multiple output rows for a input row.
The group of expressions, all of the group expressions should
output the same schema specified bye the parameter output
The output Schema
Child operator
An explain command for users to see how a command will be executed.
An explain command for users to see how a command will be executed.
Note that this command takes in a logical plan, runs the optimizer on the logical plan (but do NOT actually execute it).
:: DeveloperApi ::
Performs a sort, spilling to disk as needed.
Performs a sort, spilling to disk as needed.
when true performs a global sort of all partitions by shuffling the data first if necessary.
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi :: Applies a Generator to a stream of input rows, combining the output of each into a new stream of rows.
:: DeveloperApi ::
Applies a Generator to a stream of input rows, combining the
output of each into a new stream of rows. This operation is similar to a flatMap
in functional
programming with one important additional feature, which allows the input rows to be joined with
their output.
the generator expression
when true, each output row is implicitly joined with the input tuple that produced it.
when true, each input row will be output at least once, even if the output of the
given generator
is empty. outer
has no effect when join
is false.
the output attributes of this node, which constructed in analysis phase, and we can not change it, as the parent node bound with it already.
:: DeveloperApi :: Returns the rows in left that also appear in right using the built in spark intersection function.
:: 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 :: Take the first limit elements. Note that the implementation is different depending on whether this is a terminal operator or not. If it is terminal and is invoked using executeCollect, this operator uses something similar to Spark's take method on the Spark driver. If it is not terminal or is invoked using execute, we first take the limit on each partition, and then repartition all the data to a single partition to compute the global limit.
:: DeveloperApi :: A plan node that does nothing but lie about the output of its child.
:: DeveloperApi :: A plan node that does nothing but lie about the output of its child. Used to spice a (hopefully structurally equivalent) tree from a different optimization sequence into an already resolved tree.
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi ::
Return a new RDD that has exactly numPartitions
partitions.
:: DeveloperApi ::
Return a new RDD that has exactly numPartitions
partitions.
:: DeveloperApi :: Sample the dataset.
:: DeveloperApi :: Sample the dataset.
Lower-bound of the sampling probability (usually 0.0)
Upper-bound of the sampling probability. The expected fraction sampled will be ub - lb.
Whether to sample with replacement.
the random seed
the QueryPlan
:: DeveloperApi ::
:: DeveloperApi ::
A command for users to list all of the registered functions.
A command for users to list all of the registered functions. The syntax of using this command in SQL is:
SHOW FUNCTIONS
TODO currently we are simply ignore the db
A command for users to get tables in the given database.
A command for users to get tables in the given database. If a databaseName is not given, the current database will be used. The syntax of using this command in SQL is:
SHOW TABLES [IN databaseName]
:: DeveloperApi ::
This is a specialized version of org.apache.spark.rdd.ShuffledRDD that is optimized for shuffling rows instead of Java key-value pairs.
This is a specialized version of org.apache.spark.rdd.ShuffledRDD that is optimized for shuffling rows instead of Java key-value pairs. Note that something like this should eventually be implemented in Spark core, but that is blocked by some more general refactorings to shuffle interfaces / internals.
Performs a sort on-heap.
Performs a sort on-heap.
when true performs a global sort of all partitions by shuffling the data first if necessary.
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi :: Take the first limit elements as defined by the sortOrder, and do projection if needed.
:: DeveloperApi :: Take the first limit elements as defined by the sortOrder, and do projection if needed. This is logically equivalent to having a Limit operator after a Sort operator, or having a Project operator between them. This could have been named TopK, but Spark's top operator does the opposite in ordering so we name it TakeOrdered to avoid confusion.
A variant of Project that returns UnsafeRows.
Optimized version of ExternalSort that operates on binary data (implemented as part of Project Tungsten).
Optimized version of ExternalSort that operates on binary data (implemented as part of Project Tungsten).
when true performs a global sort of all partitions by shuffling the data first if necessary.
Method for configuring periodic spilling in unit tests. If set, will
spill every frequency
records.
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi ::
:: DeveloperApi :: This class calculates and outputs (windowed) aggregates over the rows in a single (sorted) partition.
:: DeveloperApi :: This class calculates and outputs (windowed) aggregates over the rows in a single (sorted) partition. The aggregates are calculated for each row in the group. Special processing instructions, frames, are used to calculate these aggregates. Frames are processed in the order specified in the window specification (the ORDER BY ... clause). There are four different frame types: - Entire partition: The frame is the entire partition, i.e. UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING. For this case, window function will take all rows as inputs and be evaluated once. - Growing frame: We only add new rows into the frame, i.e. UNBOUNDED PRECEDING AND .... Every time we move to a new row to process, we add some rows to the frame. We do not remove rows from this frame. - Shrinking frame: We only remove rows from the frame, i.e. ... AND UNBOUNDED FOLLOWING. Every time we move to a new row to process, we remove some rows from the frame. We do not add rows to this frame. - Moving frame: Every time we move to a new row to process, we remove some rows from the frame and we add some rows to the frame. Examples are: 1 PRECEDING AND CURRENT ROW and 1 FOLLOWING AND 2 FOLLOWING.
Different frame boundaries can be used in Growing, Shrinking and Moving frames. A frame boundary can be either Row or Range based: - Row Based: A row based boundary is based on the position of the row within the partition. An offset indicates the number of rows above or below the current row, the frame for the current row starts or ends. For instance, given a row based sliding frame with a lower bound offset of -1 and a upper bound offset of +2. The frame for row with index 5 would range from index 4 to index 6. - Range based: A range based boundary is based on the actual value of the ORDER BY expression(s). An offset is used to alter the value of the ORDER BY expression, for instance if the current order by expression has a value of 10 and the lower bound offset is -3, the resulting lower bound for the current row will be 10 - 3 = 7. This however puts a number of constraints on the ORDER BY expressions: there can be only one expression and this expression must have a numerical data type. An exception can be made when the offset is 0, because no value modification is needed, in this case multiple and non-numeric ORDER BY expression are allowed.
This is quite an expensive operator because every row for a single group must be in the same partition and partitions must be sorted according to the grouping and sort order. The operator requires the planner to take care of the partitioning and sorting.
The operator is semi-blocking. The window functions and aggregates are calculated one group at a time, the result will only be made available after the processing for the entire group has finished. The operator is able to process different frame configurations at the same time. This is done by delegating the actual frame processing (i.e. calculation of the window functions) to specialized classes, see WindowFunctionFrame, which take care of their own frame type: Entire Partition, Sliding, Growing & Shrinking. Boundary evaluation is also delegated to a pair of specialized classes: RowBoundOrdering & RangeBoundOrdering.
:: DeveloperApi :: Clear all cached data from the in-memory cache.
:: DeveloperApi :: Clear all cached data from the in-memory cache.
:: DeveloperApi ::
:: DeveloperApi ::
Contains methods for debugging query execution.
Contains methods for debugging query execution.
Usage:
import org.apache.spark.sql.execution.debug._ sql("SELECT key FROM src").debug() dataFrame.typeCheck()
:: DeveloperApi :: Physical execution operators for join operations.
The physical execution component of Spark SQL. Note that this is a private package.