Package org.apache.spark.storage.memory
Class SerializedValuesHolder<T>
Object
org.apache.spark.storage.memory.SerializedValuesHolder<T>
- All Implemented Interfaces:
- ValuesHolder<T>
A holder for storing the serialized values.
- 
Constructor SummaryConstructorsConstructorDescriptionSerializedValuesHolder(BlockId blockId, int chunkSize, scala.reflect.ClassTag<T> classTag, org.apache.spark.memory.MemoryMode memoryMode, org.apache.spark.serializer.SerializerManager serializerManager) 
- 
Method SummaryModifier and TypeMethodDescriptionscala.Function1<Object,ByteBuffer> org.apache.spark.util.io.ChunkedByteBufferOutputStreambbos()longNote: After this method is called, the ValuesHolder is invalid, we can't store data and get estimate size again.org.apache.spark.storage.memory.RedirectableOutputStreamvoidstoreValue(T value) 
- 
Constructor Details- 
SerializedValuesHolder
 
- 
- 
Method Details- 
allocator
- 
bbospublic org.apache.spark.util.io.ChunkedByteBufferOutputStream bbos()
- 
estimatedSizepublic long estimatedSize()- Specified by:
- estimatedSizein interface- ValuesHolder<T>
 
- 
getBuilderDescription copied from interface:ValuesHolderNote: After this method is called, the ValuesHolder is invalid, we can't store data and get estimate size again.- Specified by:
- getBuilderin interface- ValuesHolder<T>
- Returns:
- a MemoryEntryBuilder which is used to build a memory entry and get the stored data size.
 
- 
redirectableStreampublic org.apache.spark.storage.memory.RedirectableOutputStream redirectableStream()
- 
serializationStream
- 
storeValue- Specified by:
- storeValuein interface- ValuesHolder<T>
 
 
-