Package

org.apache.spark.sql.catalyst

catalog

Permalink

package catalog

Visibility
  1. Public
  2. All

Type Members

  1. case class BucketSpec(numBuckets: Int, bucketColumnNames: Seq[String], sortColumnNames: Seq[String]) extends Product with Serializable

    Permalink

    A container for bucketing information.

    A container for bucketing information. Bucketing is a technology for decomposing data sets into more manageable parts, and the number of buckets is fixed so it does not fluctuate with data.

    numBuckets

    number of buckets.

    bucketColumnNames

    the names of the columns that used to generate the bucket id.

    sortColumnNames

    the names of the columns that used to sort data in each bucket.

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

    Permalink

    A database defined in the catalog.

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

    Permalink

    A function defined in the catalog.

    A function defined in the catalog.

    identifier

    name of the function

    className

    fully qualified class name, e.g. "org.apache.spark.util.MyFunc"

    resources

    resource types and Uris used by the function

  4. case class CatalogStatistics(sizeInBytes: BigInt, rowCount: Option[BigInt] = None, colStats: Map[String, ColumnStat] = Map.empty) extends Product with Serializable

    Permalink

    This class of statistics is used in CatalogTable to interact with metastore.

    This class of statistics is used in CatalogTable to interact with metastore. We define this new class instead of directly using Statistics here because there are no concepts of attributes or broadcast hint in catalog.

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

    Permalink

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

  6. case class CatalogTable(identifier: TableIdentifier, tableType: CatalogTableType, storage: CatalogStorageFormat, schema: StructType, provider: Option[String] = None, partitionColumnNames: Seq[String] = Seq.empty, bucketSpec: Option[BucketSpec] = None, owner: String = "", createTime: Long = System.currentTimeMillis, lastAccessTime: Long = 1, properties: Map[String, String] = Map.empty, stats: Option[CatalogStatistics] = None, viewText: Option[String] = None, comment: Option[String] = None, unsupportedFeatures: Seq[String] = Seq.empty, tracksPartitionsInCatalog: Boolean = false, schemaPreservesCase: Boolean = true) extends Product with Serializable

    Permalink

    A table defined in the catalog.

    A table defined in the catalog.

    Note that Hive's metastore also tracks skewed columns. We should consider adding that in the future once we have a better understanding of how we want to handle skewed columns.

    provider

    the name of the data source provider for this table, e.g. parquet, json, etc. Can be None if this table is a View, should be "hive" for hive serde tables.

    unsupportedFeatures

    is a list of string descriptions of features that are used by the underlying table but not supported by Spark SQL yet.

    tracksPartitionsInCatalog

    whether this table's partition metadata is stored in the catalog. If false, it is inferred automatically based on file structure.

    schemaPreservesCase

    Whether or not the schema resolved for this table is case-sensitive. When using a Hive Metastore, this flag is set to false if a case- sensitive schema was unable to be read from the table properties. Used to trigger case-sensitive schema inference at query time, when configured.

  7. case class CatalogTablePartition(spec: TablePartitionSpec, storage: CatalogStorageFormat, parameters: Map[String, String] = Map.empty) extends Product with Serializable

    Permalink

    A partition (Hive style) defined in the catalog.

    A partition (Hive style) defined in the catalog.

    spec

    partition spec values indexed by column name

    storage

    storage format of the partition

    parameters

    some parameters for the partition, for example, stats.

  8. case class CatalogTableType extends Product with Serializable

    Permalink
  9. case class CreateDatabaseEvent(database: String) extends DatabaseEvent with Product with Serializable

    Permalink

    Event fired after a database has been created.

  10. case class CreateDatabasePreEvent(database: String) extends DatabaseEvent with Product with Serializable

    Permalink

    Event fired before a database is created.

  11. case class CreateFunctionEvent(database: String, name: String) extends FunctionEvent with Product with Serializable

    Permalink

    Event fired after a function has been created.

  12. case class CreateFunctionPreEvent(database: String, name: String) extends FunctionEvent with Product with Serializable

    Permalink

    Event fired before a function is created.

  13. case class CreateTableEvent(database: String, name: String) extends TableEvent with Product with Serializable

    Permalink

    Event fired after a table has been created.

  14. case class CreateTablePreEvent(database: String, name: String) extends TableEvent with Product with Serializable

    Permalink

    Event fired before a table is created.

  15. trait DatabaseEvent extends ExternalCatalogEvent

    Permalink

    Event fired when a database is create or dropped.

  16. case class DropDatabaseEvent(database: String) extends DatabaseEvent with Product with Serializable

    Permalink

    Event fired after a database has been dropped.

  17. case class DropDatabasePreEvent(database: String) extends DatabaseEvent with Product with Serializable

    Permalink

    Event fired before a database is dropped.

  18. case class DropFunctionEvent(database: String, name: String) extends FunctionEvent with Product with Serializable

    Permalink

    Event fired after a function has been dropped.

  19. case class DropFunctionPreEvent(database: String, name: String) extends FunctionEvent with Product with Serializable

    Permalink

    Event fired before a function is dropped.

  20. case class DropTableEvent(database: String, name: String) extends TableEvent with Product with Serializable

    Permalink

    Event fired after a table has been dropped.

  21. case class DropTablePreEvent(database: String, name: String) extends TableEvent with Product with Serializable

    Permalink

    Event fired before a table is dropped.

  22. abstract class ExternalCatalog extends ListenerBus[ExternalCatalogEventListener, ExternalCatalogEvent]

    Permalink

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

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

    This is only used for non-temporary items, and implementations must be thread-safe as they can be accessed in multiple threads. This is an external catalog because it is expected to interact with external systems.

    Implementations should throw NoSuchDatabaseException when databases don't exist.

  23. trait ExternalCatalogEvent extends SparkListenerEvent

    Permalink

    Event emitted by the external catalog when it is modified.

    Event emitted by the external catalog when it is modified. Events are either fired before or after the modification (the event should document this).

  24. trait ExternalCatalogEventListener extends AnyRef

    Permalink

    Listener interface for external catalog modification events.

  25. trait FunctionEvent extends DatabaseEvent

    Permalink

    Event fired when a function is created, dropped or renamed.

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

    Permalink
  27. trait FunctionResourceLoader extends AnyRef

    Permalink

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

    A simple trait representing a class that can be used to load resources used by a function. Because only a SQLContext can load resources, we create this trait to avoid of explicitly passing SQLContext around.

  28. abstract class FunctionResourceType extends AnyRef

    Permalink

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

  29. class GlobalTempViewManager extends AnyRef

    Permalink

    A thread-safe manager for global temporary views, providing atomic operations to manage them, e.g.

    A thread-safe manager for global temporary views, providing atomic operations to manage them, e.g. create, update, remove, etc.

    Note that, the view name is always case-sensitive here, callers are responsible to format the view name w.r.t. case-sensitive config.

  30. case class HiveTableRelation(tableMeta: CatalogTable, dataCols: Seq[AttributeReference], partitionCols: Seq[AttributeReference]) extends LeafNode with MultiInstanceRelation with Product with Serializable

    Permalink

    A LogicalPlan that represents a hive table.

    A LogicalPlan that represents a hive table.

    TODO: remove this after we completely make hive as a data source.

  31. class InMemoryCatalog extends ExternalCatalog

    Permalink

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

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

    This is a dummy implementation that does not require setting up external systems. It is intended for testing or exploration purposes only and should not be used in production.

    All public methods should be synchronized for thread-safety.

  32. case class RenameFunctionEvent(database: String, name: String, newName: String) extends FunctionEvent with Product with Serializable

    Permalink

    Event fired after a function has been renamed.

  33. case class RenameFunctionPreEvent(database: String, name: String, newName: String) extends FunctionEvent with Product with Serializable

    Permalink

    Event fired before a function is renamed.

  34. case class RenameTableEvent(database: String, name: String, newName: String) extends TableEvent with Product with Serializable

    Permalink

    Event fired after a table has been renamed.

  35. case class RenameTablePreEvent(database: String, name: String, newName: String) extends TableEvent with Product with Serializable

    Permalink

    Event fired before a table is renamed.

  36. class SessionCatalog extends Logging

    Permalink

    An internal catalog that is used by a Spark Session.

    An internal catalog that is used by a Spark Session. This internal catalog serves as a proxy to the underlying metastore (e.g. Hive Metastore) and it also manages temporary tables and functions of the Spark Session that it belongs to.

    This class must be thread-safe.

  37. trait TableEvent extends DatabaseEvent

    Permalink

    Event fired when a table is created, dropped or renamed.

  38. case class UnresolvedCatalogRelation(tableMeta: CatalogTable) extends LeafNode with Product with Serializable

    Permalink

    A placeholder for a table relation, which will be replaced by concrete relation like LogicalRelation or HiveTableRelation, during analysis.

Value Members

  1. object ArchiveResource extends FunctionResourceType

    Permalink
  2. object CatalogStorageFormat extends Serializable

    Permalink
  3. object CatalogTable extends Serializable

    Permalink
  4. object CatalogTableType extends Serializable

    Permalink
  5. object CatalogTypes

    Permalink
  6. object CatalogUtils

    Permalink
  7. object DummyFunctionResourceLoader extends FunctionResourceLoader

    Permalink
  8. object ExternalCatalogUtils

    Permalink
  9. object FileResource extends FunctionResourceType

    Permalink
  10. object FunctionResourceType

    Permalink
  11. object JarResource extends FunctionResourceType

    Permalink
  12. object SessionCatalog

    Permalink

Ungrouped