public class SerializedValuesHolder<T> extends Object implements ValuesHolder<T>
Constructor and Description |
---|
SerializedValuesHolder(BlockId blockId,
int chunkSize,
scala.reflect.ClassTag<T> classTag,
org.apache.spark.memory.MemoryMode memoryMode,
org.apache.spark.serializer.SerializerManager serializerManager) |
Modifier and Type | Method and Description |
---|---|
scala.Function1<Object,java.nio.ByteBuffer> |
allocator() |
org.apache.spark.util.io.ChunkedByteBufferOutputStream |
bbos() |
long |
estimatedSize() |
MemoryEntryBuilder<T> |
getBuilder()
Note: After this method is called, the ValuesHolder is invalid, we can't store data and
get estimate size again.
|
org.apache.spark.storage.memory.RedirectableOutputStream |
redirectableStream() |
SerializationStream |
serializationStream() |
void |
storeValue(T value) |
public scala.Function1<Object,java.nio.ByteBuffer> allocator()
public org.apache.spark.util.io.ChunkedByteBufferOutputStream bbos()
public long estimatedSize()
estimatedSize
in interface ValuesHolder<T>
public MemoryEntryBuilder<T> getBuilder()
ValuesHolder
getBuilder
in interface ValuesHolder<T>
public org.apache.spark.storage.memory.RedirectableOutputStream redirectableStream()
public SerializationStream serializationStream()
public void storeValue(T value)
storeValue
in interface ValuesHolder<T>