Class CompressedHeaderlessChannelWriterOutputView
- java.lang.Object
-
- org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
- org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
-
- All Implemented Interfaces:
DataOutput,org.apache.flink.core.memory.DataOutputView,org.apache.flink.core.memory.MemorySegmentWritable,org.apache.flink.runtime.io.network.buffer.BufferRecycler
public final class CompressedHeaderlessChannelWriterOutputView extends org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView implements org.apache.flink.runtime.io.network.buffer.BufferRecyclerADataOutputViewthat is backed by aFileIOChannel, making it effectively a data output stream. The view will compress its data before writing it in blocks to the underlying channel.
-
-
Constructor Summary
Constructors Constructor Description CompressedHeaderlessChannelWriterOutputView(org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter writer, org.apache.flink.runtime.io.compression.BlockCompressionFactory compressionCodecFactory, int compressionBlockSize)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description intclose()intgetBlockCount()org.apache.flink.runtime.io.disk.iomanager.FileIOChannelgetChannel()longgetNumBytes()longgetNumCompressedBytes()protected org.apache.flink.core.memory.MemorySegmentnextSegment(org.apache.flink.core.memory.MemorySegment current, int positionInCurrent)voidrecycle(org.apache.flink.core.memory.MemorySegment memorySegment)-
Methods inherited from class org.apache.flink.runtime.memory.AbstractPagedOutputView
advance, clear, getCurrentPositionInSegment, getCurrentSegment, getHeaderLength, getSegmentSize, seekOutput, skipBytesToWrite, write, write, write, write, write, writeBoolean, writeByte, writeBytes, writeChar, writeChars, writeDouble, writeFloat, writeInt, writeLong, writeShort, writeUTF
-
-
-
-
Method Detail
-
getChannel
public org.apache.flink.runtime.io.disk.iomanager.FileIOChannel getChannel()
- Specified by:
getChannelin classorg.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
close
public int close() throws IOException- Specified by:
closein classorg.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView- Throws:
IOException
-
nextSegment
protected org.apache.flink.core.memory.MemorySegment nextSegment(org.apache.flink.core.memory.MemorySegment current, int positionInCurrent) throws IOException- Specified by:
nextSegmentin classorg.apache.flink.runtime.memory.AbstractPagedOutputView- Throws:
IOException
-
getNumBytes
public long getNumBytes()
- Specified by:
getNumBytesin classorg.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
getNumCompressedBytes
public long getNumCompressedBytes()
- Specified by:
getNumCompressedBytesin classorg.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
getBlockCount
public int getBlockCount()
- Specified by:
getBlockCountin classorg.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
recycle
public void recycle(org.apache.flink.core.memory.MemorySegment memorySegment)
- Specified by:
recyclein interfaceorg.apache.flink.runtime.io.network.buffer.BufferRecycler
-
-