Packages

c

org.apache.spark.sql.vectorized

ColumnarBatchRow

final class ColumnarBatchRow extends InternalRow

Annotations
@DeveloperApi()
Linear Supertypes
InternalRow, Serializable, Serializable, SpecializedGetters, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ColumnarBatchRow
  2. InternalRow
  3. Serializable
  4. Serializable
  5. SpecializedGetters
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ColumnarBatchRow(columns: Array[ColumnVector])

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. def anyNull(): Boolean
    Definition Classes
    ColumnarBatchRow → InternalRow
    Annotations
    @Override()
  5. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  7. def copy(): InternalRow
    Definition Classes
    ColumnarBatchRow → InternalRow
    Annotations
    @Override()
  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 get(ordinal: Int, dataType: DataType): AnyRef
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  12. def getArray(ordinal: Int): ColumnarArray
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  13. def getBinary(ordinal: Int): Array[Byte]
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  14. def getBoolean(ordinal: Int): Boolean
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  15. def getByte(ordinal: Int): Byte
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  16. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  17. def getDecimal(ordinal: Int, precision: Int, scale: Int): Decimal
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  18. def getDouble(ordinal: Int): Double
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  19. def getFloat(ordinal: Int): Float
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  20. def getInt(ordinal: Int): Int
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  21. def getInterval(ordinal: Int): CalendarInterval
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  22. def getLong(ordinal: Int): Long
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  23. def getMap(ordinal: Int): ColumnarMap
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  24. def getShort(ordinal: Int): Short
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  25. def getString(ordinal: Int): String
    Definition Classes
    InternalRow
  26. def getStruct(ordinal: Int, numFields: Int): ColumnarRow
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  27. def getUTF8String(ordinal: Int): UTF8String
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  28. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  29. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  30. def isNullAt(ordinal: Int): Boolean
    Definition Classes
    ColumnarBatchRow → SpecializedGetters
    Annotations
    @Override()
  31. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  32. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  33. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  34. def numFields(): Int
    Definition Classes
    ColumnarBatchRow → InternalRow
    Annotations
    @Override()
  35. def setBoolean(i: Int, value: Boolean): Unit
    Definition Classes
    InternalRow
  36. def setByte(i: Int, value: Byte): Unit
    Definition Classes
    InternalRow
  37. def setDecimal(i: Int, value: Decimal, precision: Int): Unit
    Definition Classes
    InternalRow
  38. def setDouble(i: Int, value: Double): Unit
    Definition Classes
    InternalRow
  39. def setFloat(i: Int, value: Float): Unit
    Definition Classes
    InternalRow
  40. def setInt(i: Int, value: Int): Unit
    Definition Classes
    InternalRow
  41. def setInterval(i: Int, value: CalendarInterval): Unit
    Definition Classes
    InternalRow
  42. def setLong(i: Int, value: Long): Unit
    Definition Classes
    InternalRow
  43. def setNullAt(ordinal: Int): Unit
    Definition Classes
    ColumnarBatchRow → InternalRow
    Annotations
    @Override()
  44. def setShort(i: Int, value: Short): Unit
    Definition Classes
    InternalRow
  45. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  46. def toSeq(schema: StructType): Seq[Any]
    Definition Classes
    InternalRow
  47. def toSeq(fieldTypes: Seq[DataType]): Seq[Any]
    Definition Classes
    InternalRow
  48. def toString(): String
    Definition Classes
    AnyRef → Any
  49. def update(ordinal: Int, value: Any): Unit
    Definition Classes
    ColumnarBatchRow → InternalRow
    Annotations
    @Override()
  50. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  51. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  52. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()

Inherited from InternalRow

Inherited from Serializable

Inherited from Serializable

Inherited from SpecializedGetters

Inherited from AnyRef

Inherited from Any

Ungrouped