Class ReOpenableHashPartition<BT,PT>
- java.lang.Object
-
- org.apache.flink.runtime.memory.AbstractPagedInputView
-
- org.apache.flink.runtime.operators.hash.HashPartition<BT,PT>
-
- org.apache.flink.runtime.operators.hash.ReOpenableHashPartition<BT,PT>
-
- All Implemented Interfaces:
DataInput
,org.apache.flink.core.memory.DataInputView
,org.apache.flink.core.memory.SeekableDataInputView
public class ReOpenableHashPartition<BT,PT> extends HashPartition<BT,PT>
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.operators.hash.HashPartition
HashPartition.BuildSideBuffer
-
-
Field Summary
Fields Modifier and Type Field Description protected int
initialPartitionBuffersCount
-
Fields inherited from class org.apache.flink.runtime.operators.hash.HashPartition
furtherPartitioning, nextOverflowBucket, numOverflowSegments, overflowSegments, partitionBuffers, probeSideBuffer, probeSideChannel, probeSideRecordCounter, recursionLevel
-
Fields inherited from class org.apache.flink.runtime.memory.AbstractPagedInputView
headerLength
-
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method 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, boolean keepUnprobedSpilledPartitions)
-
Methods inherited from class org.apache.flink.runtime.operators.hash.HashPartition
finalizeBuildPhase, getBuildSideBlockCount, getBuildSideChannel, getBuildSideRecordCount, getLimitForSegment, getNumOccupiedMemorySegments, getPartitionNumber, getProbeSideBlockCount, getProbeSideChannel, getProbeSideRecordCount, getRecursionLevel, insertIntoBuildBuffer, insertIntoProbeBuffer, isInMemory, nextSegment, prepareProbePhase, setFurtherPatitioning, setReadPosition, spillPartition
-
Methods inherited from class org.apache.flink.runtime.memory.AbstractPagedInputView
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
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface java.io.DataInput
readBoolean, readByte, readChar, readDouble, readFloat, readFully, readFully, readInt, readLine, readLong, readShort, readUnsignedByte, readUnsignedShort, readUTF, skipBytes
-
-
-
-
Method Detail
-
finalizeProbePhase
public int finalizeProbePhase(List<org.apache.flink.core.memory.MemorySegment> freeMemory, List<HashPartition<BT,PT>> spilledPartitions, boolean keepUnprobedSpilledPartitions) throws IOException
- Overrides:
finalizeProbePhase
in classHashPartition<BT,PT>
keepUnprobedSpilledPartitions
- If true then partitions that were spilled but received no further probe requests will be retained; used for build-side outer joins.- Returns:
- The number of write-behind buffers reclaimable after this method call.
- Throws:
IOException
-
clearAllMemory
public void clearAllMemory(List<org.apache.flink.core.memory.MemorySegment> target)
- Overrides:
clearAllMemory
in classHashPartition<BT,PT>
-
-