Class 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.BufferRecycler
    A DataOutputView that is backed by a FileIOChannel, making it effectively a data output stream. The view will compress its data before writing it in blocks to the underlying channel.
    • Nested Class Summary

      • Nested classes/interfaces inherited from interface org.apache.flink.runtime.io.network.buffer.BufferRecycler

        org.apache.flink.runtime.io.network.buffer.BufferRecycler.DummyBufferRecycler
    • Field Summary

      • Fields inherited from class org.apache.flink.runtime.memory.AbstractPagedOutputView

        headerLength, segmentSize
    • 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
      int close()  
      int getBlockCount()  
      org.apache.flink.runtime.io.disk.iomanager.FileIOChannel getChannel()  
      long getNumBytes()  
      long getNumCompressedBytes()  
      protected org.apache.flink.core.memory.MemorySegment nextSegment​(org.apache.flink.core.memory.MemorySegment current, int positionInCurrent)  
      void recycle​(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
    • Constructor Detail

      • CompressedHeaderlessChannelWriterOutputView

        public CompressedHeaderlessChannelWriterOutputView​(org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter writer,
                                                           org.apache.flink.runtime.io.compression.BlockCompressionFactory compressionCodecFactory,
                                                           int compressionBlockSize)
    • Method Detail

      • getChannel

        public org.apache.flink.runtime.io.disk.iomanager.FileIOChannel getChannel()
        Specified by:
        getChannel in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
      • close

        public int close()
                  throws IOException
        Specified by:
        close in class org.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:
        nextSegment in class org.apache.flink.runtime.memory.AbstractPagedOutputView
        Throws:
        IOException
      • getNumBytes

        public long getNumBytes()
        Specified by:
        getNumBytes in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
      • getNumCompressedBytes

        public long getNumCompressedBytes()
        Specified by:
        getNumCompressedBytes in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
      • getBlockCount

        public int getBlockCount()
        Specified by:
        getBlockCount in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
      • recycle

        public void recycle​(org.apache.flink.core.memory.MemorySegment memorySegment)
        Specified by:
        recycle in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler