Trait

org.apache.spark.sql.catalyst.util

SerializedRowData

Related Doc: package util

Permalink

trait SerializedRowData extends SpecializedGetters with Externalizable with KryoSerializable

Contains the main code for SerializedRow and SerializedArray.

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

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

    Permalink
    Definition Classes
    Any
  6. final var baseObject: AnyRef

    Permalink
    Attributes
    protected
  7. final var baseOffset: Long

    Permalink
    Attributes
    protected
  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
  9. final def calculateBitSetWidthInBytes(numFields: Int): Int

    Permalink
  10. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  11. final def eq(arg0: AnyRef): Boolean

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

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

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

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

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

    Permalink
  17. final def getBaseOffset: Long

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Annotations
    @inline()
  25. final def getFloat(ordinal: Int): Float

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

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

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

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

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

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

    Permalink
  32. final def getSkipBytes: Int

    Permalink
  33. final def getStruct(ordinal: Int, numFields: Int): SerializedRow

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

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

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

    Permalink
    Attributes
    protected
  37. final def indexIsValid(index: Int): Boolean

    Permalink
    Attributes
    protected
    Annotations
    @inline()
  38. final def isInstanceOf[T0]: Boolean

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

    Permalink
    Definition Classes
    SerializedRowData → SpecializedGetters
  40. 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
  41. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  44. final def numFields: Int

    Permalink
  45. 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

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

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

    Permalink
    Definition Classes
    SerializedRowData → Externalizable
    Annotations
    @throws( ... ) @throws( ... )
  48. 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
  49. 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
  50. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink

    Returns the underlying bytes for this row.

  52. final def toString(): String

    Permalink
    Definition Classes
    SerializedRowData → AnyRef → Any
  53. final def wait(): Unit

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

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

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

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

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

Inherited from KryoSerializable

Inherited from Externalizable

Inherited from Serializable

Inherited from SpecializedGetters

Inherited from AnyRef

Inherited from Any

Ungrouped