public abstract class VectorMapJoinOptimizedHashTable extends Object implements VectorMapJoinHashTable
Modifier and Type | Class and Description |
---|---|
static class |
VectorMapJoinOptimizedHashTable.SerializedBytes |
Modifier and Type | Field and Description |
---|---|
protected ReusableGetAdaptorDirectAccess |
adapatorDirectAccess |
protected MapJoinTableContainerDirectAccess |
containerDirectAccess |
protected MapJoinTableContainer |
originalTableContainer |
Constructor and Description |
---|
VectorMapJoinOptimizedHashTable(MapJoinTableContainer originalTableContainer,
MapJoinTableContainer.ReusableGetAdaptor hashMapRowGetter) |
Modifier and Type | Method and Description |
---|---|
JoinUtil.JoinResult |
doLookup(byte[] keyBytes,
int keyOffset,
int keyLength,
BytesBytesMultiHashMap.Result bytesBytesMultiHashMapResult,
VectorMapJoinHashTableResult hashTableResult) |
void |
putRow(org.apache.hadoop.io.BytesWritable currentKey,
org.apache.hadoop.io.BytesWritable currentValue) |
protected void |
putRowInternal(org.apache.hadoop.io.BytesWritable key,
org.apache.hadoop.io.BytesWritable value) |
protected final MapJoinTableContainer originalTableContainer
protected final MapJoinTableContainerDirectAccess containerDirectAccess
protected final ReusableGetAdaptorDirectAccess adapatorDirectAccess
public VectorMapJoinOptimizedHashTable(MapJoinTableContainer originalTableContainer, MapJoinTableContainer.ReusableGetAdaptor hashMapRowGetter)
public void putRow(org.apache.hadoop.io.BytesWritable currentKey, org.apache.hadoop.io.BytesWritable currentValue) throws SerDeException, HiveException, IOException
putRow
in interface VectorMapJoinHashTable
SerDeException
HiveException
IOException
protected void putRowInternal(org.apache.hadoop.io.BytesWritable key, org.apache.hadoop.io.BytesWritable value) throws SerDeException, HiveException, IOException
SerDeException
HiveException
IOException
public JoinUtil.JoinResult doLookup(byte[] keyBytes, int keyOffset, int keyLength, BytesBytesMultiHashMap.Result bytesBytesMultiHashMapResult, VectorMapJoinHashTableResult hashTableResult)
Copyright © 2017 The Apache Software Foundation. All rights reserved.