Class/Object

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

ColumnEncoding

Related Docs: object ColumnEncoding | package encoding

Permalink

abstract class ColumnEncoding extends AnyRef

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

Instance Constructors

  1. new ColumnEncoding()

    Permalink

Abstract Value Members

  1. abstract def initializeNulls(columnBytes: AnyRef, field: Attribute): Long

    Permalink
    Attributes
    protected
  2. abstract def notNull(columnBytes: AnyRef, ordinal: Int): Int

    Permalink

    Returns 1 to indicate that column value was not-null, 0 to indicate that it was null and -1 to indicate that wasNull() needs to be invoked after the appropriate read method.

    Returns 1 to indicate that column value was not-null, 0 to indicate that it was null and -1 to indicate that wasNull() needs to be invoked after the appropriate read method.

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

    Permalink
  4. abstract def typeId: Int

    Permalink

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. final def asInstanceOf[T0]: T0

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  6. final def eq(arg0: AnyRef): Boolean

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

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

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  11. def initializeDecoding(columnBytes: AnyRef, field: Attribute): Long

    Permalink
  12. def initializeEncoding(dataType: DataType, batchSize: Int): AnyRef

    Permalink
  13. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  14. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  15. def nextBinary(columnBytes: AnyRef, cursor: Long): Long

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

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

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

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

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

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

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

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

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

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

    Permalink
  26. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  28. def readArray(columnBytes: AnyRef, cursor: Long): UnsafeArrayData

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

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
  42. def readStruct(columnBytes: AnyRef, numFields: Int, cursor: Long): UnsafeRow

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  50. def wasNull(): Boolean

    Permalink

    Only to be used for implementations (ResultSet adapter) that need to check for null after having invoked the appropriate read method.

    Only to be used for implementations (ResultSet adapter) that need to check for null after having invoked the appropriate read method. The notNull method should return -1 for such implementations.

  51. def writeArray(columnBytes: AnyRef, value: UnsafeArrayData): Unit

    Permalink
  52. def writeBinary(columnBytes: AnyRef, value: Array[Byte]): Unit

    Permalink
  53. def writeBoolean(columnBytes: AnyRef, value: Boolean): Unit

    Permalink
  54. def writeByte(columnBytes: AnyRef, value: Byte): Unit

    Permalink
  55. def writeDecimal(columnBytes: AnyRef, value: Decimal, precision: Int): Unit

    Permalink
  56. def writeDouble(columnBytes: AnyRef, value: Double): Unit

    Permalink
  57. def writeFloat(columnBytes: AnyRef, value: Float): Unit

    Permalink
  58. def writeInt(columnBytes: AnyRef, value: Int): Unit

    Permalink
  59. def writeInterval(columnBytes: AnyRef, value: CalendarInterval): Unit

    Permalink
  60. def writeLong(columnBytes: AnyRef, value: Long): Unit

    Permalink
  61. def writeLongDecimal(columnBytes: AnyRef, value: Decimal, precision: Int): Unit

    Permalink
  62. def writeMap(columnBytes: AnyRef, value: UnsafeMapData): Unit

    Permalink
  63. def writeShort(columnBytes: AnyRef, value: Short): Unit

    Permalink
  64. def writeStruct(columnBytes: AnyRef, value: UnsafeRow): Unit

    Permalink
  65. def writeUTF8String(columnBytes: AnyRef, value: UTF8String): Unit

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped