| Package | Description |
|---|---|
| org.apache.hadoop.hive.ql.exec |
Hive QL execution tasks, operators, functions and other handlers.
|
| org.apache.hadoop.hive.ql.exec.persistence | |
| org.apache.hadoop.hive.ql.exec.spark | |
| org.apache.hadoop.hive.ql.exec.vector | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized |
| Class and Description |
|---|
| HybridHashTableContainer
Hash table container that can have many partitions -- each partition has its own hashmap,
as well as row container for small table and big table.
|
| MapJoinBytesTableContainer
Table container that serializes keys and values using LazyBinarySerDe into
BytesBytesMultiHashMap, with very low memory overhead.
|
| MapJoinKey
The base class for MapJoinKey.
|
| MapJoinPersistableTableContainer |
| MapJoinTableContainer |
| MapJoinTableContainer.ReusableGetAdaptor
Retrieve rows from hashtable key by key, one key at a time, w/o copying the structures
for each key.
|
| MapJoinTableContainerSerDe |
| RowContainer
Simple persistent container for rows.
|
| Class and Description |
|---|
| AbstractMapJoinTableContainer |
| AbstractRowContainer |
| AbstractRowContainer.RowIterator |
| BytesBytesMultiHashMap
HashMap that maps byte arrays to byte arrays with limited functionality necessary for
MapJoin hash tables, with small memory overhead.
|
| BytesBytesMultiHashMap.KvSource
The source of keys and values to put into hashtable; avoids byte copying.
|
| BytesBytesMultiHashMap.Result
The result of looking up a key in the multi-hash map.
|
| HybridHashTableConf
This conf class is a wrapper of a list of HybridHashTableContainers and some common info shared
among them, which is used in n-way join (multiple small tables are involved).
|
| HybridHashTableContainer
Hash table container that can have many partitions -- each partition has its own hashmap,
as well as row container for small table and big table.
|
| HybridHashTableContainer.HashPartition
This class encapsulates the triplet together since they are closely related to each other
The triplet: hashmap (either in memory or on disk), small table container, big table container
|
| KeyValueContainer
An eager key/value container that puts every row directly to output stream.
|
| MapJoinBytesTableContainer.KeyValueHelper |
| MapJoinKey
The base class for MapJoinKey.
|
| MapJoinObjectSerDeContext |
| MapJoinPersistableTableContainer |
| MapJoinRowContainer |
| MapJoinTableContainer |
| MapJoinTableContainer.ReusableGetAdaptor
Retrieve rows from hashtable key by key, one key at a time, w/o copying the structures
for each key.
|
| MapJoinTableContainerDirectAccess |
| ObjectContainer
An eager object container that puts every row directly to output stream.
|
| RowContainer
Simple persistent container for rows.
|
| Class and Description |
|---|
| MapJoinTableContainer |
| Class and Description |
|---|
| MapJoinTableContainer |
| MapJoinTableContainer.ReusableGetAdaptor
Retrieve rows from hashtable key by key, one key at a time, w/o copying the structures
for each key.
|
| Class and Description |
|---|
| MapJoinTableContainer |
| MapJoinTableContainerSerDe |
| Class and Description |
|---|
| MapJoinKey
The base class for MapJoinKey.
|
| MapJoinObjectSerDeContext |
| MapJoinTableContainer |
| MapJoinTableContainer.ReusableGetAdaptor
Retrieve rows from hashtable key by key, one key at a time, w/o copying the structures
for each key.
|
| MapJoinTableContainerSerDe |
| Class and Description |
|---|
| MapJoinTableContainer |
| Class and Description |
|---|
| BytesBytesMultiHashMap.Result
The result of looking up a key in the multi-hash map.
|
| MapJoinTableContainer |
| MapJoinTableContainer.ReusableGetAdaptor
Retrieve rows from hashtable key by key, one key at a time, w/o copying the structures
for each key.
|
| MapJoinTableContainerDirectAccess |
| ReusableGetAdaptorDirectAccess |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.