Modifier and Type | Class and Description |
---|---|
class |
Operator<T extends OperatorDesc>
Base operator implementation.
|
class |
TerminalOperator<T extends OperatorDesc>
Terminal Operator Base Class.
|
Modifier and Type | Field and Description |
---|---|
protected T |
Operator.conf |
Modifier and Type | Field and Description |
---|---|
protected List<Operator<? extends OperatorDesc>> |
Operator.childOperators |
protected List<Operator<? extends OperatorDesc>> |
Operator.parentOperators |
Modifier and Type | Method and Description |
---|---|
static <T extends OperatorDesc> |
OperatorFactory.get(Class<T> opClass) |
static <T extends OperatorDesc> |
OperatorFactory.get(Class<T> opClass,
RowSchema rwsch) |
static <T extends OperatorDesc> |
OperatorFactory.get(T conf,
Operator<? extends OperatorDesc>... oplist)
Returns an operator given the conf and a list of children operators.
|
static <T extends OperatorDesc> |
OperatorFactory.get(T conf,
RowSchema rwsch,
Operator... oplist)
Returns an operator given the conf and a list of children operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
List<Operator<? extends OperatorDesc>> oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
Operator... oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
RowSchema rwsch,
List<Operator<? extends OperatorDesc>> oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
RowSchema rwsch,
Map<String,ExprNodeDesc> colExprMap,
List<Operator<? extends OperatorDesc>> oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
RowSchema rwsch,
Map<String,ExprNodeDesc> colExprMap,
Operator... oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
RowSchema rwsch,
Operator... oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getVectorOperator(Class<? extends Operator<?>> opClass,
T conf,
VectorizationContext vContext) |
static <T extends OperatorDesc> |
OperatorFactory.getVectorOperator(T conf,
VectorizationContext vContext) |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
TableScanOperator.clone() |
Operator<? extends OperatorDesc> |
Operator.clone() |
Operator<? extends OperatorDesc> |
Operator.cloneOp()
Clones only the operator.
|
Operator<? extends OperatorDesc> |
Operator.cloneRecursiveChildren()
Recursively clones all the children of the tree,
Fixes the pointers to children, parents and the pointers to itself coming from the children.
|
List<Operator<? extends OperatorDesc>> |
Operator.getChildOperators() |
List<Operator<? extends OperatorDesc>> |
Operator.getParentOperators() |
Operator<? extends OperatorDesc> |
Task.getReducer(MapWork work) |
Collection<Operator<? extends OperatorDesc>> |
Task.getTopOperators() |
Modifier and Type | Method and Description |
---|---|
void |
CommonMergeJoinOperator.cloneOriginalParentsList(List<Operator<? extends OperatorDesc>> opList) |
void |
Operator.OperatorFunc.func(Operator<? extends OperatorDesc> op) |
List<String> |
GroupByOperator.genColLists(HashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx) |
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
List<Operator<? extends OperatorDesc>> oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
RowSchema rwsch,
List<Operator<? extends OperatorDesc>> oplist)
Returns an operator given the conf and a list of parent operators.
|
static <T extends OperatorDesc> |
OperatorFactory.getAndMakeChild(T conf,
RowSchema rwsch,
Map<String,ExprNodeDesc> colExprMap,
List<Operator<? extends OperatorDesc>> oplist)
Returns an operator given the conf and a list of parent operators.
|
int |
CommonMergeJoinOperator.getTagForOperator(Operator<? extends OperatorDesc> op) |
static void |
OperatorFactory.makeChild(Operator<? extends OperatorDesc> ret,
Operator<? extends OperatorDesc>... oplist)
Returns an operator given the conf and a list of children operators.
|
void |
Operator.removeChild(Operator<? extends OperatorDesc> child) |
void |
Operator.removeChildAndAdoptItsChildren(Operator<? extends OperatorDesc> child)
Remove a child and add all of the child's children to the location of the child
|
void |
Operator.removeParent(Operator<? extends OperatorDesc> parent) |
void |
Operator.replaceChild(Operator<? extends OperatorDesc> child,
Operator<? extends OperatorDesc> newChild)
Replace one child with another at the same position.
|
void |
Operator.replaceChild(Operator<? extends OperatorDesc> child,
Operator<? extends OperatorDesc> newChild)
Replace one child with another at the same position.
|
void |
Operator.replaceParent(Operator<? extends OperatorDesc> parent,
Operator<? extends OperatorDesc> newParent)
Replace one parent with another at the same position.
|
void |
Operator.replaceParent(Operator<? extends OperatorDesc> parent,
Operator<? extends OperatorDesc> newParent)
Replace one parent with another at the same position.
|
void |
Operator.setChildOperators(List<Operator<? extends OperatorDesc>> childOperators) |
static void |
OperatorUtils.setChildrenCollector(List<Operator<? extends OperatorDesc>> childOperators,
Map<String,org.apache.hadoop.mapred.OutputCollector> outMap) |
static void |
OperatorUtils.setChildrenCollector(List<Operator<? extends OperatorDesc>> childOperators,
org.apache.hadoop.mapred.OutputCollector out) |
void |
Operator.setParentOperators(List<Operator<? extends OperatorDesc>> parentOperators) |
static String |
Operator.toString(Collection<Operator<? extends OperatorDesc>> top) |
Constructor and Description |
---|
SkewJoinHandler(CommonJoinOperator<? extends OperatorDesc> joinOp) |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
MapRedTask.getReducer(MapWork mapWork) |
Collection<Operator<? extends OperatorDesc>> |
MapredLocalTask.getTopOperators() |
Collection<Operator<? extends OperatorDesc>> |
ExecDriver.getTopOperators() |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
SparkTask.getReducer(MapWork mapWork) |
Modifier and Type | Field and Description |
---|---|
protected Operator<? extends OperatorDesc> |
MergeFileRecordProcessor.mergeOp |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
TezTask.getReducer(MapWork mapWork) |
Constructor and Description |
---|
VectorAppMasterEventOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorFileSinkOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorFilterOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorGroupByOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorLimitOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorMapJoinBaseOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorMapJoinOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorMapJoinOuterFilteredOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorReduceSinkOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorSelectOperator(VectorizationContext vContext,
OperatorDesc conf) |
VectorSMBMapJoinOperator(VectorizationContext vContext,
OperatorDesc conf) |
Modifier and Type | Method and Description |
---|---|
static List<Operator<? extends OperatorDesc>> |
HiveFileFormatUtils.doGetWorksFromPath(Map<String,ArrayList<String>> pathToAliases,
Map<String,Operator<? extends OperatorDesc>> aliasToWork,
org.apache.hadoop.fs.Path dir)
Get the list of operators from the operator tree that are needed for the path
|
Modifier and Type | Method and Description |
---|---|
static List<Operator<? extends OperatorDesc>> |
HiveFileFormatUtils.doGetWorksFromPath(Map<String,ArrayList<String>> pathToAliases,
Map<String,Operator<? extends OperatorDesc>> aliasToWork,
org.apache.hadoop.fs.Path dir)
Get the list of operators from the operator tree that are needed for the path
|
Modifier and Type | Class and Description |
---|---|
class |
MergeFileWork |
Modifier and Type | Class and Description |
---|---|
class |
PartialScanWork
Partial Scan Work.
|
Modifier and Type | Class and Description |
---|---|
class |
ColumnTruncateWork |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
GenMRProcContext.getCurrTopOp() |
List<Operator<? extends OperatorDesc>> |
GenMRProcContext.GenMRUnionCtx.getListTopOperators() |
LinkedHashMap<Operator<? extends OperatorDesc>,GenMRProcContext.GenMapRedCtx> |
GenMRProcContext.getMapCurrCtx() |
HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> |
GenMRProcContext.getOpTaskMap() |
Map<Operator<? extends OperatorDesc>,List<String>> |
ColumnPrunerProcCtx.getPrunedColLists() |
Modifier and Type | Method and Description |
---|---|
void |
GenMRProcContext.GenMRUnionCtx.addListTopOperators(Operator<? extends OperatorDesc> topOperator) |
protected boolean |
AbstractBucketJoinProc.checkConvertBucketMapJoin(BucketJoinProcCtx context,
Map<String,Operator<? extends OperatorDesc>> aliasToOpInfo,
Map<Byte,List<ExprNodeDesc>> keysMap,
String baseBigAlias,
List<String> joinAliases) |
static TableScanOperator |
GenMapRedUtils.createTemporaryFile(Operator<? extends OperatorDesc> parent,
Operator<? extends OperatorDesc> child,
org.apache.hadoop.fs.Path taskTmpDir,
TableDesc tt_desc,
ParseContext parseCtx)
Break the pipeline between parent and child, and then
output data generated by parent to a temporary file stored in taskTmpDir.
|
static TableScanOperator |
GenMapRedUtils.createTemporaryFile(Operator<? extends OperatorDesc> parent,
Operator<? extends OperatorDesc> child,
org.apache.hadoop.fs.Path taskTmpDir,
TableDesc tt_desc,
ParseContext parseCtx)
Break the pipeline between parent and child, and then
output data generated by parent to a temporary file stored in taskTmpDir.
|
List<String> |
ColumnPrunerProcCtx.genColLists(Operator<? extends OperatorDesc> curOp)
Creates the list of internal column names(these names are used in the
RowResolver and are different from the external column names) that are
needed in the subtree.
|
List<String> |
ColumnPrunerProcCtx.genColLists(Operator<? extends OperatorDesc> curOp,
Operator<? extends OperatorDesc> child)
Creates the list of internal column names(these names are used in the
RowResolver and are different from the external column names) that are
needed in the subtree.
|
List<String> |
ColumnPrunerProcCtx.genColLists(Operator<? extends OperatorDesc> curOp,
Operator<? extends OperatorDesc> child)
Creates the list of internal column names(these names are used in the
RowResolver and are different from the external column names) that are
needed in the subtree.
|
protected void |
SizeBasedBigTableSelectorForAutoSMJ.getListTopOps(Operator<? extends OperatorDesc> op,
List<TableScanOperator> topOps) |
List<String> |
ColumnPrunerProcCtx.getPrunedColList(Operator<? extends OperatorDesc> op) |
void |
ColumnPrunerProcCtx.handleFilterUnionChildren(Operator<? extends OperatorDesc> curOp)
If the input filter operator has direct child(ren) which are union operator,
and the filter's column is not the same as union's
create select operator between them.
|
void |
GenMRProcContext.setCurrTopOp(Operator<? extends OperatorDesc> currTopOp) |
static void |
GenMapRedUtils.setKeyAndValueDesc(ReduceWork plan,
Operator<? extends OperatorDesc> topOp)
set key and value descriptor.
|
void |
GenMRProcContext.GenMRUnionCtx.setListTopOperators(List<Operator<? extends OperatorDesc>> listTopOperators) |
void |
GenMRProcContext.setMapCurrCtx(LinkedHashMap<Operator<? extends OperatorDesc>,GenMRProcContext.GenMapRedCtx> mapCurrCtx) |
static void |
GenMapRedUtils.setMapWork(MapWork plan,
ParseContext parseCtx,
Set<ReadEntity> inputs,
PrunedPartitionList partsList,
Operator<? extends OperatorDesc> topOp,
String alias_id,
HiveConf conf,
boolean local)
initialize MapWork
|
void |
GenMRProcContext.setOpTaskMap(HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> opTaskMap) |
static void |
GenMapRedUtils.setTaskPlan(String alias_id,
Operator<? extends OperatorDesc> topOp,
Task<?> task,
boolean local,
GenMRProcContext opProcCtx)
set the current task in the mapredWork.
|
static void |
GenMapRedUtils.setTaskPlan(String alias_id,
Operator<? extends OperatorDesc> topOp,
Task<?> task,
boolean local,
GenMRProcContext opProcCtx,
PrunedPartitionList pList)
set the current task in the mapredWork.
|
static void |
GenMapRedUtils.setTaskPlan(String path,
String alias,
Operator<? extends OperatorDesc> topOp,
MapWork plan,
boolean local,
TableDesc tt_desc)
set the current task in the mapredWork.
|
Constructor and Description |
---|
GenMRProcContext(HiveConf conf,
HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> opTaskMap,
ParseContext parseCtx,
List<Task<MoveWork>> mvTask,
List<Task<? extends Serializable>> rootTasks,
LinkedHashMap<Operator<? extends OperatorDesc>,GenMRProcContext.GenMapRedCtx> mapCurrCtx,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs) |
GenMRProcContext(HiveConf conf,
HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> opTaskMap,
ParseContext parseCtx,
List<Task<MoveWork>> mvTask,
List<Task<? extends Serializable>> rootTasks,
LinkedHashMap<Operator<? extends OperatorDesc>,GenMRProcContext.GenMapRedCtx> mapCurrCtx,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs) |
Constructor and Description |
---|
HiveOpConverter(SemanticAnalyzer semanticAnalyzer,
HiveConf hiveConf,
UnparseTranslator unparseTranslator,
Map<String,Operator<? extends OperatorDesc>> topOps,
boolean strictMode) |
Modifier and Type | Method and Description |
---|---|
static List<Operator<? extends OperatorDesc>> |
CorrelationUtilities.findSiblingOperators(Operator<? extends OperatorDesc> op)
Find all sibling operators (which have the same child operator of op) of op (op
included).
|
Modifier and Type | Method and Description |
---|---|
static List<Operator<? extends OperatorDesc>> |
CorrelationUtilities.findSiblingOperators(Operator<? extends OperatorDesc> op)
Find all sibling operators (which have the same child operator of op) of op (op
included).
|
Modifier and Type | Method and Description |
---|---|
static Operator<? extends OperatorDesc> |
RewriteParseContextGenerator.generateOperatorTree(HiveConf conf,
String command)
Parse the input
String command and generate an operator tree. |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
ExprProcCtx.getInputOperator()
Gets the input operator.
|
protected static Operator<? extends OperatorDesc> |
OpProcFactory.getParent(Stack<Node> stack)
Returns the parent operator in the walk path to the current operator.
|
Modifier and Type | Method and Description |
---|---|
LineageInfo.Dependency |
LineageCtx.Index.getDependency(Operator<? extends OperatorDesc> op,
ColumnInfo col)
Gets the dependency for an operator, columninfo tuple.
|
static LineageInfo.Dependency |
ExprProcFactory.getExprDependency(LineageCtx lctx,
Operator<? extends OperatorDesc> inpOp,
ExprNodeDesc expr)
Gets the expression dependencies for the expression.
|
void |
LineageCtx.Index.mergeDependency(Operator<? extends OperatorDesc> op,
ColumnInfo ci,
LineageInfo.Dependency dep)
Merges the new dependencies in dep to the existing dependencies
of (op, ci).
|
void |
LineageCtx.Index.putDependency(Operator<? extends OperatorDesc> op,
ColumnInfo col,
LineageInfo.Dependency dep)
Puts the dependency for an operator, columninfo tuple.
|
Constructor and Description |
---|
ExprProcCtx(LineageCtx lctx,
Operator<? extends OperatorDesc> inpOp)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
PcrOpWalkerCtx.OpToDeleteInfo.getParent() |
Constructor and Description |
---|
PcrOpWalkerCtx.OpToDeleteInfo(Operator<? extends OperatorDesc> parent,
FilterOperator operator) |
Modifier and Type | Method and Description |
---|---|
Map<MapJoinOperator,List<Operator<? extends OperatorDesc>>> |
MapJoinResolver.LocalMapJoinProcCtx.getDirectWorks() |
List<Operator<? extends OperatorDesc>> |
MapJoinResolver.LocalMapJoinProcCtx.getDummyParentOp() |
protected static Operator<? extends OperatorDesc> |
BucketingSortingOpProcFactory.getParent(Stack<Node> stack)
Returns the parent operator in the walk path to the current operator.
|
Modifier and Type | Method and Description |
---|---|
void |
MapJoinResolver.LocalMapJoinProcCtx.addDirectWorks(MapJoinOperator mapJoinOp,
List<Operator<? extends OperatorDesc>> directOperators) |
void |
MapJoinResolver.LocalMapJoinProcCtx.addDummyParentOp(Operator<? extends OperatorDesc> op) |
List<BucketingSortingCtx.BucketCol> |
BucketingSortingCtx.getBucketedCols(Operator<? extends OperatorDesc> op) |
List<BucketingSortingCtx.SortCol> |
BucketingSortingCtx.getSortedCols(Operator<? extends OperatorDesc> op) |
void |
LocalMapJoinProcFactory.LocalMapJoinProcessor.hasGroupBy(Operator<? extends OperatorDesc> mapJoinOp,
MapJoinResolver.LocalMapJoinProcCtx localMapJoinProcCtx) |
Boolean |
Vectorizer.nonVectorizableChildOfGroupBy(Operator<? extends OperatorDesc> op) |
protected Object |
BucketingSortingOpProcFactory.GroupByInferrer.processGroupBy(Operator<? extends OperatorDesc> parent,
GroupByOperator gop,
BucketingSortingCtx bctx)
Process a GroupByOperator to determine which if any columns the output is bucketed and
sorted by, assumes the columns output by the parent which are bucketed and sorted have
already been determined.
|
void |
BucketingSortingCtx.setBucketedCols(Operator<? extends OperatorDesc> op,
List<BucketingSortingCtx.BucketCol> bucketCols) |
void |
MapJoinResolver.LocalMapJoinProcCtx.setDirectWorks(Map<MapJoinOperator,List<Operator<? extends OperatorDesc>>> directWorks) |
void |
MapJoinResolver.LocalMapJoinProcCtx.setDummyParentOp(List<Operator<? extends OperatorDesc>> op) |
void |
BucketingSortingCtx.setSortedCols(Operator<? extends OperatorDesc> op,
List<BucketingSortingCtx.SortCol> sortedCols) |
Modifier and Type | Field and Description |
---|---|
Operator<? extends OperatorDesc> |
GenTezProcContext.currentRootOperator |
protected LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> |
SemanticAnalyzer.opParseCtx |
Operator<? extends OperatorDesc> |
GenTezProcContext.parentOfRoot |
Deque<Operator<? extends OperatorDesc>> |
OptimizeTezProcContext.rootOperators |
protected HashMap<String,Operator<? extends OperatorDesc>> |
SemanticAnalyzer.topOps |
Modifier and Type | Method and Description |
---|---|
<T extends OperatorDesc> |
SemanticAnalyzer.putOpInsertMap(Operator<T> op,
RowResolver rr) |
Modifier and Type | Method and Description |
---|---|
Map<String,Operator<? extends OperatorDesc>> |
QBJoinTree.getAliasToOpInfo() |
Map<Operator<? extends OperatorDesc>,Map<String,List<String>>> |
TableAccessInfo.getOperatorToTableAccessMap() |
HashMap<String,Operator<? extends OperatorDesc>> |
ParseContext.getTopOps() |
Modifier and Type | Method and Description |
---|---|
void |
TableAccessInfo.add(Operator<? extends OperatorDesc> op,
Map<String,List<String>> tableToKeysMap) |
void |
TableAccessCtx.addOperatorTableAccess(Operator<? extends OperatorDesc> op,
Map<String,List<String>> tableToKeysMap) |
static TableScanOperator |
TableAccessAnalyzer.genRootTableScan(Operator<? extends OperatorDesc> op,
List<String> keyNames)
This method traces up from the given operator to the root
of the operator graph until a TableScanOperator is reached.
|
void |
QBJoinTree.setAliasToOpInfo(Map<String,Operator<? extends OperatorDesc>> aliasToOpInfo) |
void |
OptimizeTezProcContext.setRootOperators(Deque<Operator<? extends OperatorDesc>> roots) |
void |
ParseContext.setTopOps(HashMap<String,Operator<? extends OperatorDesc>> topOps) |
protected void |
GenTezUtils.setupMapWork(MapWork mapWork,
GenTezProcContext context,
PrunedPartitionList partitions,
Operator<? extends OperatorDesc> root,
String alias) |
Modifier and Type | Field and Description |
---|---|
Operator<? extends OperatorDesc> |
GenSparkProcContext.currentRootOperator |
Operator<? extends OperatorDesc> |
GenSparkProcContext.parentOfRoot |
Map<String,Operator<? extends OperatorDesc>> |
GenSparkProcContext.topOps |
Modifier and Type | Method and Description |
---|---|
Deque<Operator<? extends OperatorDesc>> |
OptimizeSparkProcContext.getRootOperators() |
Modifier and Type | Method and Description |
---|---|
protected void |
GenSparkUtils.setupMapWork(MapWork mapWork,
GenSparkProcContext context,
PrunedPartitionList partitions,
Operator<? extends OperatorDesc> root,
String alias) |
Constructor and Description |
---|
GenSparkProcContext(HiveConf conf,
ParseContext parseContext,
List<Task<MoveWork>> moveTask,
List<Task<? extends Serializable>> rootTasks,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
Map<String,Operator<? extends OperatorDesc>> topOps) |
OptimizeSparkProcContext(HiveConf conf,
ParseContext parseContext,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
Deque<Operator<? extends OperatorDesc>> rootOperators) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractOperatorDesc |
class |
AppMasterEventDesc |
class |
BaseWork
BaseWork.
|
class |
CollectDesc
CollectDesc.
|
class |
CommonMergeJoinDesc |
class |
DemuxDesc
Demux operator descriptor implementation.
|
class |
DummyStoreDesc
Dummy Store Desc.
|
class |
DynamicPruningEventDesc |
class |
FileMergeDesc |
class |
FileSinkDesc
FileSinkDesc.
|
class |
FilterDesc
FilterDesc.
|
class |
ForwardDesc
ForwardDesc.
|
class |
GroupByDesc
GroupByDesc.
|
class |
HashTableDummyDesc
HashTable Dummy Descriptor implementation.
|
class |
HashTableSinkDesc
Map Join operator Descriptor implementation.
|
class |
JoinDesc
Join operator Descriptor implementation.
|
class |
LateralViewForwardDesc
LateralViewForwardDesc.
|
class |
LateralViewJoinDesc
LateralViewJoinDesc.
|
class |
LimitDesc
LimitDesc.
|
class |
ListSinkDesc
description for ListSinkOperator, just for explain result.
|
class |
MapJoinDesc
Map Join operator Descriptor implementation.
|
class |
MapredWork
MapredWork.
|
class |
MapWork
MapWork represents all the information used to run a map task on the cluster.
|
class |
MergeJoinWork |
class |
MuxDesc
Mux operator descriptor implementation..
|
class |
OrcFileMergeDesc
ORC fast file merge operator descriptor.
|
class |
PTFDesc |
class |
RCFileMergeDesc
Descriptor for Fast file merge RC file operator.
|
class |
ReduceSinkDesc
ReduceSinkDesc.
|
class |
ReduceWork
ReduceWork represents all the information used to run a reduce task on the cluster.
|
class |
ScriptDesc
ScriptDesc.
|
class |
SelectDesc
SelectDesc.
|
class |
SMBJoinDesc |
class |
SparkHashTableSinkDesc
Map Join operator Descriptor implementation.
|
class |
SparkWork
This class encapsulates all the work objects that can be executed
in a single Spark job.
|
class |
TableScanDesc
Table Scan Descriptor Currently, data is only read from a base source as part
of map-reduce framework.
|
class |
TezWork
TezWork.
|
class |
UDTFDesc
All member variables should have a setters and getters of the form get
|
class |
UnionDesc
unionDesc is a empty class currently.
|
class |
UnionWork
Simple wrapper for union all cases.
|
Modifier and Type | Method and Description |
---|---|
Map<String,Operator<? extends OperatorDesc>> |
JoinDesc.getAliasToOpInfo() |
LinkedHashMap<String,Operator<? extends OperatorDesc>> |
MapWork.getAliasToWork() |
LinkedHashMap<String,Operator<? extends OperatorDesc>> |
MapredLocalWork.getAliasToWork() |
Map<MapJoinOperator,List<Operator<? extends OperatorDesc>>> |
MapredLocalWork.getDirectFetchOp() |
List<Operator<? extends OperatorDesc>> |
MapredLocalWork.getDummyParentOp() |
Operator<? extends OperatorDesc> |
ExprNodeDynamicListDesc.getSource() |
Modifier and Type | Method and Description |
---|---|
MapredLocalWork |
MapredLocalWork.extractDirectWorks(Map<MapJoinOperator,List<Operator<? extends OperatorDesc>>> directWorks) |
void |
JoinDesc.setAliasToOpInfo(Map<String,Operator<? extends OperatorDesc>> aliasToOpInfo) |
void |
MapWork.setAliasToWork(LinkedHashMap<String,Operator<? extends OperatorDesc>> aliasToWork) |
void |
MapredLocalWork.setAliasToWork(LinkedHashMap<String,Operator<? extends OperatorDesc>> aliasToWork) |
void |
MapredLocalWork.setDirectFetchOp(Map<MapJoinOperator,List<Operator<? extends OperatorDesc>>> op) |
void |
MapredLocalWork.setDummyParentOp(List<Operator<? extends OperatorDesc>> op) |
void |
ExprNodeDynamicListDesc.setSource(Operator<? extends OperatorDesc> source) |
Constructor and Description |
---|
ExprNodeDynamicListDesc(TypeInfo typeInfo,
Operator<? extends OperatorDesc> source,
int keyIndex) |
MapredLocalWork(LinkedHashMap<String,Operator<? extends OperatorDesc>> aliasToWork,
LinkedHashMap<String,FetchWork> aliasToFetchWork) |
MuxDesc(List<Operator<? extends OperatorDesc>> ops) |
Modifier and Type | Method and Description |
---|---|
Operator<? extends OperatorDesc> |
ExprWalkerInfo.getOp() |
Modifier and Type | Method and Description |
---|---|
static ExprWalkerInfo |
ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext,
Operator<? extends OperatorDesc> op,
ExprNodeDesc pred) |
static ExprWalkerInfo |
ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext,
Operator<? extends OperatorDesc> op,
List<ExprNodeDesc> preds)
Extracts pushdown predicates from the given list of predicate expression.
|
ExprWalkerInfo |
OpWalkerInfo.getPrunedPreds(Operator<? extends OperatorDesc> op) |
ExprWalkerInfo |
OpWalkerInfo.putPrunedPreds(Operator<? extends OperatorDesc> op,
ExprWalkerInfo value) |
Constructor and Description |
---|
ExprWalkerInfo(Operator<? extends OperatorDesc> op) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.