Packages

o

org.apache.spark.sql.pipelines.graph

GraphIdentifierManager

object GraphIdentifierManager

Responsible for properly qualify the identifiers for datasets inside or referenced by the dataflow graph.

Source
GraphIdentifierManager.scala
Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. GraphIdentifierManager
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Type Members

  1. sealed trait DatasetIdentifier extends AnyRef

    Represents the identifier for a dataset that is defined or referenced in a pipeline.

  2. case class ExternalDatasetIdentifier(identifier: TableIdentifier) extends DatasetIdentifier with Product with Serializable

    Represents the identifier for a dataset that is external to the current pipeline.

  3. case class InternalDatasetIdentifier extends DatasetIdentifier with Product with Serializable

    Represents the identifier for a dataset that is defined by the current pipeline.

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
  6. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  7. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  8. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  9. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  10. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  11. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  12. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  13. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  14. def parseAndQualifyFlowIdentifier(rawFlowIdentifier: TableIdentifier, currentCatalog: Option[String], currentDatabase: Option[String]): InternalDatasetIdentifier

    Parses the flow identifier from the raw flow identifier and fully qualify it.

    Parses the flow identifier from the raw flow identifier and fully qualify it.

    rawFlowIdentifier

    the raw flow identifier

    returns

    the parsed flow identifier

    Annotations
    @throws(scala.this.throws.<init>$default$1[org.apache.spark.sql.AnalysisException])
  15. def parseAndQualifyInputIdentifier(context: FlowAnalysisContext, rawInputName: String): DatasetIdentifier

    Fully qualify (if needed) the user-specified identifier used to reference datasets, and categorizing the dataset we're referencing (i.e.

    Fully qualify (if needed) the user-specified identifier used to reference datasets, and categorizing the dataset we're referencing (i.e. dataset from this pipeline or dataset that is external to this pipeline).

    Returns whether the input dataset should be read as a dataset and also the qualified identifier.

    rawInputName

    the user-specified name when referencing datasets.

  16. def parseAndQualifyTableIdentifier(rawTableIdentifier: TableIdentifier, currentCatalog: Option[String], currentDatabase: Option[String]): InternalDatasetIdentifier

    Parses the table identifier from the raw table identifier and fully qualifies it.

    Parses the table identifier from the raw table identifier and fully qualifies it.

    rawTableIdentifier

    the raw table identifier

    returns

    the parsed table identifier

    Annotations
    @throws(scala.this.throws.<init>$default$1[org.apache.spark.sql.AnalysisException])
  17. def parseAndValidatePersistedViewIdentifier(rawViewIdentifier: TableIdentifier, currentCatalog: Option[String], currentDatabase: Option[String]): TableIdentifier

    Parses and validates the view identifier from the raw view identifier for persisted views.

    Parses and validates the view identifier from the raw view identifier for persisted views.

    rawViewIdentifier

    the raw view identifier

    currentCatalog

    the catalog

    currentDatabase

    the schema

    returns

    the parsed view identifier

  18. def parseAndValidateTemporaryViewIdentifier(rawViewIdentifier: TableIdentifier): TableIdentifier

    Parses and validates the view identifier from the raw view identifier for temporary views.

    Parses and validates the view identifier from the raw view identifier for temporary views.

    rawViewIdentifier

    the raw view identifier

    returns

    the parsed view identifier

    Annotations
    @throws(scala.this.throws.<init>$default$1[org.apache.spark.sql.AnalysisException])
  19. def parseTableIdentifier(name: String, spark: classic.SparkSession): TableIdentifier
  20. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  21. def toString(): String
    Definition Classes
    AnyRef → Any
  22. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  23. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  24. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

Inherited from AnyRef

Inherited from Any

Ungrouped