|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of Node in org.apache.hadoop.hive.ql.exec |
---|
Classes in org.apache.hadoop.hive.ql.exec that implement Node | |
---|---|
class |
AbstractMapJoinOperator<T extends MapJoinDesc>
|
class |
CollectOperator
Buffers rows emitted by other operators. |
class |
ColumnStatsTask
ColumnStatsTask implementation. |
class |
CommonJoinOperator<T extends JoinDesc>
Join operator implementation. |
class |
ConditionalTask
Conditional Task implementation. |
class |
CopyTask
CopyTask implementation. |
class |
DDLTask
DDLTask implementation. |
class |
DemuxOperator
DemuxOperator is an operator used by MapReduce Jobs optimized by CorrelationOptimizer. |
class |
DependencyCollectionTask
DependencyCollectionTask. |
class |
DummyStoreOperator
For SortMerge joins, this is a dummy operator, which stores the row for the small table before it reaches the sort merge join operator. |
class |
ExplainTask
ExplainTask implementation. |
class |
ExtractOperator
Extract operator implementation Extracts a subobject and passes that on. |
class |
FetchTask
FetchTask implementation. |
class |
FileSinkOperator
File Sink operator implementation. |
class |
FilterOperator
Filter operator implementation. |
class |
ForwardOperator
Forward Operator Just forwards. |
class |
FunctionTask
FunctionTask. |
class |
GroupByOperator
GroupBy operator implementation. |
class |
HashTableDummyOperator
|
class |
HashTableSinkOperator
|
class |
JoinOperator
Join operator implementation. |
class |
LateralViewForwardOperator
LateralViewForwardOperator. |
class |
LateralViewJoinOperator
The lateral view join operator is used for FROM src LATERAL VIEW udtf()... |
class |
LimitOperator
Limit operator implementation Limits the number of rows to be passed on. |
class |
ListSinkOperator
For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator. |
class |
MapJoinOperator
Map side Join operator implementation. |
class |
MapOperator
Map operator. |
class |
MoveTask
MoveTask implementation. |
class |
MuxOperator
MuxOperator is used in the Reduce side of MapReduce jobs optimized by Correlation Optimizer. |
class |
Operator<T extends OperatorDesc>
Base operator implementation. |
class |
PTFOperator
|
class |
ReduceSinkOperator
Reduce Sink Operator sends output to the reduce stage. |
class |
ScriptOperator
ScriptOperator. |
class |
SelectOperator
Select operator implementation. |
class |
SMBMapJoinOperator
Sorted Merge Map Join Operator. |
class |
StatsTask
StatsTask implementation. |
class |
TableScanOperator
Table Scan Operator If the data is coming from the map-reduce framework, just forward it. |
class |
Task<T extends Serializable>
Task implementation. |
class |
TerminalOperator<T extends OperatorDesc>
Terminal Operator Base Class. |
class |
UDTFOperator
UDTFOperator. |
class |
UnionOperator
Union Operator Just forwards. |
Methods in org.apache.hadoop.hive.ql.exec that return types with arguments of type Node | |
---|---|
ArrayList<Node> |
Operator.getChildren()
Implements the getChildren function for the Node Interface. |
List<? extends Node> |
Task.getChildren()
|
Uses of Node in org.apache.hadoop.hive.ql.exec.mr |
---|
Classes in org.apache.hadoop.hive.ql.exec.mr that implement Node | |
---|---|
class |
ExecDriver
ExecDriver is the central class in co-ordinating execution of any map-reduce task. |
class |
MapredLocalTask
MapredLocalTask represents any local work (i.e.: client side work) that hive needs to execute. |
class |
MapRedTask
Extension of ExecDriver: - can optionally spawn a map-reduce task from a separate jvm - will make last minute adjustments to map-reduce job parameters, viz: * estimating number of reducers * estimating whether job should run locally |
Uses of Node in org.apache.hadoop.hive.ql.index |
---|
Classes in org.apache.hadoop.hive.ql.index that implement Node | |
---|---|
class |
IndexMetadataChangeTask
|
Uses of Node in org.apache.hadoop.hive.ql.io.rcfile.merge |
---|
Classes in org.apache.hadoop.hive.ql.io.rcfile.merge that implement Node | |
---|---|
class |
BlockMergeTask
|
Uses of Node in org.apache.hadoop.hive.ql.io.rcfile.stats |
---|
Classes in org.apache.hadoop.hive.ql.io.rcfile.stats that implement Node | |
---|---|
class |
PartialScanTask
PartialScanTask. |
Uses of Node in org.apache.hadoop.hive.ql.io.rcfile.truncate |
---|
Classes in org.apache.hadoop.hive.ql.io.rcfile.truncate that implement Node | |
---|---|
class |
ColumnTruncateTask
|
Uses of Node in org.apache.hadoop.hive.ql.lib |
---|
Fields in org.apache.hadoop.hive.ql.lib with type parameters of type Node | |
---|---|
protected Stack<Node> |
TaskGraphWalker.opStack
|
protected Stack<Node> |
DefaultGraphWalker.opStack
|
Methods in org.apache.hadoop.hive.ql.lib that return Node | |
---|---|
static Node |
Utils.getNthAncestor(Stack<Node> st,
int n)
Gets the nth ancestor (the parent being the 1st ancestor) in the traversal path. |
Methods in org.apache.hadoop.hive.ql.lib that return types with arguments of type Node | |
---|---|
List<? extends Node> |
Node.getChildren()
Gets the vector of children nodes. |
Set<Node> |
TaskGraphWalker.getDispatchedList()
|
Set<Node> |
DefaultGraphWalker.getDispatchedList()
|
List<Node> |
TaskGraphWalker.getToWalk()
|
List<Node> |
DefaultGraphWalker.getToWalk()
|
Methods in org.apache.hadoop.hive.ql.lib with parameters of type Node | ||
---|---|---|
void |
TaskGraphWalker.TaskGraphWalkerContext.addToDispatchList(Node dispatchedObj)
|
|
void |
TaskGraphWalker.dispatch(Node nd,
Stack<Node> ndStack)
|
|
void |
DefaultGraphWalker.dispatch(Node nd,
Stack<Node> ndStack)
Dispatch the current operator. |
|
Object |
Dispatcher.dispatch(Node nd,
Stack<Node> stack,
Object... nodeOutputs)
Dispatcher function. |
|
Object |
DefaultRuleDispatcher.dispatch(Node nd,
Stack<Node> ndStack,
Object... nodeOutputs)
Dispatcher function. |
|
void |
TaskGraphWalker.dispatch(Node nd,
Stack<Node> ndStack,
TaskGraphWalker.TaskGraphWalkerContext walkerCtx)
Dispatch the current operator. |
|
|
DefaultGraphWalker.dispatchAndReturn(Node nd,
Stack<Node> ndStack)
Returns dispatch result |
|
Object |
NodeProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Generic process for all ops that don't have specific implementations. |
|
void |
PreOrderWalker.walk(Node nd)
Walk the current operator and its descendants. |
|
void |
TaskGraphWalker.walk(Node nd)
walk the current operator and its descendants. |
|
void |
DefaultGraphWalker.walk(Node nd)
walk the current operator and its descendants. |
Method parameters in org.apache.hadoop.hive.ql.lib with type arguments of type Node | ||
---|---|---|
int |
RuleRegExp.cost(Stack<Node> stack)
This function returns the cost of the rule for the specified stack. |
|
int |
RuleExactMatch.cost(Stack<Node> stack)
This function returns the cost of the rule for the specified stack. |
|
int |
Rule.cost(Stack<Node> stack)
|
|
void |
TaskGraphWalker.dispatch(Node nd,
Stack<Node> ndStack)
|
|
void |
DefaultGraphWalker.dispatch(Node nd,
Stack<Node> ndStack)
Dispatch the current operator. |
|
Object |
Dispatcher.dispatch(Node nd,
Stack<Node> stack,
Object... nodeOutputs)
Dispatcher function. |
|
Object |
DefaultRuleDispatcher.dispatch(Node nd,
Stack<Node> ndStack,
Object... nodeOutputs)
Dispatcher function. |
|
void |
TaskGraphWalker.dispatch(Node nd,
Stack<Node> ndStack,
TaskGraphWalker.TaskGraphWalkerContext walkerCtx)
Dispatch the current operator. |
|
|
DefaultGraphWalker.dispatchAndReturn(Node nd,
Stack<Node> ndStack)
Returns dispatch result |
|
static
|
Utils.findNode(Stack<Node> stack,
Class<T> target)
Find the first node of a type from ancestor stack, starting from parents. |
|
static Node |
Utils.getNthAncestor(Stack<Node> st,
int n)
Gets the nth ancestor (the parent being the 1st ancestor) in the traversal path. |
|
Object |
NodeProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Generic process for all ops that don't have specific implementations. |
|
void |
GraphWalker.startWalking(Collection<Node> startNodes,
HashMap<Node,Object> nodeOutput)
starting point for walking. |
|
void |
GraphWalker.startWalking(Collection<Node> startNodes,
HashMap<Node,Object> nodeOutput)
starting point for walking. |
|
void |
TaskGraphWalker.startWalking(Collection<Node> startNodes,
HashMap<Node,Object> nodeOutput)
starting point for walking. |
|
void |
TaskGraphWalker.startWalking(Collection<Node> startNodes,
HashMap<Node,Object> nodeOutput)
starting point for walking. |
|
void |
DefaultGraphWalker.startWalking(Collection<Node> startNodes,
HashMap<Node,Object> nodeOutput)
starting point for walking. |
|
void |
DefaultGraphWalker.startWalking(Collection<Node> startNodes,
HashMap<Node,Object> nodeOutput)
starting point for walking. |
Constructor parameters in org.apache.hadoop.hive.ql.lib with type arguments of type Node | |
---|---|
TaskGraphWalker.TaskGraphWalkerContext(HashMap<Node,Object> reMap)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer |
---|
Methods in org.apache.hadoop.hive.ql.optimizer that return types with arguments of type Node | |
---|---|
static Map<Node,Object> |
PrunerUtils.walkExprTree(ExprNodeDesc pred,
NodeProcessorCtx ctx,
NodeProcessor colProc,
NodeProcessor fieldProc,
NodeProcessor genFuncProc,
NodeProcessor defProc)
Walk expression tree for pruner generation. |
Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type Node | |
---|---|
Object |
GenMRTableScan1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Table Sink encountered. |
Object |
SkewJoinOptimizer.SkewJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRRedSink3.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Reduce Scan encountered. |
Object |
PrunerExpressionOperatorFactory.GenericFuncExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerExpressionOperatorFactory.FieldExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerExpressionOperatorFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerExpressionOperatorFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRUnion1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Union Operator encountered . |
Object |
BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRRedSink2.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Reduce Scan encountered. |
Object |
SamplePruner.FilterPPR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
SamplePruner.DefaultPPR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerOperatorFactory.FilterPruner.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerOperatorFactory.DefaultPruner.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketMapjoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerFilterProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerGroupByProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerPTFProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerDefaultProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerTableScanProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerLateralViewForwardProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerSelectProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerMapJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
abstract Object |
AbstractBucketJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GroupByOptimizer.SortGroupByProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GroupByOptimizer.SortGroupBySkewProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
MapJoinProcessor.CurrentMapJoin.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Store the current mapjoin in the context. |
Object |
MapJoinProcessor.MapJoinFS.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Store the current mapjoin in a list of mapjoins followed by a filesink. |
Object |
MapJoinProcessor.MapJoinDefault.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Store the mapjoin in a rejected list. |
Object |
MapJoinProcessor.Default.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Nothing to do. |
Object |
SortedMergeBucketMapjoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
SortedMergeJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRRedSink1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Reduce Sink encountered. |
Object |
GenMRFileSink1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
File Sink Operator encountered. |
Object |
GenMROperator.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Reduce Scan encountered. |
abstract Object |
AbstractSMBJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
void |
ColumnPruner.ColumnPrunerWalker.walk(Node nd)
Walk the given operator. |
Method parameters in org.apache.hadoop.hive.ql.optimizer with type arguments of type Node | |
---|---|
protected boolean |
AbstractSMBJoinProc.canConvertBucketMapJoinToSMBJoin(MapJoinOperator mapJoinOp,
Stack<Node> stack,
SortBucketJoinProcCtx smbJoinContext,
Object... nodeOutputs)
|
protected GroupByOptimizer.GroupByOptimizerSortMatch |
GroupByOptimizer.SortGroupByProcessor.checkSortGroupBy(Stack<Node> stack,
GroupByOperator groupByOp)
|
static int |
MapJoinFactory.getPositionParent(AbstractMapJoinOperator<? extends MapJoinDesc> op,
Stack<Node> stack)
|
Object |
GenMRTableScan1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Table Sink encountered. |
Object |
SkewJoinOptimizer.SkewJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRRedSink3.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Reduce Scan encountered. |
Object |
PrunerExpressionOperatorFactory.GenericFuncExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerExpressionOperatorFactory.FieldExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerExpressionOperatorFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerExpressionOperatorFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRUnion1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Union Operator encountered . |
Object |
BucketingSortingReduceSinkOptimizer.BucketSortReduceSinkProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRRedSink2.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Reduce Scan encountered. |
Object |
SamplePruner.FilterPPR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
SamplePruner.DefaultPPR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerOperatorFactory.FilterPruner.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PrunerOperatorFactory.DefaultPruner.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketMapjoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerFilterProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerGroupByProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerPTFProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerDefaultProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerTableScanProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerLateralViewForwardProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerSelectProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
ColumnPrunerProcFactory.ColumnPrunerMapJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
abstract Object |
AbstractBucketJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GroupByOptimizer.SortGroupByProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GroupByOptimizer.SortGroupBySkewProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
MapJoinProcessor.CurrentMapJoin.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Store the current mapjoin in the context. |
Object |
MapJoinProcessor.MapJoinFS.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Store the current mapjoin in a list of mapjoins followed by a filesink. |
Object |
MapJoinProcessor.MapJoinDefault.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Store the mapjoin in a rejected list. |
Object |
MapJoinProcessor.Default.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Nothing to do. |
Object |
SortedMergeBucketMapjoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
SortedMergeJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
GenMRRedSink1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
Reduce Sink encountered. |
Object |
GenMRFileSink1.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx opProcCtx,
Object... nodeOutputs)
File Sink Operator encountered. |
Object |
GenMROperator.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Reduce Scan encountered. |
abstract Object |
AbstractSMBJoinProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
protected void |
GroupByOptimizer.SortGroupByProcessor.processGroupBy(GroupByOptimizer.GroupByOptimizerContext ctx,
Stack<Node> stack,
GroupByOperator groupByOp,
int depth)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer.correlation |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.correlation with parameters of type Node | |
---|---|
Object |
ReduceSinkDeDuplication.AbsctractReducerReducerProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.optimizer.correlation with type arguments of type Node | |
---|---|
Object |
ReduceSinkDeDuplication.AbsctractReducerReducerProc.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer.lineage |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.lineage with parameters of type Node | |
---|---|
Object |
OpProcFactory.TransformLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.TableScanLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.JoinLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.LateralViewJoinLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.SelectLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.GroupByLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.UnionLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.ReduceSinkLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.DefaultLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprProcFactory.GenericExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.optimizer.lineage with type arguments of type Node | |
---|---|
protected static Operator<? extends OperatorDesc> |
OpProcFactory.getParent(Stack<Node> stack)
Returns the parent operator in the walk path to the current operator. |
Object |
OpProcFactory.TransformLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.TableScanLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.JoinLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.LateralViewJoinLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.SelectLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.GroupByLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.UnionLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.ReduceSinkLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.DefaultLineage.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprProcFactory.GenericExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer.pcr |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.pcr with parameters of type Node | |
---|---|
Object |
PcrExprProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrExprProcFactory.GenericFuncExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrExprProcFactory.FieldExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrExprProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrOpProcFactory.FilterPCR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrOpProcFactory.DefaultPCR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.optimizer.pcr with type arguments of type Node | |
---|---|
Object |
PcrExprProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrExprProcFactory.GenericFuncExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrExprProcFactory.FieldExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrExprProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrOpProcFactory.FilterPCR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
PcrOpProcFactory.DefaultPCR.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer.physical |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type Node | |
---|---|
Object |
AbstractJoinTaskDispatcher.dispatch(Node nd,
Stack<Node> stack,
Object... nodeOutputs)
|
Object |
LocalMapJoinProcFactory.MapJoinFollowedByGroupByProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
LocalMapJoinProcFactory.LocalMapJoinProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.DefaultInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.JoinInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.SelectInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.FileSinkInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.ExtractInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.MultiGroupByInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.GroupByInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.ForwardingInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
SkewJoinProcFactory.SkewJoinJoinProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
SkewJoinProcFactory.SkewJoinDefaultProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.optimizer.physical with type arguments of type Node | |
---|---|
Object |
AbstractJoinTaskDispatcher.dispatch(Node nd,
Stack<Node> stack,
Object... nodeOutputs)
|
protected static Operator<? extends OperatorDesc> |
BucketingSortingOpProcFactory.getParent(Stack<Node> stack)
Returns the parent operator in the walk path to the current operator. |
Object |
LocalMapJoinProcFactory.MapJoinFollowedByGroupByProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
LocalMapJoinProcFactory.LocalMapJoinProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.DefaultInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.JoinInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.SelectInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.FileSinkInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.ExtractInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.MultiGroupByInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.GroupByInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
BucketingSortingOpProcFactory.ForwardingInferrer.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
SkewJoinProcFactory.SkewJoinJoinProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
SkewJoinProcFactory.SkewJoinDefaultProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer.physical.index |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.physical.index with parameters of type Node | |
---|---|
Object |
IndexWhereTaskDispatcher.dispatch(Node nd,
Stack<Node> stack,
Object... nodeOutputs)
|
Object |
IndexWhereProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.optimizer.physical.index with type arguments of type Node | |
---|---|
Object |
IndexWhereTaskDispatcher.dispatch(Node nd,
Stack<Node> stack,
Object... nodeOutputs)
|
Object |
IndexWhereProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.optimizer.unionproc |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.unionproc with parameters of type Node | |
---|---|
Object |
UnionProcFactory.MapRedUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.MapUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.UnknownUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.UnionNoProcessFile.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.NoUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.optimizer.unionproc with type arguments of type Node | |
---|---|
static int |
UnionProcFactory.getPositionParent(UnionOperator union,
Stack<Node> stack)
|
Object |
UnionProcFactory.MapRedUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.MapUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.UnknownUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.UnionNoProcessFile.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
UnionProcFactory.NoUnion.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.parse |
---|
Classes in org.apache.hadoop.hive.ql.parse that implement Node | |
---|---|
class |
ASTErrorNode
|
class |
ASTNode
|
Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type Node | |
---|---|
ArrayList<Node> |
ASTNode.getChildren()
|
Methods in org.apache.hadoop.hive.ql.parse with parameters of type Node | |
---|---|
protected List<String> |
BaseSemanticAnalyzer.getSkewedValuesFromASTNode(Node node)
Retrieve skewed values from ASTNode. |
Object |
PrintOpTreeProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.NullExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.NumExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.StrExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.BoolExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.DateExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TableAccessAnalyzer.GroupByProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TableAccessAnalyzer.JoinProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
static ExprNodeDesc |
TypeCheckProcFactory.processGByExpr(Node nd,
Object procCtx)
Function to do groupby subexpression elimination. |
void |
GenMapRedWalker.walk(Node nd)
Walk the given operator. |
Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type Node | |
---|---|
Object |
PrintOpTreeProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx ctx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.NullExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.NumExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.StrExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.BoolExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.DateExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TypeCheckProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TableAccessAnalyzer.GroupByProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
TableAccessAnalyzer.JoinProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.plan |
---|
Classes in org.apache.hadoop.hive.ql.plan that implement Node | |
---|---|
class |
ExprNodeColumnDesc
ExprNodeColumnDesc. |
class |
ExprNodeColumnListDesc
Dummy desc only for populating TOK_ALLCOLREF and should not be used outside of TypeCheckProcFactory |
class |
ExprNodeConstantDesc
A constant expression. |
class |
ExprNodeDesc
ExprNodeDesc. |
class |
ExprNodeFieldDesc
ExprNodeFieldDesc. |
class |
ExprNodeGenericFuncDesc
Describes a GenericFunc node. |
class |
ExprNodeNullDesc
ExprNodeNullDesc. |
Uses of Node in org.apache.hadoop.hive.ql.ppd |
---|
Methods in org.apache.hadoop.hive.ql.ppd with parameters of type Node | |
---|---|
ExprNodeDesc |
ExprWalkerInfo.getConvertedNode(Node nd)
|
RowResolver |
OpWalkerInfo.getRowResolver(Node op)
|
protected void |
OpProcFactory.DefaultPPD.logExpr(Node nd,
ExprWalkerInfo ewi)
|
protected ExprWalkerInfo |
OpProcFactory.DefaultPPD.mergeChildrenPred(Node nd,
OpWalkerInfo owi,
Set<String> excludedAliases,
boolean ignoreAliases)
|
protected boolean |
OpProcFactory.DefaultPPD.mergeWithChildrenPred(Node nd,
OpWalkerInfo owi,
ExprWalkerInfo ewi,
Set<String> aliases,
boolean ignoreAliases)
Take current operators pushdown predicates and merges them with children's pushdown predicates. |
Object |
OpProcFactory.ScriptPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.UDTFPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.LateralViewForwardPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.TableScanPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.FilterPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.JoinPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.ReduceSinkPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.DefaultPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprWalkerProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Converts the reference from child row resolver to current row resolver. |
Object |
ExprWalkerProcFactory.FieldExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprWalkerProcFactory.GenericFuncExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprWalkerProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Method parameters in org.apache.hadoop.hive.ql.ppd with type arguments of type Node | |
---|---|
Object |
OpProcFactory.ScriptPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.UDTFPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.LateralViewForwardPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.TableScanPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.FilterPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.JoinPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.ReduceSinkPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
OpProcFactory.DefaultPPD.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprWalkerProcFactory.ColumnExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Converts the reference from child row resolver to current row resolver. |
Object |
ExprWalkerProcFactory.FieldExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprWalkerProcFactory.GenericFuncExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Object |
ExprWalkerProcFactory.DefaultExprProcessor.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
|
Uses of Node in org.apache.hadoop.hive.ql.tools |
---|
Methods in org.apache.hadoop.hive.ql.tools with parameters of type Node | |
---|---|
Object |
LineageInfo.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Implements the process method for the NodeProcessor interface. |
Method parameters in org.apache.hadoop.hive.ql.tools with type arguments of type Node | |
---|---|
Object |
LineageInfo.process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Implements the process method for the NodeProcessor interface. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |