Package

org.apache.spark.sql

delta

Permalink

package delta

Visibility
  1. Public
  2. All

Type Members

  1. case class CheckpointInstance(version: Long, numParts: Option[Int]) extends Ordered[CheckpointInstance] with Product with Serializable

    Permalink

    A class to help with comparing checkpoints with each other, where we may have had concurrent writers that checkpoint with different number of parts.

  2. case class CheckpointMetaData(version: Long, size: Long, parts: Option[Int]) extends Product with Serializable

    Permalink

    Records information about a checkpoint.

    Records information about a checkpoint.

    version

    the version of this checkpoint

    size

    the number of actions in the checkpoint

    parts

    the number of parts when the checkpoint has multiple parts. None if this is a singular checkpoint

  3. trait Checkpoints extends DeltaLogging

    Permalink
  4. case class CommitStats(startVersion: Long, commitVersion: Long, readVersion: Long, txnDurationMs: Long, commitDurationMs: Long, numAdd: Int, numRemove: Int, bytesNew: Long, numFilesTotal: Long, sizeInBytesTotal: Long, protocol: Protocol, info: CommitInfo, newMetadata: Option[Metadata], numAbsolutePathsInAdd: Int, numDistinctPartitionsInAdd: Int, isolationLevel: String) extends Product with Serializable

    Permalink

    Record metrics about a successful commit.

  5. class ConcurrentAppendException extends DeltaConcurrentModificationException

    Permalink

    Thrown when files are added that would have been read by the current transaction.

  6. class ConcurrentDeleteDeleteException extends DeltaConcurrentModificationException

    Permalink

    Thrown when the current transaction deletes data that was deleted by a concurrent transaction.

  7. class ConcurrentDeleteReadException extends DeltaConcurrentModificationException

    Permalink

    Thrown when the current transaction reads data that was deleted by a concurrent transaction.

  8. class ConcurrentTransactionException extends DeltaConcurrentModificationException

    Permalink

    Thrown when concurrent transaction both attempt to update the same idempotent transaction.

  9. class ConcurrentWriteException extends DeltaConcurrentModificationException

    Permalink

    Thrown when a concurrent transaction has written data after the current transaction read the table.

  10. abstract class DeltaConcurrentModificationException extends ConcurrentModificationException

    Permalink

    The basic class for all Tahoe commit conflict exceptions.

  11. case class DeltaConfig[T](key: String, defaultValue: String, fromString: (String) ⇒ T, validationFunction: (T) ⇒ Boolean, helpMessage: String, minimumProtocolVersion: Option[Protocol] = None) extends Product with Serializable

    Permalink
  12. trait DeltaFileFormat extends AnyRef

    Permalink
  13. class DeltaHistoryManager extends DeltaLogging

    Permalink

    This class keeps tracks of the version of commits and their timestamps for a Delta table to help with operations like describing the history of a table.

  14. class DeltaLog extends Checkpoints with MetadataCleanup with LogStoreProvider with VerifyChecksum

    Permalink

    Used to query the current state of the log as well as modify it by adding new atomic collections of actions.

    Used to query the current state of the log as well as modify it by adding new atomic collections of actions.

    Internally, this class implements an optimistic concurrency control algorithm to handle multiple readers or writers. Any single read is guaranteed to see a consistent snapshot of the table.

  15. trait DeltaOptionParser extends AnyRef

    Permalink
  16. class DeltaOptions extends DeltaWriteOptions with DeltaReadOptions with Serializable

    Permalink

    Options for the Delta data source.

  17. trait DeltaReadOptions extends DeltaOptionParser

    Permalink
  18. case class DeltaTableIdentifier(path: Option[String] = None, table: Option[TableIdentifier] = None) extends Product with Serializable

    Permalink

    An identifier for a Delta table containing one of the path or the table identifier.

  19. case class DeltaTimeTravelSpec(timestamp: Option[Expression], version: Option[Long], creationSource: Option[String]) extends Product with Serializable

    Permalink

    The specification to time travel a Delta Table to the given timestamp or version.

    The specification to time travel a Delta Table to the given timestamp or version.

    timestamp

    An expression that can be evaluated into a timestamp. The expression cannot be a subquery.

    version

    The version of the table to time travel to. Must be >= 0.

    creationSource

    The API used to perform time travel, e.g. atSyntax, dfReader or SQL

  20. trait DeltaWriteOptions extends DeltaWriteOptionsImpl with DeltaOptionParser

    Permalink
  21. trait DeltaWriteOptionsImpl extends DeltaOptionParser

    Permalink
  22. trait DocsPath extends AnyRef

    Permalink
  23. class InitialSnapshot extends Snapshot

    Permalink

    An initial snapshot with only metadata specified.

    An initial snapshot with only metadata specified. Useful for creating a DataFrame from an existing parquet table during its conversion to delta.

  24. class MetadataChangedException extends DeltaConcurrentModificationException

    Permalink

    Thrown when the metadata of the Delta table has changed between the time of read and the time of commit.

  25. trait MetadataCleanup extends DeltaLogging

    Permalink

    Cleans up expired Delta table metadata.

  26. class MetadataMismatchErrorBuilder extends AnyRef

    Permalink

    A helper class in building a helpful error message in case of metadata mismatches.

  27. class OptimisticTransaction extends OptimisticTransactionImpl with DeltaLogging

    Permalink

    Used to perform a set of reads in a transaction and then commit a set of updates to the state of the log.

    Used to perform a set of reads in a transaction and then commit a set of updates to the state of the log. All reads from the DeltaLog, MUST go through this instance rather than directly to the DeltaLog otherwise they will not be check for logical conflicts with concurrent updates.

    This class is not thread-safe.

  28. trait OptimisticTransactionImpl extends TransactionalWrite

    Permalink

    Used to perform a set of reads in a transaction and then commit a set of updates to the state of the log.

    Used to perform a set of reads in a transaction and then commit a set of updates to the state of the log. All reads from the DeltaLog, MUST go through this instance rather than directly to the DeltaLog otherwise they will not be check for logical conflicts with concurrent updates.

    This trait is not thread-safe.

  29. trait PartitionFiltering extends AnyRef

    Permalink
  30. case class PreprocessTableMerge(conf: SQLConf) extends UpdateExpressionsSupport with Product with Serializable

    Permalink
  31. case class PreprocessTableUpdate(conf: SQLConf) extends UpdateExpressionsSupport with Product with Serializable

    Permalink
  32. class ProtocolChangedException extends DeltaConcurrentModificationException

    Permalink

    Thrown when the protocol version has changed between the time of read and the time of commit.

  33. trait RecordChecksum extends DeltaLogging

    Permalink

    Record the state of the table as a checksum file along with a commit.

  34. class Snapshot extends StateCache with PartitionFiltering with DeltaFileFormat with DeltaLogging

    Permalink

    An immutable snapshot of the state of the log at some delta version.

    An immutable snapshot of the state of the log at some delta version. Internally this class manages the replay of actions stored in checkpoint or delta files, given an optional starting snapshot.

    After resolving any new actions, it caches the result and collects the following basic information to the driver:

    • Protocol Version
    • Metadata
    • Transaction state
  35. trait UpdateExpressionsSupport extends CastSupport

    Permalink

    Trait with helper functions to generate expressions to update target columns, even if they are nested fields.

  36. trait VerifyChecksum extends DeltaLogging

    Permalink

    Verify the state of the table using the checksum files.

  37. case class VersionChecksum(tableSizeBytes: Long, numFiles: Long, numMetadata: Long, numProtocol: Long, numTransactions: Long) extends Product with Serializable

    Permalink

    Stats calculated within a snapshot, which we store along individual transactions for verification.

    Stats calculated within a snapshot, which we store along individual transactions for verification.

    tableSizeBytes

    The size of the table in bytes

    numFiles

    Number of AddFile actions in the snapshot

    numMetadata

    Number of Metadata actions in the snapshot

    numProtocol

    Number of Protocol actions in the snapshot

    numTransactions

    Number of SetTransaction actions in the snapshot

Value Members

  1. object CheckpointInstance extends Serializable

    Permalink
  2. object Checkpoints

    Permalink
  3. object DeltaConfigs extends DeltaLogging

    Permalink

    Contains list of reservoir configs and validation checks.

  4. object DeltaErrors extends DocsPath with DeltaLogging

    Permalink

    A holder object for Delta errors.

  5. object DeltaFullTable

    Permalink

    Extractor Object for pulling out the full table scan of a Delta table.

  6. object DeltaHistoryManager extends DeltaLogging

    Permalink

    Contains many utility methods that can also be executed on Spark executors.

  7. object DeltaLog extends DeltaLogging

    Permalink
  8. object DeltaOperations

    Permalink

    Exhaustive list of operations that can be performed on a Delta table.

    Exhaustive list of operations that can be performed on a Delta table. These operations are tracked as the first line in delta logs, and power DESCRIBE HISTORY for Delta tables.

  9. object DeltaOptions extends DeltaLogging with Serializable

    Permalink
  10. object DeltaTable

    Permalink

    Extractor Object for pulling out the table scan of a Delta table.

    Extractor Object for pulling out the table scan of a Delta table. It could be a full scan or a partial scan.

  11. object DeltaTableIdentifier extends Serializable

    Permalink

    Utilities for DeltaTableIdentifier.

  12. object DeltaTableUtils extends PredicateHelper with DeltaLogging

    Permalink
  13. object DeltaTimeTravelSpec extends Serializable

    Permalink
  14. object OptimisticTransaction

    Permalink
  15. object Snapshot extends DeltaLogging

    Permalink
  16. package actions

    Permalink
  17. package commands

    Permalink
  18. package files

    Permalink
  19. package metering

    Permalink
  20. package schema

    Permalink
  21. package sources

    Permalink
  22. package stats

    Permalink
  23. package storage

    Permalink
  24. package util

    Permalink

Ungrouped