public class RandomAccessInputView extends AbstractPagedInputView implements org.apache.flink.core.memory.SeekableDataInputView
headerLength
构造器和说明 |
---|
RandomAccessInputView(ArrayList<org.apache.flink.core.memory.MemorySegment> segments,
int segmentSize) |
RandomAccessInputView(ArrayList<org.apache.flink.core.memory.MemorySegment> segments,
int segmentSize,
int limitInLastSegment) |
限定符和类型 | 方法和说明 |
---|---|
protected int |
getLimitForSegment(org.apache.flink.core.memory.MemorySegment segment)
Gets the limit for reading bytes from the given memory segment.
|
long |
getReadPosition() |
protected org.apache.flink.core.memory.MemorySegment |
nextSegment(org.apache.flink.core.memory.MemorySegment current)
The method by which concrete subclasses realize page crossing.
|
void |
setReadPosition(long position) |
advance, clear, doAdvance, getCurrentPositionInSegment, getCurrentSegment, getCurrentSegmentLimit, getHeaderLength, read, read, readBoolean, readByte, readChar, readDouble, readFloat, readFully, readFully, readInt, readLine, readLong, readShort, readUnsignedByte, readUnsignedShort, readUTF, seekInput, skipBytes, skipBytesToRead
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
readBoolean, readByte, readChar, readDouble, readFloat, readFully, readFully, readInt, readLine, readLong, readShort, readUnsignedByte, readUnsignedShort, readUTF, skipBytes
public RandomAccessInputView(ArrayList<org.apache.flink.core.memory.MemorySegment> segments, int segmentSize)
public RandomAccessInputView(ArrayList<org.apache.flink.core.memory.MemorySegment> segments, int segmentSize, int limitInLastSegment)
public void setReadPosition(long position)
setReadPosition
在接口中 org.apache.flink.core.memory.SeekableDataInputView
public long getReadPosition()
protected org.apache.flink.core.memory.MemorySegment nextSegment(org.apache.flink.core.memory.MemorySegment current) throws EOFException
AbstractPagedInputView
EOFException
.nextSegment
在类中 AbstractPagedInputView
current
- The current page that was read to its limit. May be null
, if this method is
invoked for the first time.null
. If the input is
exhausted, an EOFException
must be thrown instead.EOFException
- Thrown, if no further segment is available.protected int getLimitForSegment(org.apache.flink.core.memory.MemorySegment segment)
AbstractPagedInputView
getLimitForSegment
在类中 AbstractPagedInputView
segment
- The segment to determine the limit for.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.