Class SerializedValuesHolder<T>

Object
org.apache.spark.storage.memory.SerializedValuesHolder<T>
All Implemented Interfaces:
ValuesHolder<T>

public class SerializedValuesHolder<T> extends Object implements ValuesHolder<T>
A holder for storing the serialized values.
  • Constructor Details

    • SerializedValuesHolder

      public SerializedValuesHolder(BlockId blockId, int chunkSize, scala.reflect.ClassTag<T> classTag, org.apache.spark.memory.MemoryMode memoryMode, org.apache.spark.serializer.SerializerManager serializerManager)
  • Method Details

    • allocator

      public scala.Function1<Object,ByteBuffer> allocator()
    • bbos

      public org.apache.spark.util.io.ChunkedByteBufferOutputStream bbos()
    • estimatedSize

      public long estimatedSize()
      Specified by:
      estimatedSize in interface ValuesHolder<T>
    • getBuilder

      public MemoryEntryBuilder<T> getBuilder()
      Description copied from interface: ValuesHolder
      Note: After this method is called, the ValuesHolder is invalid, we can't store data and get estimate size again.
      Specified by:
      getBuilder in interface ValuesHolder<T>
      Returns:
      a MemoryEntryBuilder which is used to build a memory entry and get the stored data size.
    • redirectableStream

      public org.apache.spark.storage.memory.RedirectableOutputStream redirectableStream()
    • serializationStream

      public SerializationStream serializationStream()
    • storeValue

      public void storeValue(T value)
      Specified by:
      storeValue in interface ValuesHolder<T>