org.apache.spark.sql.catalyst

catalog

package catalog

Visibility
  1. Public
  2. All

Type Members

  1. case class CatalogColumn(name: String, dataType: String, nullable: Boolean = true, comment: Option[String] = scala.None) extends Product with Serializable

    A column in a table.

  2. case class CatalogDatabase(name: String, description: String, locationUri: String, properties: Map[String, String]) extends Product with Serializable

    A database defined in the catalog.

  3. case class CatalogFunction(identifier: FunctionIdentifier, className: String, resources: Seq[FunctionResource]) extends Product with Serializable

    A function defined in the catalog.

  4. trait CatalogRelation extends AnyRef

    An interface that is implemented by logical plans to return the underlying catalog table.

  5. case class CatalogStorageFormat(locationUri: Option[String], inputFormat: Option[String], outputFormat: Option[String], serde: Option[String], compressed: Boolean, serdeProperties: Map[String, String]) extends Product with Serializable

    Storage format, used to describe how a partition or a table is stored.

  6. case class CatalogTable(identifier: TableIdentifier, tableType: CatalogTableType, storage: CatalogStorageFormat, schema: Seq[CatalogColumn], partitionColumnNames: Seq[String] = collection.this.Seq.empty[Nothing], sortColumnNames: Seq[String] = collection.this.Seq.empty[Nothing], bucketColumnNames: Seq[String] = collection.this.Seq.empty[Nothing], numBuckets: Int = -1, owner: String = "", createTime: Long = ..., lastAccessTime: Long = -1, properties: Map[String, String] = ..., viewOriginalText: Option[String] = scala.None, viewText: Option[String] = scala.None, comment: Option[String] = scala.None, unsupportedFeatures: Seq[String] = collection.this.Seq.empty[Nothing]) extends Product with Serializable

    A table defined in the catalog.

  7. case class CatalogTablePartition(spec: TablePartitionSpec, storage: CatalogStorageFormat) extends Product with Serializable

    A partition (Hive style) defined in the catalog.

  8. case class CatalogTableType extends Product with Serializable

  9. abstract class ExternalCatalog extends AnyRef

    Interface for the system catalog (of columns, partitions, tables, and databases).

  10. case class FunctionResource(resourceType: FunctionResourceType, uri: String) extends Product with Serializable

  11. trait FunctionResourceLoader extends AnyRef

    A simple trait representing a class that can be used to load resources used by a function.

  12. abstract class FunctionResourceType extends AnyRef

    A trait that represents the type of a resourced needed by a function.

  13. class InMemoryCatalog extends ExternalCatalog

    An in-memory (ephemeral) implementation of the system catalog.

  14. class SessionCatalog extends Logging

    An internal catalog that is used by a Spark Session.

  15. case class SimpleCatalogRelation(databaseName: String, metadata: CatalogTable, alias: Option[String] = scala.None) extends LeafNode with CatalogRelation with Product with Serializable

    A LogicalPlan that wraps CatalogTable.

Value Members

  1. object ArchiveResource extends FunctionResourceType

  2. object CatalogStorageFormat extends Serializable

  3. object CatalogTableType extends Serializable

  4. object CatalogTypes

  5. object DummyFunctionResourceLoader extends FunctionResourceLoader

  6. object FileResource extends FunctionResourceType

  7. object FunctionResourceType

  8. object JarResource extends FunctionResourceType

  9. object SessionCatalog

Ungrouped