Package | Description |
---|---|
org.apache.flink.runtime.iterative.io | |
org.apache.flink.runtime.operators.hash |
Constructor and Description |
---|
HashPartitionIterator(Iterator<HashPartition<BT,PT>> partitions,
TypeSerializer<BT> serializer) |
Modifier and Type | Class and Description |
---|---|
class |
ReOpenableHashPartition<BT,PT> |
Modifier and Type | Field and Description |
---|---|
protected ArrayList<HashPartition<BT,PT>> |
MutableHashTable.partitionsBeingBuilt
The partitions that are built by processing the current partition.
|
Modifier and Type | Method and Description |
---|---|
protected HashPartition<BT,PT> |
MutableHashTable.getNewInMemoryPartition(int number,
int recursionLevel)
Returns a new inMemoryPartition object.
|
protected HashPartition<BT,PT> |
ReOpenableMutableHashTable.getNewInMemoryPartition(int number,
int recursionLevel) |
Modifier and Type | Method and Description |
---|---|
protected void |
MutableHashTable.buildBloomFilterForBucketsInPartition(int partNum,
HashPartition<BT,PT> partition) |
protected void |
MutableHashTable.buildTableFromSpilledPartition(HashPartition<BT,PT> p) |
Modifier and Type | Method and Description |
---|---|
int |
ReOpenableHashPartition.finalizeProbePhase(List<MemorySegment> freeMemory,
List<HashPartition<BT,PT>> spilledPartitions,
boolean keepUnprobedSpilledPartitions) |
int |
HashPartition.finalizeProbePhase(List<MemorySegment> freeMemory,
List<HashPartition<BT,PT>> spilledPartitions,
boolean keepUnprobedSpilledPartitions) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.