Class

org.apache.spark.sql.execution.columnar.encoding

ColumnDecoder

Related Doc: package encoding

Permalink

abstract class ColumnDecoder extends ColumnEncoding

Linear Supertypes
ColumnEncoding, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ColumnDecoder
  2. ColumnEncoding
  3. AnyRef
  4. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ColumnDecoder()

    Permalink

Abstract Value Members

  1. abstract def hasNulls: Boolean

    Permalink
    Attributes
    protected[org.apache.spark.sql]
  2. abstract def initializeCursor(columnBytes: AnyRef, cursor: Long, field: StructField): Long

    Permalink
    Attributes
    protected[org.apache.spark.sql]
  3. abstract def initializeNulls(columnBytes: AnyRef, cursor: Long, field: StructField): Long

    Permalink
    Attributes
    protected[org.apache.spark.sql]
  4. abstract def isNull(columnBytes: AnyRef, ordinal: Int): Boolean

    Permalink

    Sequential null check for a value which should be invoked for all values of ordinal from 0 until maximum in order.

  5. abstract def supports(dataType: DataType): Boolean

    Permalink
    Definition Classes
    ColumnEncoding
  6. abstract def typeId: Int

    Permalink
    Definition Classes
    ColumnEncoding

Concrete 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. def absoluteArray(columnBytes: AnyRef, position: Int): Long

    Permalink
  5. def absoluteBinary(columnBytes: AnyRef, position: Int): Long

    Permalink
  6. def absoluteBoolean(columnBytes: AnyRef, position: Int): Long

    Permalink

    Random access to the encoded data.

  7. def absoluteByte(columnBytes: AnyRef, position: Int): Long

    Permalink
  8. def absoluteDate(columnBytes: AnyRef, position: Int): Long

    Permalink
  9. def absoluteDecimal(columnBytes: AnyRef, position: Int): Long

    Permalink
  10. def absoluteDouble(columnBytes: AnyRef, position: Int): Long

    Permalink
  11. def absoluteFloat(columnBytes: AnyRef, position: Int): Long

    Permalink
  12. def absoluteInt(columnBytes: AnyRef, position: Int): Long

    Permalink
  13. def absoluteInterval(columnBytes: AnyRef, position: Int): Long

    Permalink
  14. def absoluteLong(columnBytes: AnyRef, position: Int): Long

    Permalink
  15. def absoluteLongDecimal(columnBytes: AnyRef, position: Int): Long

    Permalink
  16. def absoluteMap(columnBytes: AnyRef, position: Int): Long

    Permalink
  17. def absoluteShort(columnBytes: AnyRef, position: Int): Long

    Permalink
  18. def absoluteStruct(columnBytes: AnyRef, position: Int): Long

    Permalink
  19. def absoluteTimestamp(columnBytes: AnyRef, position: Int): Long

    Permalink
  20. def absoluteUTF8String(columnBytes: AnyRef, position: Int): Long

    Permalink
  21. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  22. final var baseCursor: Long

    Permalink
    Attributes
    protected
  23. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  24. final var currentCursor: Long

    Permalink

    Normally not used by decoder but supplied by caller to the methods but can be used if required but needs to be set by caller explicitly.

  25. final def eq(arg0: AnyRef): Boolean

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

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  29. def getStringDictionary: StringDictionary

    Permalink
  30. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  31. final def initialize(columnBytes: AnyRef, cursor: Long, field: StructField): Long

    Permalink

    Delta encoder/decoder depend on initialize being final and invoking initializeCursor and initializeNulls as below.

  32. final def initialize(buffer: ByteBuffer, field: StructField): Long

    Permalink
  33. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  34. def isNullAt(columnBytes: AnyRef, position: Int): Boolean

    Permalink

    Absolute ordinal null check for random access.

  35. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  36. def nextArray(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  37. def nextBinary(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  38. def nextBoolean(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  39. def nextByte(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  40. def nextDecimal(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  41. def nextDouble(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  42. def nextFloat(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  43. def nextInt(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  44. def nextInterval(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  45. def nextLong(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  46. def nextLongDecimal(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  47. def nextMap(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  48. def nextShort(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  49. def nextStruct(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  50. def nextUTF8String(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  51. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  53. def numNullsUntilPosition(columnBytes: AnyRef, position: Int): Int

    Permalink

    Get the number of null values till given 0-based position (exclusive) for random access.

    Get the number of null values till given 0-based position (exclusive) for random access.

    Attributes
    protected
  54. def readArray(columnBytes: AnyRef, cursor: Long): ArrayData

    Permalink
  55. def readBinary(columnBytes: AnyRef, cursor: Long): Array[Byte]

    Permalink
  56. def readBoolean(columnBytes: AnyRef, cursor: Long): Boolean

    Permalink
  57. def readByte(columnBytes: AnyRef, cursor: Long): Byte

    Permalink
  58. def readDate(columnBytes: AnyRef, cursor: Long): Int

    Permalink
  59. def readDecimal(columnBytes: AnyRef, precision: Int, scale: Int, cursor: Long): Decimal

    Permalink
  60. def readDictionaryIndex(columnBytes: AnyRef, cursor: Long): Int

    Permalink
  61. def readDouble(columnBytes: AnyRef, cursor: Long): Double

    Permalink
  62. def readFloat(columnBytes: AnyRef, cursor: Long): Float

    Permalink
  63. def readInt(columnBytes: AnyRef, cursor: Long): Int

    Permalink
  64. def readInterval(columnBytes: AnyRef, cursor: Long): CalendarInterval

    Permalink
  65. def readLong(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  66. def readLongDecimal(columnBytes: AnyRef, precision: Int, scale: Int, cursor: Long): Decimal

    Permalink
  67. def readMap(columnBytes: AnyRef, cursor: Long): MapData

    Permalink
  68. def readShort(columnBytes: AnyRef, cursor: Long): Short

    Permalink
  69. def readStruct(columnBytes: AnyRef, numFields: Int, cursor: Long): InternalRow

    Permalink
  70. def readTimestamp(columnBytes: AnyRef, cursor: Long): Long

    Permalink
  71. def readUTF8String(columnBytes: AnyRef, cursor: Long): UTF8String

    Permalink
  72. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  73. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  74. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from ColumnEncoding

Inherited from AnyRef

Inherited from Any

Ungrouped