org.apache.spark.sql.catalyst.expressions

UnsafeRow

final class UnsafeRow extends MutableRow with Externalizable with KryoSerializable

Linear Supertypes
KryoSerializable, Externalizable, MutableRow, InternalRow, Serializable, Serializable, SpecializedGetters, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. UnsafeRow
  2. KryoSerializable
  3. Externalizable
  4. MutableRow
  5. InternalRow
  6. Serializable
  7. Serializable
  8. SpecializedGetters
  9. AnyRef
  10. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new UnsafeRow()

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. def anyNull(): Boolean

    Returns true if there are any NULL values in this row.

    Returns true if there are any NULL values in this row.

    Definition Classes
    UnsafeRowInternalRow
  7. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  8. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. def copy(): UnsafeRow

    Make a copy of the current InternalRow object.

    Make a copy of the current InternalRow object.

    Definition Classes
    UnsafeRowInternalRow
  10. def copyFrom(row: UnsafeRow): Unit

  11. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  12. def equals(other: Any): Boolean

    Definition Classes
    UnsafeRow → AnyRef → Any
  13. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  14. def get(ordinal: Int, dataType: DataType): AnyRef

    Definition Classes
    UnsafeRowSpecializedGetters
  15. def getArray(ordinal: Int): UnsafeArrayData

    Definition Classes
    UnsafeRowSpecializedGetters
  16. def getBaseObject(): AnyRef

  17. def getBaseOffset(): Long

  18. def getBinary(ordinal: Int): Array[Byte]

    Definition Classes
    UnsafeRowSpecializedGetters
  19. def getBoolean(ordinal: Int): Boolean

    Definition Classes
    UnsafeRowSpecializedGetters
  20. def getByte(ordinal: Int): Byte

    Definition Classes
    UnsafeRowSpecializedGetters
  21. def getBytes(): Array[Byte]

  22. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  23. def getDecimal(ordinal: Int, precision: Int, scale: Int): Decimal

    Definition Classes
    UnsafeRowSpecializedGetters
  24. def getDouble(ordinal: Int): Double

    Definition Classes
    UnsafeRowSpecializedGetters
  25. def getFloat(ordinal: Int): Float

    Definition Classes
    UnsafeRowSpecializedGetters
  26. def getInt(ordinal: Int): Int

    Definition Classes
    UnsafeRowSpecializedGetters
  27. def getInterval(ordinal: Int): CalendarInterval

    Definition Classes
    UnsafeRowSpecializedGetters
  28. def getLong(ordinal: Int): Long

    Definition Classes
    UnsafeRowSpecializedGetters
  29. def getMap(ordinal: Int): UnsafeMapData

    Definition Classes
    UnsafeRowSpecializedGetters
  30. def getShort(ordinal: Int): Short

    Definition Classes
    UnsafeRowSpecializedGetters
  31. def getSizeInBytes(): Int

  32. def getString(ordinal: Int): String

    Definition Classes
    InternalRow
  33. def getStruct(ordinal: Int, numFields: Int): UnsafeRow

    Definition Classes
    UnsafeRowSpecializedGetters
  34. def getUTF8String(ordinal: Int): UTF8String

    Definition Classes
    UnsafeRowSpecializedGetters
  35. def hashCode(): Int

    Definition Classes
    UnsafeRow → AnyRef → Any
  36. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  37. def isNullAt(ordinal: Int): Boolean

    Definition Classes
    UnsafeRowSpecializedGetters
  38. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  39. final def notify(): Unit

    Definition Classes
    AnyRef
  40. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  41. def numFields(): Int

    Definition Classes
    UnsafeRowInternalRow
  42. def pointTo(buf: Array[Byte], sizeInBytes: Int): Unit

  43. def pointTo(buf: Array[Byte], numFields: Int, sizeInBytes: Int): Unit

  44. def pointTo(baseObject: Any, baseOffset: Long, numFields: Int, sizeInBytes: Int): Unit

  45. def read(kryo: Kryo, in: Input): Unit

    Definition Classes
    UnsafeRow → KryoSerializable
  46. def readExternal(in: ObjectInput): Unit

    Definition Classes
    UnsafeRow → Externalizable
  47. def setBoolean(ordinal: Int, value: Boolean): Unit

    Definition Classes
    UnsafeRowMutableRow
  48. def setByte(ordinal: Int, value: Byte): Unit

    Definition Classes
    UnsafeRowMutableRow
  49. def setDecimal(ordinal: Int, value: Decimal, precision: Int): Unit

    Update the decimal column at i.

    Update the decimal column at i.

    Note: In order to support update decimal with precision > 18 in UnsafeRow, CAN NOT call setNullAt() for decimal column on UnsafeRow, call setDecimal(i, null, precision).

    Definition Classes
    UnsafeRowMutableRow
  50. def setDouble(ordinal: Int, value: Double): Unit

    Definition Classes
    UnsafeRowMutableRow
  51. def setFloat(ordinal: Int, value: Float): Unit

    Definition Classes
    UnsafeRowMutableRow
  52. def setInt(ordinal: Int, value: Int): Unit

    Definition Classes
    UnsafeRowMutableRow
  53. def setLong(ordinal: Int, value: Long): Unit

    Definition Classes
    UnsafeRowMutableRow
  54. def setNotNullAt(i: Int): Unit

  55. def setNullAt(i: Int): Unit

    Definition Classes
    UnsafeRowMutableRow
  56. def setShort(ordinal: Int, value: Short): Unit

    Definition Classes
    UnsafeRowMutableRow
  57. def setTotalSize(sizeInBytes: Int): Unit

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

    Definition Classes
    AnyRef
  59. def toSeq(schema: StructType): Seq[Any]

    Definition Classes
    InternalRow
  60. def toSeq(fieldTypes: Seq[DataType]): Seq[Any]

    Return a Scala Seq representing the row.

    Return a Scala Seq representing the row. Elements are placed in the same order in the Seq.

    Definition Classes
    InternalRow
  61. def toString(): String

    Definition Classes
    UnsafeRow → AnyRef → Any
  62. def update(ordinal: Int, value: Any): Unit

    Definition Classes
    UnsafeRowMutableRow
  63. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  66. def write(kryo: Kryo, out: Output): Unit

    Definition Classes
    UnsafeRow → KryoSerializable
  67. def writeExternal(out: ObjectOutput): Unit

    Definition Classes
    UnsafeRow → Externalizable
  68. def writeFieldTo(ordinal: Int, buffer: ByteBuffer): Unit

  69. def writeTo(buffer: ByteBuffer): Unit

  70. def writeToMemory(target: Any, targetOffset: Long): Unit

  71. def writeToStream(out: OutputStream, writeBuffer: Array[Byte]): Unit

Inherited from KryoSerializable

Inherited from Externalizable

Inherited from MutableRow

Inherited from InternalRow

Inherited from Serializable

Inherited from Serializable

Inherited from SpecializedGetters

Inherited from AnyRef

Inherited from Any

Ungrouped