Package org.apache.flink.runtime.io.disk
Class ChannelReaderInputViewIterator<E>
- java.lang.Object
-
- org.apache.flink.runtime.io.disk.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 Summary
Constructors Constructor Description ChannelReaderInputViewIterator(AbstractChannelReaderInputView inView, List<org.apache.flink.core.memory.MemorySegment> freeMemTarget, org.apache.flink.api.common.typeutils.TypeSerializer<E> accessors)
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)
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)
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)
-
-
-
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 interfaceorg.apache.flink.util.MutableObjectIterator<E>
- Throws:
IOException
-
next
public E next() throws IOException
- Specified by:
next
in interfaceorg.apache.flink.util.MutableObjectIterator<E>
- Throws:
IOException
-
-