public abstract class LongHybridHashTable extends BaseHybridHashTable
See LongHashPartition
. TODO add min max long filter and bloomFilter to spilled
partition.
buildRowCount, buildSpillRetBufferNumbers, buildSpillReturnBuffers, closed, compressionBlockSize, compressionCodecFactory, compressionEnable, currentEnumerator, currentRecursionDepth, currentSpilledBuildSide, currentSpilledProbeSide, initPartitionFanOut, internalPool, ioManager, LOG, MAX_NUM_PARTITIONS, MAX_RECURSION_DEPTH, numSpillFiles, segmentSize, segmentSizeBits, segmentSizeMask, spillInBytes, totalNumBuffers, tryDistinctBuildRow
Constructor and Description |
---|
LongHybridHashTable(Configuration conf,
Object owner,
BinaryRowDataSerializer buildSideSerializer,
BinaryRowDataSerializer probeSideSerializer,
MemoryManager memManager,
long reservedMemorySize,
IOManager ioManager,
int avgRecordLen,
long buildRowCount) |
Modifier and Type | Method and Description |
---|---|
protected void |
clearPartitions() |
void |
close()
Closes the hash table.
|
int |
compressionBlockSize() |
BlockCompressionFactory |
compressionCodecFactory() |
boolean |
compressionEnable() |
void |
endBuild() |
void |
free() |
abstract long |
getBuildLongKey(RowData row)
For code gen get build side long key.
|
LongHashPartition.MatchIterator |
getBuildSideIterator() |
RowData |
getCurrentProbeRow() |
abstract long |
getProbeLongKey(RowData row)
For code gen get probe side long key.
|
boolean |
nextMatching() |
abstract BinaryRowData |
probeToBinary(RowData row)
For code gen probe side to BinaryRowData.
|
void |
putBuildRow(BinaryRowData row) |
int |
spillPartition() |
boolean |
tryProbe(RowData record) |
createInputView, ensureNumBuffersReturned, freeCurrent, freePages, getNextBuffer, getNextBuffers, getNotNullNextBuffer, getNumSpillFiles, getSpillInBytes, getUsedMemoryInBytes, hash, maxInitBufferOfBucketArea, maxNumPartition, nextSegment, pageSize, readAllBuffers, remainBuffers, returnAll, returnPage
public LongHybridHashTable(Configuration conf, Object owner, BinaryRowDataSerializer buildSideSerializer, BinaryRowDataSerializer probeSideSerializer, MemoryManager memManager, long reservedMemorySize, IOManager ioManager, int avgRecordLen, long buildRowCount)
public void putBuildRow(BinaryRowData row) throws IOException
IOException
public void endBuild() throws IOException
IOException
public boolean tryProbe(RowData record) throws IOException
IOException
public boolean nextMatching() throws IOException
IOException
public RowData getCurrentProbeRow()
public LongHashPartition.MatchIterator getBuildSideIterator()
public void close()
BaseHybridHashTable
close
in class BaseHybridHashTable
public void free()
free
in class BaseHybridHashTable
public abstract long getBuildLongKey(RowData row)
public abstract long getProbeLongKey(RowData row)
public abstract BinaryRowData probeToBinary(RowData row)
public int spillPartition() throws IOException
spillPartition
in class BaseHybridHashTable
IOException
protected void clearPartitions()
clearPartitions
in class BaseHybridHashTable
public boolean compressionEnable()
public BlockCompressionFactory compressionCodecFactory()
public int compressionBlockSize()
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.