org.apache.spark.sql.execution

command

package command

Visibility
  1. Public
  2. All

Type Members

  1. case class AddFileCommand(path: String) extends LogicalPlan 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 LogicalPlan 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 LogicalPlan 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 AlterTableAddPartitionCommand(tableName: TableIdentifier, partitionSpecsAndLocs: Seq[(TablePartitionSpec, Option[String])], ifNotExists: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

    Add Partition in ALTER TABLE: add the table partitions.

  5. case class AlterTableDropPartitionCommand(tableName: TableIdentifier, specs: Seq[TablePartitionSpec], ifExists: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

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

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

    A command that renames a table/view.

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

    Alter a table partition's spec.

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

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

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

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

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

    A command that sets table/view properties.

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

    A command that unsets table/view properties.

  12. case class AnalyzeTableCommand(tableName: String) extends LogicalPlan with RunnableCommand with Product with Serializable

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

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

  14. case class CreateDataSourceTableAsSelectCommand(tableIdent: TableIdentifier, provider: String, partitionColumns: Array[String], bucketSpec: Option[BucketSpec], mode: SaveMode, options: Map[String, String], query: LogicalPlan) extends LogicalPlan with RunnableCommand with Product with Serializable

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

  15. case class CreateDataSourceTableCommand(tableIdent: TableIdentifier, userSpecifiedSchema: Option[StructType], provider: String, options: Map[String, String], partitionColumns: Array[String], bucketSpec: Option[BucketSpec], ignoreIfExists: Boolean, managedIfNoPath: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

    A command used to create a data source table.

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

    A command for users to create a new database.

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

    The DDL command that creates a function.

  18. case class CreateHiveTableAsSelectLogicalPlan(tableDesc: CatalogTable, child: LogicalPlan, allowExisting: Boolean) extends UnaryNode with Command with Product with Serializable

  19. case class CreateTableCommand(table: CatalogTable, ifNotExists: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

    A command to create a table.

  20. case class CreateTableLikeCommand(targetTable: TableIdentifier, sourceTable: TableIdentifier, ifNotExists: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

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

  21. case class CreateViewCommand(tableDesc: CatalogTable, child: LogicalPlan, allowExisting: Boolean, replace: Boolean, isTemporary: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

    Create Hive view on non-hive-compatible tables by specifying schema ourselves instead of depending on Hive meta-store.

  22. case class DescribeDatabaseCommand(databaseName: String, extended: Boolean) extends LogicalPlan 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.

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

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

  24. case class DescribeTableCommand(table: TableIdentifier, isExtended: Boolean, isFormatted: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

    Command that looks like

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

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

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

    The DDL command that drops a function.

  27. case class DropTableCommand(tableName: TableIdentifier, ifExists: Boolean, isView: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable

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

  28. case class ExplainCommand(logicalPlan: LogicalPlan, output: Seq[Attribute] = ..., extended: Boolean = false, codegen: Boolean = false) extends LogicalPlan with RunnableCommand with Product with Serializable

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

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

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

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

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

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

    A command that loads data into a Hive table.

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

    Command that runs

  33. case class SetDatabaseCommand(databaseName: String) extends LogicalPlan with RunnableCommand with Product with Serializable

    Command for setting the current database.

  34. case class ShowColumnsCommand(table: TableIdentifier) extends LogicalPlan with RunnableCommand with Product with Serializable

    A command to list the column names for a table.

  35. case class ShowCreateTableCommand(table: TableIdentifier) extends LogicalPlan with RunnableCommand with Product with Serializable

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

    A command for users to list the databases/schemas.

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

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

  38. case class ShowPartitionsCommand(table: TableIdentifier, spec: Option[TablePartitionSpec]) extends LogicalPlan with RunnableCommand with Product with Serializable

    A command to list the partition names of a table.

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

    A command for users to list the properties for a table If propertyKey is specified, the value for the propertyKey is returned.

  40. case class ShowTablesCommand(databaseName: Option[String], tableIdentifierPattern: Option[String]) extends LogicalPlan with RunnableCommand with Product with Serializable

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

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

    A command to truncate table.

  42. case class UncacheTableCommand(tableIdent: TableIdentifier) extends LogicalPlan with RunnableCommand with Product with Serializable

Value Members

  1. object AnalyzeTableCommand extends Serializable

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

    Clear all cached data from the in-memory cache.

  3. object CreateDataSourceTableUtils extends Logging

  4. object DDLUtils

  5. object ResetCommand extends LogicalPlan with RunnableCommand with Logging with Product with Serializable

    This command is for resetting SQLConf to the default values.

Ungrouped