Packages

c

org.apache.spark.sql.vectorized

ColumnarBatchRow

final class ColumnarBatchRow extends InternalRow

This class wraps an array of ColumnVector and provides a row view.

Annotations
@DeveloperApi()
Source
ColumnarBatchRow.java
Since

3.3.0

Linear Supertypes
InternalRow, Serializable, SpecializedGetters, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ColumnarBatchRow
  2. InternalRow
  3. Serializable
  4. SpecializedGetters
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

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

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

Inherited from InternalRow

Inherited from Serializable

Inherited from SpecializedGetters

Inherited from AnyRef

Inherited from Any

Ungrouped