org.apache.spark.sql.execution

command

package command

Visibility
  1. Public
  2. All

Type Members

  1. case class AddFileCommand(path: String) extends LeafNode with RunnableCommand with Product with Serializable

    Adds a file to the current session so it can be used.

  2. case class AddJarCommand(path: String) extends LeafNode with RunnableCommand with Product with Serializable

    Adds a jar to the current session so it can be used (for UDFs or serdes).

  3. case class AlterDatabasePropertiesCommand(databaseName: String, props: Map[String, String]) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to add new (key, value) pairs into DBPROPERTIES If the database does not exist, an error message will be issued to indicate the database does not exist.

  4. case class AlterTableAddColumnsCommand(table: TableIdentifier, colsToAdd: Seq[StructField]) extends LeafNode with RunnableCommand with Product with Serializable

    A command that add columns to a table The syntax of using this command in SQL is:

  5. case class AlterTableAddPartitionCommand(tableName: TableIdentifier, partitionSpecsAndLocs: Seq[(TablePartitionSpec, Option[String])], ifNotExists: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    Add Partition in ALTER TABLE: add the table partitions.

  6. case class AlterTableChangeColumnCommand(tableName: TableIdentifier, columnName: String, newColumn: StructField) extends LeafNode with RunnableCommand with Product with Serializable

    A command to change the column for a table, only support changing the comment of a non-partition column for now.

  7. case class AlterTableDropPartitionCommand(tableName: TableIdentifier, specs: Seq[TablePartitionSpec], ifExists: Boolean, purge: Boolean, retainData: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    Drop Partition in ALTER TABLE: to drop a particular partition for a table.

  8. case class AlterTableRecoverPartitionsCommand(tableName: TableIdentifier, cmd: String = "ALTER TABLE RECOVER PARTITIONS") extends LeafNode with RunnableCommand with Product with Serializable

    Recover Partitions in ALTER TABLE: recover all the partition in the directory of a table and update the catalog.

  9. case class AlterTableRenameCommand(oldName: TableIdentifier, newName: TableIdentifier, isView: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command that renames a table/view.

  10. case class AlterTableRenamePartitionCommand(tableName: TableIdentifier, oldPartition: TablePartitionSpec, newPartition: TablePartitionSpec) extends LeafNode with RunnableCommand with Product with Serializable

    Alter a table partition's spec.

  11. case class AlterTableSerDePropertiesCommand(tableName: TableIdentifier, serdeClassName: Option[String], serdeProperties: Option[Map[String, String]], partSpec: Option[TablePartitionSpec]) extends LeafNode with RunnableCommand with Product with Serializable

    A command that sets the serde class and/or serde properties of a table/view.

  12. case class AlterTableSetLocationCommand(tableName: TableIdentifier, partitionSpec: Option[TablePartitionSpec], location: String) extends LeafNode with RunnableCommand with Product with Serializable

    A command that sets the location of a table or a partition.

  13. case class AlterTableSetPropertiesCommand(tableName: TableIdentifier, properties: Map[String, String], isView: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command that sets table/view properties.

  14. case class AlterTableUnsetPropertiesCommand(tableName: TableIdentifier, propKeys: Seq[String], ifExists: Boolean, isView: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command that unsets table/view properties.

  15. case class AlterViewAsCommand(name: TableIdentifier, originalText: String, query: LogicalPlan) extends LeafNode with RunnableCommand with Product with Serializable

    Alter a view with given query plan.

  16. case class AnalyzeColumnCommand(tableIdent: TableIdentifier, columnNames: Seq[String]) extends LeafNode with RunnableCommand with Product with Serializable

    Analyzes the given columns of the given table to generate statistics, which will be used in query optimizations.

  17. case class AnalyzeTableCommand(tableIdent: TableIdentifier, noscan: Boolean = true) extends LeafNode with RunnableCommand with Product with Serializable

    Analyzes the given table to generate statistics, which will be used in query optimizations.

  18. case class CacheTableCommand(tableIdent: TableIdentifier, plan: Option[LogicalPlan], isLazy: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

  19. case class CreateDataSourceTableAsSelectCommand(table: CatalogTable, mode: SaveMode, query: LogicalPlan) extends LeafNode with RunnableCommand with Product with Serializable

    A command used to create a data source table using the result of a query.

  20. case class CreateDataSourceTableCommand(table: CatalogTable, ignoreIfExists: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command used to create a data source table.

  21. case class CreateDatabaseCommand(databaseName: String, ifNotExists: Boolean, path: Option[String], comment: Option[String], props: Map[String, String]) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to create a new database.

  22. case class CreateFunctionCommand(databaseName: Option[String], functionName: String, className: String, resources: Seq[FunctionResource], isTemp: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    The DDL command that creates a function.

  23. case class CreateTableCommand(table: CatalogTable, ignoreIfExists: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command to create a table.

  24. case class CreateTableLikeCommand(targetTable: TableIdentifier, sourceTable: TableIdentifier, location: Option[String], ifNotExists: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command to create a table with the same definition of the given existing table.

  25. case class CreateViewCommand(name: TableIdentifier, userSpecifiedColumns: Seq[(String, Option[String])], comment: Option[String], properties: Map[String, String], originalText: Option[String], child: LogicalPlan, allowExisting: Boolean, replace: Boolean, viewType: ViewType) extends LeafNode with RunnableCommand with Product with Serializable

    Create or replace a view with given query plan.

  26. case class DescribeDatabaseCommand(databaseName: String, extended: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to show the name of the database, its comment (if one has been set), and its root location on the filesystem.

  27. case class DescribeFunctionCommand(functionName: FunctionIdentifier, isExtended: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to get the usage of a registered function.

  28. case class DescribeTableCommand(table: TableIdentifier, partitionSpec: TablePartitionSpec, isExtended: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    Command that looks like

  29. case class DropDatabaseCommand(databaseName: String, ifExists: Boolean, cascade: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to remove a database from the system.

  30. case class DropFunctionCommand(databaseName: Option[String], functionName: String, ifExists: Boolean, isTemp: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    The DDL command that drops a function.

  31. case class DropTableCommand(tableName: TableIdentifier, ifExists: Boolean, isView: Boolean, purge: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    Drops a table/view from the metastore and removes it if it is cached.

  32. case class ExecutedCommandExec(cmd: RunnableCommand) extends SparkPlan with Product with Serializable

    A physical operator that executes the run method of a RunnableCommand and saves the result to prevent multiple executions.

  33. case class ExplainCommand(logicalPlan: LogicalPlan, extended: Boolean = false, codegen: Boolean = false, cost: Boolean = false) extends LeafNode with RunnableCommand with Product with Serializable

    An explain command for users to see how a command will be executed.

  34. case class ListFilesCommand(files: Seq[String] = collection.this.Seq.empty[String]) extends LeafNode with RunnableCommand with Product with Serializable

    Returns a list of file paths that are added to resources.

  35. case class ListJarsCommand(jars: Seq[String] = collection.this.Seq.empty[String]) extends LeafNode with RunnableCommand with Product with Serializable

    Returns a list of jar files that are added to resources.

  36. case class LoadDataCommand(table: TableIdentifier, path: String, isLocal: Boolean, isOverwrite: Boolean, partition: Option[TablePartitionSpec]) extends LeafNode with RunnableCommand with Product with Serializable

    A command that loads data into a Hive table.

  37. case class PartitionStatistics(numFiles: Int, totalSize: Long) extends Product with Serializable

  38. trait RunnableCommand extends LeafNode with Command

    A logical command that is executed for its side-effects.

  39. case class SetCommand(kv: Option[(String, Option[String])]) extends LeafNode with RunnableCommand with Logging with Product with Serializable

    Command that runs

  40. case class SetDatabaseCommand(databaseName: String) extends LeafNode with RunnableCommand with Product with Serializable

    Command for setting the current database.

  41. case class ShowColumnsCommand(databaseName: Option[String], tableName: TableIdentifier) extends LeafNode with RunnableCommand with Product with Serializable

    A command to list the column names for a table.

  42. case class ShowCreateTableCommand(table: TableIdentifier) extends LeafNode with RunnableCommand with Product with Serializable

  43. case class ShowDatabasesCommand(databasePattern: Option[String]) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to list the databases/schemas.

  44. case class ShowFunctionsCommand(db: Option[String], pattern: Option[String], showUserFunctions: Boolean, showSystemFunctions: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to list all of the registered functions.

  45. case class ShowPartitionsCommand(tableName: TableIdentifier, spec: Option[TablePartitionSpec]) extends LeafNode with RunnableCommand with Product with Serializable

    A command to list the partition names of a table.

  46. case class ShowTablePropertiesCommand(table: TableIdentifier, propertyKey: Option[String]) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to list the properties for a table.

  47. case class ShowTablesCommand(databaseName: Option[String], tableIdentifierPattern: Option[String], isExtended: Boolean = false, partitionSpec: Option[TablePartitionSpec] = scala.None) extends LeafNode with RunnableCommand with Product with Serializable

    A command for users to get tables in the given database.

  48. case class StreamingExplainCommand(queryExecution: IncrementalExecution, extended: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    An explain command for users to see how a streaming batch is executed.

  49. case class TruncateTableCommand(tableName: TableIdentifier, partitionSpec: Option[TablePartitionSpec]) extends LeafNode with RunnableCommand with Product with Serializable

    A command to truncate table.

  50. case class UncacheTableCommand(tableIdent: TableIdentifier, ifExists: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

  51. sealed trait ViewType extends AnyRef

    ViewType is used to specify the expected view type when we want to create or replace a view in CreateViewCommand.

Value Members

  1. object AnalyzeTableCommand extends Logging with Serializable

  2. object ClearCacheCommand extends LeafNode with RunnableCommand with Product with Serializable

    Clear all cached data from the in-memory cache.

  3. object DDLUtils

  4. object GlobalTempView extends ViewType

    GlobalTempView means cross-session global temporary views.

  5. object LocalTempView extends ViewType

    LocalTempView means session-scoped local temporary views.

  6. object PersistedView extends ViewType

    PersistedView means cross-session persisted views.

  7. object ResetCommand extends LeafNode with RunnableCommand with Logging with Product with Serializable

    This command is for resetting SQLConf to the default values.

  8. object SetCommand extends Serializable

  9. object ViewHelper

Ungrouped