Class

org.apache.spark.sql.catalyst.util

SerializedRow

Related Doc: package util

Permalink

final class SerializedRow extends InternalRow with SerializedRowData

Like UnsafeRow uses raw memory bytes to encode the data in a row instead of objects. The difference is that it pays attention to endianness to use a consistent endian format (little-endian) so is suitable for storage.

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

Instance Constructors

  1. new SerializedRow(skipBytes: Int, numFields: Int)

    Permalink

    Construct a new SerializedRow.

    Construct a new SerializedRow. The resulting row won't be usable until pointTo() has been called, since the value returned by this constructor is equivalent to a null pointer.

    skipBytes

    number of bytes to skip at the start

    numFields

    the number of fields in this row

  2. new SerializedRow()

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

    Permalink
    Definition Classes
    SerializedRowData
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. final var baseObject: AnyRef

    Permalink
    Attributes
    protected
    Definition Classes
    SerializedRowData
  7. final var baseOffset: Long

    Permalink
    Attributes
    protected
    Definition Classes
    SerializedRowData
  8. final var bitSetWidthInBytes: Int

    Permalink

    The width of the null tracking bit set, in bytes

    The width of the null tracking bit set, in bytes

    Attributes
    protected
    Definition Classes
    SerializedRowData
  9. final def calculateBitSetWidthInBytes(numFields: Int): Int

    Permalink
    Definition Classes
    SerializedRowData
  10. def clone(): AnyRef

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

    Permalink

    Copies this row, returning a self-contained SerializedRow that stores its data in an internal byte array.

    Copies this row, returning a self-contained SerializedRow that stores its data in an internal byte array.

    Definition Classes
    SerializedRow → InternalRow
  12. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    SerializedRowData → AnyRef → Any
  14. def finalize(): Unit

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

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  16. final def getArray(ordinal: Int): SerializedArray

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  17. final def getBaseObject: AnyRef

    Permalink
    Definition Classes
    SerializedRowData
  18. final def getBaseOffset: Long

    Permalink
    Definition Classes
    SerializedRowData
  19. final def getBinary(ordinal: Int): Array[Byte]

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  20. final def getBoolean(ordinal: Int): Boolean

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  21. final def getByte(ordinal: Int): Byte

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  22. final def getClass(): Class[_]

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

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  24. final def getDouble(ordinal: Int): Double

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  25. final def getFieldCursor(ordinal: Int): Long

    Permalink
    Attributes
    protected
    Definition Classes
    SerializedRowData
    Annotations
    @inline()
  26. final def getFloat(ordinal: Int): Float

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  27. final def getInt(ordinal: Int): Int

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  28. final def getInterval(ordinal: Int): CalendarInterval

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  29. final def getLong(ordinal: Int): Long

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  30. final def getMap(ordinal: Int): SerializedMap

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  31. final def getShort(ordinal: Int): Short

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  32. final def getSizeInBytes: Int

    Permalink
    Definition Classes
    SerializedRowData
  33. final def getSkipBytes: Int

    Permalink
    Definition Classes
    SerializedRowData
  34. def getString(ordinal: Int): String

    Permalink
    Definition Classes
    InternalRow
  35. final def getStruct(ordinal: Int, numFields: Int): SerializedRow

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  36. final def getUTF8String(ordinal: Int): UTF8String

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  37. final def hashCode(): Int

    Permalink
    Definition Classes
    SerializedRowData → AnyRef → Any
  38. final def indexInvalid(index: Int): AssertionError

    Permalink
    Attributes
    protected
    Definition Classes
    SerializedRowData
  39. final def indexIsValid(index: Int): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    SerializedRowData
    Annotations
    @inline()
  40. final def isInstanceOf[T0]: Boolean

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

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  42. final var nFields: Int

    Permalink

    The number of fields in this row, used for calculating the bitset width.

    The number of fields in this row, used for calculating the bitset width.

    Attributes
    protected
    Definition Classes
    SerializedRowData
  43. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  46. final def numFields: Int

    Permalink
    Definition Classes
    SerializedRowData
  47. def pointTo(baseObject: AnyRef, baseOffset: Long, sizeInBytes: Int): Unit

    Permalink

    Update this SerializedRow to point to different backing data.

    Update this SerializedRow to point to different backing data.

    baseObject

    the base object

    baseOffset

    the offset within the base object

    sizeInBytes

    the size of this row's backing data, in bytes

    Definition Classes
    SerializedRowData
  48. final def read(kryo: Kryo, in: Input): Unit

    Permalink
    Definition Classes
    SerializedRowData → KryoSerializable
  49. final def readExternal(in: ObjectInput): Unit

    Permalink
    Definition Classes
    SerializedRowData → Externalizable
    Annotations
    @throws( ... ) @throws( ... )
  50. def setBoolean(i: Int, value: Boolean): Unit

    Permalink
    Definition Classes
    InternalRow
  51. def setByte(i: Int, value: Byte): Unit

    Permalink
    Definition Classes
    InternalRow
  52. def setDecimal(i: Int, value: Decimal, precision: Int): Unit

    Permalink
    Definition Classes
    InternalRow
  53. def setDouble(i: Int, value: Double): Unit

    Permalink
    Definition Classes
    InternalRow
  54. def setFloat(i: Int, value: Float): Unit

    Permalink
    Definition Classes
    InternalRow
  55. def setInt(i: Int, value: Int): Unit

    Permalink
    Definition Classes
    InternalRow
  56. def setLong(i: Int, value: Long): Unit

    Permalink
    Definition Classes
    InternalRow
  57. def setNullAt(i: Int): Unit

    Permalink
    Definition Classes
    SerializedRow → InternalRow
  58. def setShort(i: Int, value: Short): Unit

    Permalink
    Definition Classes
    InternalRow
  59. final var sizeInBytes: Int

    Permalink

    The size of this row's backing data, in bytes)

    The size of this row's backing data, in bytes)

    Attributes
    protected
    Definition Classes
    SerializedRowData
  60. final var skipBytes: Int

    Permalink

    The number of bytes reserved for size or something at the start that need to be skipped when reading data otherwise.

    The number of bytes reserved for size or something at the start that need to be skipped when reading data otherwise. This is not adjusted in baseOffset since those reserved bytes are part of the data that need to be retained when copying etc.

    Attributes
    protected
    Definition Classes
    SerializedRowData
  61. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  62. final def toBytes: Array[Byte]

    Permalink

    Returns the underlying bytes for this row.

    Returns the underlying bytes for this row.

    Definition Classes
    SerializedRowData
  63. def toSeq(schema: StructType): Seq[Any]

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

    Permalink
    Definition Classes
    InternalRow
  65. final def toString(): String

    Permalink
    Definition Classes
    SerializedRowData → AnyRef → Any
  66. def update(i: Int, value: Any): Unit

    Permalink
    Definition Classes
    SerializedRow → InternalRow
  67. final def wait(): Unit

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

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

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

    Permalink
    Definition Classes
    SerializedRowData → KryoSerializable
  71. final def writeExternal(out: ObjectOutput): Unit

    Permalink
    Definition Classes
    SerializedRowData → Externalizable
    Annotations
    @throws( ... )

Inherited from SerializedRowData

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