Class BytesMultiMap
- java.lang.Object
-
- org.apache.flink.table.runtime.util.collections.binary.BytesMap<K,Iterator<RowData>>
-
- org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap<BinaryRowData>
-
- org.apache.flink.table.runtime.util.collections.binary.BytesMultiMap
-
public final class BytesMultiMap extends AbstractBytesMultiMap<BinaryRowData>
A binary map in the structure likeMap<BinaryRowData, List<BinaryRowData>>
.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.table.runtime.util.collections.binary.BytesMap
BytesMap.LookupInfo<K,V>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
keySerializer
-
Fields inherited from class org.apache.flink.table.runtime.util.collections.binary.BytesMap
BUCKET_SIZE, BUCKET_SIZE_BITS, bucketSegments, ELEMENT_POINT_LENGTH, END_OF_LIST, growthThreshold, INIT_BUCKET_MEMORY_IN_BYTES, lastBucketPosition, LOAD_FACTOR, log2NumBuckets, memoryPool, numBucketsMask, numBucketsMask2, numBucketsPerSegment, numBucketsPerSegmentBits, numBucketsPerSegmentMask, numElements, numSpillFiles, RECORD_EXTRA_LENGTH, recordArea, reservedNumBuffers, reusedKey, reusedValue, segmentSize, spillInBytes, STEP_INCREMENT
-
-
Constructor Summary
Constructors Constructor Description BytesMultiMap(Object owner, MemoryManager memoryManager, long memorySize, LogicalType[] keyTypes, LogicalType[] valueTypes)
-
Method Summary
-
Methods inherited from class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
append, free, free, getEntryIterator, getNumKeys, reset
-
Methods inherited from class org.apache.flink.table.runtime.util.collections.binary.BytesMap
calcSecondHashCode, getNumElements, getNumSpillFiles, getSpillInBytes, growAndRehash, initBucketSegments, lookup, resetBucketSegments, returnSegments
-
-
-
-
Constructor Detail
-
BytesMultiMap
public BytesMultiMap(Object owner, MemoryManager memoryManager, long memorySize, LogicalType[] keyTypes, LogicalType[] valueTypes)
-
-