Packages

c

org.apache.spark.sql.vectorized

ArrowColumnVector

class ArrowColumnVector extends ColumnVector

Annotations
@DeveloperApi()
Linear Supertypes
ColumnVector, AutoCloseable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ArrowColumnVector
  2. ColumnVector
  3. AutoCloseable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ArrowColumnVector(vector: ValueVector)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  6. def close(): Unit
    Definition Classes
    ArrowColumnVectorColumnVector → AutoCloseable
    Annotations
    @Override()
  7. final def dataType(): DataType
    Definition Classes
    ColumnVector
  8. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  9. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  10. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  11. def getArray(rowId: Int): ColumnarArray
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  12. def getBinary(rowId: Int): Array[Byte]
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  13. def getBoolean(rowId: Int): Boolean
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  14. def getBooleans(rowId: Int, count: Int): Array[Boolean]
    Definition Classes
    ColumnVector
  15. def getByte(rowId: Int): Byte
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  16. def getBytes(rowId: Int, count: Int): Array[Byte]
    Definition Classes
    ColumnVector
  17. def getChild(ordinal: Int): ArrowColumnVector
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  18. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  19. def getDecimal(rowId: Int, precision: Int, scale: Int): Decimal
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  20. def getDouble(rowId: Int): Double
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  21. def getDoubles(rowId: Int, count: Int): Array[Double]
    Definition Classes
    ColumnVector
  22. def getFloat(rowId: Int): Float
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  23. def getFloats(rowId: Int, count: Int): Array[Float]
    Definition Classes
    ColumnVector
  24. def getInt(rowId: Int): Int
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  25. final def getInterval(rowId: Int): CalendarInterval
    Definition Classes
    ColumnVector
  26. def getInts(rowId: Int, count: Int): Array[Int]
    Definition Classes
    ColumnVector
  27. def getLong(rowId: Int): Long
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  28. def getLongs(rowId: Int, count: Int): Array[Long]
    Definition Classes
    ColumnVector
  29. def getMap(rowId: Int): ColumnarMap
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  30. def getShort(rowId: Int): Short
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  31. def getShorts(rowId: Int, count: Int): Array[Short]
    Definition Classes
    ColumnVector
  32. final def getStruct(rowId: Int): ColumnarRow
    Definition Classes
    ColumnVector
  33. def getUTF8String(rowId: Int): UTF8String
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  34. def getValueVector(): ValueVector
  35. def hasNull(): Boolean
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  36. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  37. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  38. def isNullAt(rowId: Int): Boolean
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  39. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  40. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  41. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  42. def numNulls(): Int
    Definition Classes
    ArrowColumnVectorColumnVector
    Annotations
    @Override()
  43. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  44. def toString(): String
    Definition Classes
    AnyRef → Any
  45. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  46. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  47. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()

Inherited from ColumnVector

Inherited from AutoCloseable

Inherited from AnyRef

Inherited from Any

Ungrouped