| Package | Description |
|---|---|
| org.apache.hadoop.hive.ql.exec |
Hive QL execution tasks, operators, functions and other handlers.
|
| org.apache.hadoop.hive.ql.exec.mr | |
| org.apache.hadoop.hive.ql.exec.spark | |
| org.apache.hadoop.hive.ql.exec.tez | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin | |
| org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast |
| Modifier and Type | Method and Description |
|---|---|
ExecMapperContext |
Operator.getExecContext() |
| Modifier and Type | Method and Description |
|---|---|
void |
HashTableLoader.init(ExecMapperContext context,
MapredContext mrContext,
org.apache.hadoop.conf.Configuration hconf,
MapJoinOperator joinOp) |
protected org.apache.commons.lang3.tuple.Pair<MapJoinTableContainer[],MapJoinTableContainerSerDe[]> |
MapJoinOperator.loadHashTable(ExecMapperContext mapContext,
MapredContext mrContext) |
void |
Operator.passExecContext(ExecMapperContext execContext)
Pass the execContext reference to every child operator
|
static Object[] |
MapOperator.populateVirtualColumnValues(ExecMapperContext ctx,
List<VirtualColumn> vcs,
Object[] vcValues,
Deserializer deserializer) |
void |
Operator.setExecContext(ExecMapperContext execContext) |
| Modifier and Type | Method and Description |
|---|---|
void |
HashTableLoader.init(ExecMapperContext context,
MapredContext mrContext,
org.apache.hadoop.conf.Configuration hconf,
MapJoinOperator joinOp) |
void |
MapredLocalTask.setExecContext(ExecMapperContext execContext) |
| Modifier and Type | Method and Description |
|---|---|
void |
HashTableLoader.init(ExecMapperContext context,
MapredContext mrContext,
org.apache.hadoop.conf.Configuration hconf,
MapJoinOperator joinOp) |
| Modifier and Type | Method and Description |
|---|---|
void |
HashTableLoader.init(ExecMapperContext context,
MapredContext mrContext,
org.apache.hadoop.conf.Configuration hconf,
MapJoinOperator joinOp) |
| Modifier and Type | Method and Description |
|---|---|
protected org.apache.commons.lang3.tuple.Pair<MapJoinTableContainer[],MapJoinTableContainerSerDe[]> |
VectorMapJoinCommonOperator.loadHashTable(ExecMapperContext mapContext,
MapredContext mrContext) |
| Modifier and Type | Method and Description |
|---|---|
void |
VectorMapJoinFastHashTableLoader.init(ExecMapperContext context,
MapredContext mrContext,
org.apache.hadoop.conf.Configuration hconf,
MapJoinOperator joinOp) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.