| Package | Description |
|---|---|
| org.apache.hadoop.hive.ql.exec |
Hive QL execution tasks, operators, functions and other handlers.
|
| org.apache.hadoop.hive.ql.optimizer | |
| org.apache.hadoop.hive.ql.optimizer.physical | |
| org.apache.hadoop.hive.ql.optimizer.spark | |
| org.apache.hadoop.hive.ql.parse | |
| org.apache.hadoop.hive.ql.parse.spark | |
| org.apache.hadoop.hive.ql.plan |
| Modifier and Type | Method and Description |
|---|---|
static ReduceWork |
Utilities.getReduceWork(org.apache.hadoop.conf.Configuration conf) |
| Modifier and Type | Method and Description |
|---|---|
static void |
Utilities.createTmpDirs(org.apache.hadoop.conf.Configuration conf,
ReduceWork rWork)
Hive uses tmp directories to capture the output of each FileSinkOperator.
|
static void |
Utilities.setReduceWork(org.apache.hadoop.conf.Configuration conf,
ReduceWork work) |
static org.apache.hadoop.fs.Path |
Utilities.setReduceWork(org.apache.hadoop.conf.Configuration conf,
ReduceWork w,
org.apache.hadoop.fs.Path hiveScratchDir,
boolean useCache) |
| Modifier and Type | Method and Description |
|---|---|
static boolean |
GenMapRedUtils.needsTagging(ReduceWork rWork) |
static void |
GenMapRedUtils.setKeyAndValueDesc(ReduceWork plan,
Operator<? extends OperatorDesc> topOp)
set key and value descriptor.
|
static void |
GenMapRedUtils.setKeyAndValueDesc(ReduceWork work,
ReduceSinkOperator rs)
Set key and value descriptor
|
| Modifier and Type | Method and Description |
|---|---|
static void |
GenSparkSkewJoinProcessor.processSkewJoin(JoinOperator joinOp,
Task<? extends Serializable> currTask,
ReduceWork reduceWork,
ParseContext parseCtx) |
| Modifier and Type | Method and Description |
|---|---|
Map<Operator<?>,ReduceWork> |
SparkSkewJoinResolver.SparkSkewJoinProcCtx.getReducerToReduceWork() |
| Modifier and Type | Method and Description |
|---|---|
ReduceWork |
GenTezUtils.createReduceWork(GenTezProcContext context,
Operator<?> root,
TezWork tezWork) |
| Modifier and Type | Method and Description |
|---|---|
protected void |
GenTezUtils.setupReduceSink(GenTezProcContext context,
ReduceWork reduceWork,
ReduceSinkOperator reduceSink) |
| Modifier and Type | Field and Description |
|---|---|
Map<ReduceSinkOperator,ObjectPair<SparkEdgeProperty,ReduceWork>> |
GenSparkProcContext.leafOpToFollowingWorkInfo |
| Modifier and Type | Method and Description |
|---|---|
ReduceWork |
GenSparkUtils.createReduceWork(GenSparkProcContext context,
Operator<?> root,
SparkWork sparkWork) |
| Modifier and Type | Method and Description |
|---|---|
static SparkEdgeProperty |
GenSparkUtils.getEdgeProperty(ReduceSinkOperator reduceSink,
ReduceWork reduceWork) |
protected void |
GenSparkUtils.setupReduceSink(GenSparkProcContext context,
ReduceWork reduceWork,
ReduceSinkOperator reduceSink) |
| Modifier and Type | Method and Description |
|---|---|
ReduceWork |
MapredWork.getReduceWork() |
| Modifier and Type | Method and Description |
|---|---|
List<ReduceWork> |
SparkWork.getAllReduceWork() |
| Modifier and Type | Method and Description |
|---|---|
void |
MapredWork.setReduceWork(ReduceWork reduceWork) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.