public static class SerDeEncodedDataReader.CacheWriter extends Object implements org.apache.orc.PhysicalWriter
| Constructor and Description |
|---|
CacheWriter(BufferUsageManager bufferManager,
List<Integer> columnIds,
boolean[] writerIncludes,
boolean doesSourceHaveIncludes,
org.apache.hadoop.hive.common.io.Allocator.BufferObjectFactory bufferFactory) |
| Modifier and Type | Method and Description |
|---|---|
void |
appendRawStripe(ByteBuffer stripe,
org.apache.orc.OrcProto.StripeInformation.Builder dirEntry) |
void |
close() |
org.apache.orc.PhysicalWriter.OutputReceiver |
createDataStream(org.apache.orc.impl.StreamName name) |
void |
discardData() |
void |
finalizeStripe(org.apache.orc.OrcProto.StripeFooter.Builder footer,
org.apache.orc.OrcProto.StripeInformation.Builder dirEntry) |
void |
flush() |
org.apache.orc.CompressionCodec |
getCompressionCodec() |
long |
getFileBytes(int column) |
void |
setCurrentStripeOffsets(long currentKnownTornStart,
long firstStartOffset,
long lastStartOffset,
long currentFileOffset) |
void |
validateIncludes(org.apache.orc.OrcProto.Footer footer) |
void |
writeBloomFilter(org.apache.orc.impl.StreamName name,
org.apache.orc.OrcProto.BloomFilterIndex.Builder bloom,
org.apache.orc.CompressionCodec codec) |
void |
writeFileFooter(org.apache.orc.OrcProto.Footer.Builder builder) |
void |
writeFileMetadata(org.apache.orc.OrcProto.Metadata.Builder builder) |
void |
writeHeader() |
void |
writeIndex(org.apache.orc.impl.StreamName name,
org.apache.orc.OrcProto.RowIndex.Builder index,
org.apache.orc.CompressionCodec codec) |
long |
writePostScript(org.apache.orc.OrcProto.PostScript.Builder builder) |
public CacheWriter(BufferUsageManager bufferManager, List<Integer> columnIds, boolean[] writerIncludes, boolean doesSourceHaveIncludes, org.apache.hadoop.hive.common.io.Allocator.BufferObjectFactory bufferFactory)
public void writeFileMetadata(org.apache.orc.OrcProto.Metadata.Builder builder)
throws IOException
writeFileMetadata in interface org.apache.orc.PhysicalWriterIOExceptionpublic void writeFileFooter(org.apache.orc.OrcProto.Footer.Builder builder)
throws IOException
writeFileFooter in interface org.apache.orc.PhysicalWriterIOExceptionpublic void validateIncludes(org.apache.orc.OrcProto.Footer footer)
throws IOException
IOExceptionpublic long writePostScript(org.apache.orc.OrcProto.PostScript.Builder builder)
writePostScript in interface org.apache.orc.PhysicalWriterpublic void close()
throws IOException
close in interface org.apache.orc.PhysicalWriterIOExceptionpublic void discardData()
public org.apache.orc.PhysicalWriter.OutputReceiver createDataStream(org.apache.orc.impl.StreamName name)
throws IOException
createDataStream in interface org.apache.orc.PhysicalWriterIOExceptionpublic void writeHeader()
throws IOException
writeHeader in interface org.apache.orc.PhysicalWriterIOExceptionpublic void writeIndex(org.apache.orc.impl.StreamName name,
org.apache.orc.OrcProto.RowIndex.Builder index,
org.apache.orc.CompressionCodec codec)
throws IOException
writeIndex in interface org.apache.orc.PhysicalWriterIOExceptionpublic void writeBloomFilter(org.apache.orc.impl.StreamName name,
org.apache.orc.OrcProto.BloomFilterIndex.Builder bloom,
org.apache.orc.CompressionCodec codec)
throws IOException
writeBloomFilter in interface org.apache.orc.PhysicalWriterIOExceptionpublic void finalizeStripe(org.apache.orc.OrcProto.StripeFooter.Builder footer,
org.apache.orc.OrcProto.StripeInformation.Builder dirEntry)
throws IOException
finalizeStripe in interface org.apache.orc.PhysicalWriterIOExceptionpublic void flush()
throws IOException
flush in interface org.apache.orc.PhysicalWriterIOExceptionpublic void appendRawStripe(ByteBuffer stripe, org.apache.orc.OrcProto.StripeInformation.Builder dirEntry) throws IOException
appendRawStripe in interface org.apache.orc.PhysicalWriterIOExceptionpublic void setCurrentStripeOffsets(long currentKnownTornStart,
long firstStartOffset,
long lastStartOffset,
long currentFileOffset)
public org.apache.orc.CompressionCodec getCompressionCodec()
getCompressionCodec in interface org.apache.orc.PhysicalWriterpublic long getFileBytes(int column)
getFileBytes in interface org.apache.orc.PhysicalWriterCopyright © 2019 The Apache Software Foundation. All Rights Reserved.