Class

org.apache.spark.sql.catalyst.expressions

UnsafeRow

Related Doc: package expressions

Permalink

final class UnsafeRow extends InternalRow with Externalizable with KryoSerializable

Linear Supertypes
KryoSerializable, Externalizable, InternalRow, Serializable, Serializable, SpecializedGetters, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. UnsafeRow
  2. KryoSerializable
  3. Externalizable
  4. InternalRow
  5. Serializable
  6. Serializable
  7. SpecializedGetters
  8. AnyRef
  9. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new UnsafeRow()

    Permalink
  2. new UnsafeRow(numFields: Int)

    Permalink

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. def anyNull(): Boolean

    Permalink

    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
  5. final def asInstanceOf[T0]: T0

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

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

    Permalink

    Make a copy of the current InternalRow object.

    Make a copy of the current InternalRow object.

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

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

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

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  12. def fromData(in: DataInput): Unit

    Permalink
  13. def get(ordinal: Int, dataType: DataType): AnyRef

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

    Permalink
    Definition Classes
    UnsafeRowSpecializedGetters
  15. def getBaseObject(): AnyRef

    Permalink
  16. def getBaseOffset(): Long

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

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    UnsafeRowSpecializedGetters
  25. def getInt(ordinal: Int): Int

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

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

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

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

    Permalink
    Definition Classes
    UnsafeRowSpecializedGetters
  30. def getSizeInBytes(): Int

    Permalink
  31. def getString(ordinal: Int): String

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

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

    Permalink
    Definition Classes
    UnsafeRowSpecializedGetters
  34. def hashCode(): Int

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

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  40. def numFields(): Int

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

    Permalink
  42. def pointTo(baseObject: Any, baseOffset: Long, sizeInBytes: Int): Unit

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

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

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

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  46. def setByte(ordinal: Int, value: Byte): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  47. def setDecimal(ordinal: Int, value: Decimal, precision: Int): Unit

    Permalink

    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
    UnsafeRowInternalRow
  48. def setDouble(ordinal: Int, value: Double): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  49. def setFloat(ordinal: Int, value: Float): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  50. def setInt(ordinal: Int, value: Int): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  51. def setLong(ordinal: Int, value: Long): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  52. def setNotNullAt(i: Int): Unit

    Permalink
  53. def setNullAt(i: Int): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  54. def setShort(ordinal: Int, value: Short): Unit

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  55. def setTotalSize(sizeInBytes: Int): Unit

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

    Permalink
    Definition Classes
    AnyRef
  57. def toData(out: DataOutput): Unit

    Permalink
  58. def toSeq(schema: StructType): Seq[Any]

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

    Permalink

    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
  60. def toString(): String

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

    Permalink
    Definition Classes
    UnsafeRowInternalRow
  62. final def wait(): Unit

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

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

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

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

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

    Permalink
  68. def writeTo(buffer: ByteBuffer): Unit

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

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

    Permalink

Inherited from KryoSerializable

Inherited from Externalizable

Inherited from InternalRow

Inherited from Serializable

Inherited from Serializable

Inherited from SpecializedGetters

Inherited from AnyRef

Inherited from Any

Ungrouped