Class ChannelReaderInputViewIterator<E>

  • All Implemented Interfaces:
    org.apache.flink.util.MutableObjectIterator<E>

    public class ChannelReaderInputViewIterator<E>
    extends Object
    implements org.apache.flink.util.MutableObjectIterator<E>
    A simple iterator over the input read though an I/O channel.
    • Constructor Detail

      • ChannelReaderInputViewIterator

        public ChannelReaderInputViewIterator​(IOManager ioAccess,
                                              FileIOChannel.ID channel,
                                              List<org.apache.flink.core.memory.MemorySegment> segments,
                                              List<org.apache.flink.core.memory.MemorySegment> freeMemTarget,
                                              org.apache.flink.api.common.typeutils.TypeSerializer<E> accessors,
                                              int numBlocks)
                                       throws IOException
        Throws:
        IOException
      • ChannelReaderInputViewIterator

        public ChannelReaderInputViewIterator​(IOManager ioAccess,
                                              FileIOChannel.ID channel,
                                              LinkedBlockingQueue<org.apache.flink.core.memory.MemorySegment> returnQueue,
                                              List<org.apache.flink.core.memory.MemorySegment> segments,
                                              List<org.apache.flink.core.memory.MemorySegment> freeMemTarget,
                                              org.apache.flink.api.common.typeutils.TypeSerializer<E> accessors,
                                              int numBlocks)
                                       throws IOException
        Throws:
        IOException
      • ChannelReaderInputViewIterator

        public ChannelReaderInputViewIterator​(BlockChannelReader<org.apache.flink.core.memory.MemorySegment> reader,
                                              LinkedBlockingQueue<org.apache.flink.core.memory.MemorySegment> returnQueue,
                                              List<org.apache.flink.core.memory.MemorySegment> segments,
                                              List<org.apache.flink.core.memory.MemorySegment> freeMemTarget,
                                              org.apache.flink.api.common.typeutils.TypeSerializer<E> accessors,
                                              int numBlocks)
                                       throws IOException
        Throws:
        IOException
      • ChannelReaderInputViewIterator

        public ChannelReaderInputViewIterator​(AbstractChannelReaderInputView inView,
                                              List<org.apache.flink.core.memory.MemorySegment> freeMemTarget,
                                              org.apache.flink.api.common.typeutils.TypeSerializer<E> accessors)
    • Method Detail

      • next

        public E next​(E reuse)
               throws IOException
        Specified by:
        next in interface org.apache.flink.util.MutableObjectIterator<E>
        Throws:
        IOException
      • next

        public E next()
               throws IOException
        Specified by:
        next in interface org.apache.flink.util.MutableObjectIterator<E>
        Throws:
        IOException