Class/Object

org.apache.spark.sql.execution.columnar.impl

ColumnDelta

Related Docs: object ColumnDelta | package impl

Permalink

final class ColumnDelta extends ColumnFormatValue with Delta

Encapsulates a delta for update to be applied to column table and also is stored in the region. The key for a delta is a negative columnIndex evaluated as (ColumnFormatEntry.DELTA_STATROW_COL_INDEX - 1 + MAX_DEPTH * -columnIndex) where columnIndex is the 0-based index of the underlying table column.

Note that this delta is for carrying the delta update and applying on existing delta, if any, while the actual value that is stored in the region is a ColumnFormatValue. This is to ensure clean working of the delta mechanism where store-layer code checks the type of object for Delta and makes assumptions about it (like it being a temporary value that should not go into region etc).

For a description of column delta format see the class comments in org.apache.spark.sql.execution.columnar.encoding.ColumnDeltaEncoder.

Linear Supertypes
Delta, ColumnFormatValue, Sizeable, GfxdSerializable, GfxdDSFID, DataSerializableFixedID, SerializationVersions, SerializedDiskBuffer, ByteBufferReference, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ColumnDelta
  2. Delta
  3. ColumnFormatValue
  4. Sizeable
  5. GfxdSerializable
  6. GfxdDSFID
  7. DataSerializableFixedID
  8. SerializationVersions
  9. SerializedDiskBuffer
  10. ByteBufferReference
  11. AnyRef
  12. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ColumnDelta(buffer: ByteBuffer)

    Permalink
  2. new ColumnDelta()

    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 allowCreate(): Boolean

    Permalink

    first delta update for a column will be put as is into the region

    first delta update for a column will be put as is into the region

    Definition Classes
    ColumnDelta → Delta
  5. def apply(region: Region[_, _], key: AnyRef, oldValue: AnyRef, prepareForOffHeap: Boolean): AnyRef

    Permalink
    Definition Classes
    ColumnDelta → Delta
  6. def apply(putEvent: EntryEvent[_, _]): AnyRef

    Permalink
    Definition Classes
    ColumnDelta → Delta
  7. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  8. final def channelSize(): Int

    Permalink
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer
  9. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  10. def cloneDelta(): Delta

    Permalink
    Definition Classes
    ColumnDelta → Delta
  11. var columnBuffer: ByteBuffer

    Permalink
    Attributes
    protected
    Definition Classes
    ColumnFormatValue
  12. final def copyToHeap(owner: String): Unit

    Permalink
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer
  13. var diskId: DiskId

    Permalink
    Attributes
    protected
    Definition Classes
    ColumnFormatValue
  14. var diskRegion: DiskRegionView

    Permalink
    Attributes
    protected
    Definition Classes
    ColumnFormatValue
  15. def duplicateBuffer(buffer: ByteBuffer): ByteBuffer

    Permalink
    Attributes
    protected
    Definition Classes
    ColumnFormatValue
    Annotations
    @inline()
  16. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  17. def equals(arg0: Any): Boolean

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

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

    Permalink
    Definition Classes
    ColumnFormatValue → DataSerializableFixedID
  20. final def getBufferRetain(): ByteBuffer

    Permalink

    Callers of this method should have a corresponding release method for eager release to work else off-heap object may keep around occupying system RAM until the next GC cycle.

    Callers of this method should have a corresponding release method for eager release to work else off-heap object may keep around occupying system RAM until the next GC cycle. Callers may decide whether to keep the release method in a finally block to ensure its invocation, or do it only in normal paths because JVM reference collector will eventually clean it in any case.

    Calls to this specific class are guaranteed to always return buffers which have position as zero so callers can make simplifying assumptions about the same.

    Definition Classes
    ColumnFormatValue → ByteBufferReference
  21. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  22. final def getDSFID(): Int

    Permalink
    Definition Classes
    ColumnFormatValue → DataSerializableFixedID
  23. def getDiskBufferRetain(): SerializedDiskBuffer

    Permalink
    Definition Classes
    SerializedDiskBuffer
  24. def getGfxdID(): Byte

    Permalink
    Definition Classes
    ColumnDeltaColumnFormatValue → GfxdDSFID
  25. def getOffHeapSizeInBytes(): Int

    Permalink
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer
  26. def getSerializationVersions(): Array[Version]

    Permalink
    Definition Classes
    ColumnFormatValue → SerializationVersions
  27. def getSizeInBytes(): Int

    Permalink
    Definition Classes
    ColumnFormatValue → Sizeable
  28. def getVersionTag(): VersionTag[_ <: VersionSource[_]]

    Permalink
    Definition Classes
    ColumnDelta → Delta
  29. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  30. final def isDirect: Boolean

    Permalink
    Definition Classes
    ColumnFormatValue
  31. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  32. def merge(region: Region[_, _], toMerge: Delta): Delta

    Permalink
    Definition Classes
    ColumnDelta → Delta
  33. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  34. final def needsRelease(): Boolean

    Permalink
    Definition Classes
    ColumnFormatValue → ByteBufferReference
  35. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  37. def refCount(): Int

    Permalink
    Definition Classes
    SerializedDiskBuffer → ByteBufferReference
  38. def release(): Unit

    Permalink
    Definition Classes
    SerializedDiskBuffer → ByteBufferReference
  39. def releaseBuffer(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer
  40. def retain(): Boolean

    Permalink
    Definition Classes
    SerializedDiskBuffer → ByteBufferReference
  41. def setBuffer(buffer: ByteBuffer, changeOwnerToStorage: Boolean = true): Unit

    Permalink
    Definition Classes
    ColumnFormatValue
  42. final def setDiskId(id: DiskId, dr: DiskRegionView): Unit

    Permalink
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer
  43. def setVersionTag(versionTag: VersionTag[_ <: VersionSource[_]]): Unit

    Permalink
    Definition Classes
    ColumnDelta → Delta
  44. final def size(): Int

    Permalink
    Definition Classes
    ColumnFormatValue → ByteBufferReference
  45. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    ColumnFormatValue → DataSerializableFixedID
  47. def toString(): String

    Permalink
    Definition Classes
    ColumnDeltaColumnFormatValue → AnyRef → Any
  48. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  51. final def write(channel: OutputStreamChannel): Unit

    Permalink
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer
  52. final def write(arg0: OutputStreamChannel, arg1: ByteBuffer): Unit

    Permalink
    Attributes
    protected[com.gemstone.gemfire.internal.cache.store]
    Definition Classes
    SerializedDiskBuffer
    Annotations
    @throws( classOf[java.io.IOException] )
  53. final def writeSerializationHeader(src: ByteBuffer, writeBuf: ByteBuffer): Boolean

    Permalink
    Definition Classes
    ColumnFormatValue → SerializedDiskBuffer

Inherited from Delta

Inherited from ColumnFormatValue

Inherited from Sizeable

Inherited from GfxdSerializable

Inherited from GfxdDSFID

Inherited from DataSerializableFixedID

Inherited from SerializationVersions

Inherited from SerializedDiskBuffer

Inherited from ByteBufferReference

Inherited from AnyRef

Inherited from Any

Ungrouped