Object/Class

org.apache.spark.sql.execution.columnar.impl

ColumnDelta

Related Docs: class ColumnDelta | package impl

Permalink

object ColumnDelta extends Enumeration with Logging

Linear Supertypes
Logging, Enumeration, Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ColumnDelta
  2. Logging
  3. Enumeration
  4. Serializable
  5. Serializable
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. final class MutableColumn extends Val

    Permalink

    Extension to standard enumeration value to hold the StructField.

    Extension to standard enumeration value to hold the StructField. Also exposes the name as "name" field rather than having to use toString.

  2. type Type = MutableColumn

    Permalink
  3. class Val extends Value with Serializable

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
    Annotations
    @SerialVersionUID()
  4. abstract class Value extends Ordered[Value] with Serializable

    Permalink
    Definition Classes
    Enumeration
    Annotations
    @SerialVersionUID()
  5. class ValueSet extends AbstractSet[Value] with SortedSet[Value] with SortedSetLike[Value, ValueSet] with Serializable

    Permalink
    Definition Classes
    Enumeration

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. val BatchId: Type

    Permalink
  5. val BatchNumRows: Type

    Permalink
  6. val BucketId: Type

    Permalink
  7. val INIT_SIZE: Int

    Permalink

    The initial size of delta column (the smallest delta in the hierarchy).

  8. val MAX_DEPTH: Int

    Permalink

    The maximum depth of the hierarchy of deltas for column starting with smallest delta, which is merged with larger delta, then larger, ...

    The maximum depth of the hierarchy of deltas for column starting with smallest delta, which is merged with larger delta, then larger, ... till the full column value.

    As of now only one-level of depth is used and deltas always merged immediately.

  9. val RowOrdinal: Type

    Permalink

    These enumeration values are the virtual columns that are injected in the select plan for update/delete so that those operations can actually apply the changes.

  10. val USED_MAX_DEPTH: Int

    Permalink

    This is the currently used maximum depth which must be <= MAX_DEPTH.

    This is the currently used maximum depth which must be <= MAX_DEPTH. It should only be used by transient execution-time structures and never in storage.

  11. final def Value(i: Int, name: String): Value

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  12. final def Value(name: String): Value

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  13. final def Value(i: Int): Value

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  14. final def Value: Value

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  15. object ValueSet extends Serializable

    Permalink
    Definition Classes
    Enumeration
  16. final def apply(x: Int): Value

    Permalink
    Definition Classes
    Enumeration
  17. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  18. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  19. def deltaColumnIndex(tableColumnIndex: Int, hierarchyDepth: Int): Int

    Permalink

    Returns the delta column index as store in region key given the 0 based table column index (table column index stored in region key is 1 based).

  20. def deltaHierarchyDepth(deltaColumnIndex: Int): Int

    Permalink
  21. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  22. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  23. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  24. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  25. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  26. def initializeLogIfNecessary(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  27. final def isDebugEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  28. final def isInfoEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  29. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  30. final def isTraceEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  31. final var levelFlags: Int

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  32. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  33. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Definition Classes
    Logging
  34. def logDebug(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  35. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Definition Classes
    Logging
  36. def logError(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  37. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Definition Classes
    Logging
  38. def logInfo(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  39. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  40. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Definition Classes
    Logging
  41. def logTrace(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  42. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Definition Classes
    Logging
  43. def logWarning(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  44. final var log_: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  45. final def maxId: Int

    Permalink
    Definition Classes
    Enumeration
  46. def mutableKeyAttributes: Seq[AttributeReference]

    Permalink
  47. val mutableKeyFields: IndexedSeq[StructField]

    Permalink
  48. val mutableKeyMap: Map[String, Type]

    Permalink
  49. val mutableKeyNamePrefix: String

    Permalink
  50. val mutableKeyNames: IndexedSeq[String]

    Permalink
  51. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  52. var nextId: Int

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  53. var nextName: Iterator[String]

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  54. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  55. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  56. def readResolve(): AnyRef

    Permalink
    Attributes
    protected
    Definition Classes
    Enumeration
  57. def resetLogger(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  58. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  59. def tableColumnIndex(deltaColumnIndex: Int): Int

    Permalink

    Returns 1 based table column index for given delta or table column index (table column index stored in region key is 1 based).

  60. def toString(): String

    Permalink
    Definition Classes
    Enumeration → AnyRef → Any
  61. def values: ValueSet

    Permalink
    Definition Classes
    Enumeration
  62. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  63. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  64. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  65. final def withName(s: String): Value

    Permalink
    Definition Classes
    Enumeration

Inherited from Logging

Inherited from Enumeration

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped