public class ReOpenableHashPartition<BT,PT> extends HashPartition<BT,PT>
HashPartition.BuildSideBuffer
Modifier and Type | Field and Description |
---|---|
protected int |
initialPartitionBuffersCount |
furtherPartitioning, nextOverflowBucket, numOverflowSegments, overflowSegments, partitionBuffers, probeSideBuffer, probeSideChannel, probeSideRecordCounter, recursionLevel
headerLength
Modifier and Type | Method and Description |
---|---|
void |
clearAllMemory(List<org.apache.flink.core.memory.MemorySegment> target) |
int |
finalizeProbePhase(List<org.apache.flink.core.memory.MemorySegment> freeMemory,
List<HashPartition<BT,PT>> spilledPartitions) |
finalizeBuildPhase, getBuildSideBlockCount, getBuildSideChannel, getBuildSideRecordCount, getLimitForSegment, getNumOccupiedMemorySegments, getPartitionNumber, getProbeSideBlockCount, getProbeSideChannel, getProbeSideRecordCount, getRecursionLevel, insertIntoBuildBuffer, insertIntoProbeBuffer, isInMemory, nextSegment, prepareProbePhase, setFurtherPatitioning, setReadPosition, spillPartition
advance, clear, getCurrentPositionInSegment, getCurrentSegment, getCurrentSegmentLimit, 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
read, read, skipBytesToRead
readBoolean, readByte, readChar, readDouble, readFloat, readFully, readFully, readInt, readLine, readLong, readShort, readUnsignedByte, readUnsignedShort, readUTF, skipBytes
public int finalizeProbePhase(List<org.apache.flink.core.memory.MemorySegment> freeMemory, List<HashPartition<BT,PT>> spilledPartitions) throws IOException
finalizeProbePhase
in class HashPartition<BT,PT>
IOException
public void clearAllMemory(List<org.apache.flink.core.memory.MemorySegment> target)
clearAllMemory
in class HashPartition<BT,PT>
Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.