Class

org.apache.spark.sql.execution.vectorized

ColumnVector

Related Doc: package vectorized

Permalink

abstract class ColumnVector extends AutoCloseable

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

Instance Constructors

  1. new ColumnVector(capacity: Int, type: DataType, memMode: MemoryMode)

    Permalink

Abstract Value Members

  1. abstract def close(): Unit

    Permalink
    Definition Classes
    ColumnVector → AutoCloseable
  2. abstract def getArrayLength(rowId: Int): Int

    Permalink
  3. abstract def getArrayOffset(rowId: Int): Int

    Permalink
  4. abstract def getBoolean(rowId: Int): Boolean

    Permalink
  5. abstract def getByte(rowId: Int): Byte

    Permalink
  6. abstract def getDictId(rowId: Int): Int

    Permalink
  7. abstract def getDouble(rowId: Int): Double

    Permalink
  8. abstract def getFloat(rowId: Int): Float

    Permalink
  9. abstract def getInt(rowId: Int): Int

    Permalink
  10. abstract def getLong(rowId: Int): Long

    Permalink
  11. abstract def getShort(rowId: Int): Short

    Permalink
  12. abstract def isNullAt(rowId: Int): Boolean

    Permalink
  13. abstract def loadBytes(array: Array): Unit

    Permalink
  14. abstract def nullsNativeAddress(): Long

    Permalink
  15. abstract def putArray(rowId: Int, offset: Int, length: Int): Unit

    Permalink
  16. abstract def putBoolean(rowId: Int, value: Boolean): Unit

    Permalink
  17. abstract def putBooleans(rowId: Int, count: Int, value: Boolean): Unit

    Permalink
  18. abstract def putByte(rowId: Int, value: Byte): Unit

    Permalink
  19. abstract def putByteArray(rowId: Int, value: Array[Byte], offset: Int, count: Int): Int

    Permalink
  20. abstract def putBytes(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit

    Permalink
  21. abstract def putBytes(rowId: Int, count: Int, value: Byte): Unit

    Permalink
  22. abstract def putDouble(rowId: Int, value: Double): Unit

    Permalink
  23. abstract def putDoubles(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit

    Permalink
  24. abstract def putDoubles(rowId: Int, count: Int, src: Array[Double], srcIndex: Int): Unit

    Permalink
  25. abstract def putDoubles(rowId: Int, count: Int, value: Double): Unit

    Permalink
  26. abstract def putFloat(rowId: Int, value: Float): Unit

    Permalink
  27. abstract def putFloats(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit

    Permalink
  28. abstract def putFloats(rowId: Int, count: Int, src: Array[Float], srcIndex: Int): Unit

    Permalink
  29. abstract def putFloats(rowId: Int, count: Int, value: Float): Unit

    Permalink
  30. abstract def putInt(rowId: Int, value: Int): Unit

    Permalink
  31. abstract def putInts(rowId: Int, count: Int, src: Array[Int], srcIndex: Int): Unit

    Permalink
  32. abstract def putInts(rowId: Int, count: Int, value: Int): Unit

    Permalink
  33. abstract def putIntsLittleEndian(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit

    Permalink
  34. abstract def putLong(rowId: Int, value: Long): Unit

    Permalink
  35. abstract def putLongs(rowId: Int, count: Int, src: Array[Long], srcIndex: Int): Unit

    Permalink
  36. abstract def putLongs(rowId: Int, count: Int, value: Long): Unit

    Permalink
  37. abstract def putLongsLittleEndian(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit

    Permalink
  38. abstract def putNotNull(rowId: Int): Unit

    Permalink
  39. abstract def putNotNulls(rowId: Int, count: Int): Unit

    Permalink
  40. abstract def putNull(rowId: Int): Unit

    Permalink
  41. abstract def putNulls(rowId: Int, count: Int): Unit

    Permalink
  42. abstract def putShort(rowId: Int, value: Short): Unit

    Permalink
  43. abstract def putShorts(rowId: Int, count: Int, src: Array[Short], srcIndex: Int): Unit

    Permalink
  44. abstract def putShorts(rowId: Int, count: Int, value: Short): Unit

    Permalink
  45. abstract def reserveInternal(capacity: Int): Unit

    Permalink
  46. abstract def valuesNativeAddress(): Long

    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 anyNullsSet(): Boolean

    Permalink
  5. final def appendArray(length: Int): Int

    Permalink
  6. final def appendBoolean(v: Boolean): Int

    Permalink
  7. final def appendBooleans(count: Int, v: Boolean): Int

    Permalink
  8. final def appendByte(v: Byte): Int

    Permalink
  9. final def appendByteArray(value: Array[Byte], offset: Int, length: Int): Int

    Permalink
  10. final def appendBytes(length: Int, src: Array[Byte], offset: Int): Int

    Permalink
  11. final def appendBytes(count: Int, v: Byte): Int

    Permalink
  12. final def appendDouble(v: Double): Int

    Permalink
  13. final def appendDoubles(length: Int, src: Array[Double], offset: Int): Int

    Permalink
  14. final def appendDoubles(count: Int, v: Double): Int

    Permalink
  15. final def appendFloat(v: Float): Int

    Permalink
  16. final def appendFloats(count: Int, v: Float): Int

    Permalink
  17. final def appendInt(v: Int): Int

    Permalink
  18. final def appendInts(length: Int, src: Array[Int], offset: Int): Int

    Permalink
  19. final def appendInts(count: Int, v: Int): Int

    Permalink
  20. final def appendLong(v: Long): Int

    Permalink
  21. final def appendLongs(length: Int, src: Array[Long], offset: Int): Int

    Permalink
  22. final def appendLongs(count: Int, v: Long): Int

    Permalink
  23. final def appendNotNull(): Int

    Permalink
  24. final def appendNotNulls(count: Int): Int

    Permalink
  25. final def appendNull(): Int

    Permalink
  26. final def appendNulls(count: Int): Int

    Permalink
  27. final def appendShort(v: Short): Int

    Permalink
  28. final def appendShorts(length: Int, src: Array[Short], offset: Int): Int

    Permalink
  29. final def appendShorts(count: Int, v: Short): Int

    Permalink
  30. final def appendStruct(isNull: Boolean): Int

    Permalink
  31. final def arrayData(): ColumnVector

    Permalink
  32. final def asInstanceOf[T0]: T0

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  34. final def dataType(): DataType

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

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

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  38. final def getArray(rowId: Int): Array

    Permalink
  39. final def getBinary(rowId: Int): Array[Byte]

    Permalink
  40. final def getChildColumn(ordinal: Int): ColumnVector

    Permalink
  41. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  42. final def getDecimal(rowId: Int, precision: Int, scale: Int): Decimal

    Permalink
  43. def getDictionaryIds(): ColumnVector

    Permalink
  44. final def getElementsAppended(): Int

    Permalink
  45. def getMap(ordinal: Int): MapData

    Permalink
  46. def getStruct(rowId: Int, size: Int): ColumnarBatch.Row

    Permalink
  47. def getStruct(rowId: Int): ColumnarBatch.Row

    Permalink
  48. final def getUTF8String(rowId: Int): UTF8String

    Permalink
  49. def hasDictionary(): Boolean

    Permalink
  50. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  51. final def isArray(): Boolean

    Permalink
  52. final def isInstanceOf[T0]: Boolean

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

    Permalink
    Definition Classes
    AnyRef
  54. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  56. final def numNulls(): Int

    Permalink
  57. final def putByteArray(rowId: Int, value: Array[Byte]): Int

    Permalink
  58. final def putDecimal(rowId: Int, value: Decimal, precision: Int): Unit

    Permalink
  59. def reserve(requiredCapacity: Int): Unit

    Permalink
  60. def reserveDictionaryIds(capacity: Int): ColumnVector

    Permalink
  61. def reset(): Unit

    Permalink
  62. def setDictionary(dictionary: Dictionary): Unit

    Permalink
  63. final def setIsConstant(): Unit

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

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

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

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

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

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

Inherited from AutoCloseable

Inherited from AnyRef

Inherited from Any

Ungrouped