public abstract class AbstractBucketJoinProc extends Object implements NodeProcessor
Modifier and Type | Field and Description |
---|---|
protected ParseContext |
pGraphContext |
Constructor and Description |
---|
AbstractBucketJoinProc() |
AbstractBucketJoinProc(ParseContext pGraphContext) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
canConvertMapJoinToBucketMapJoin(MapJoinOperator mapJoinOp,
BucketJoinProcCtx context) |
protected boolean |
checkConvertBucketMapJoin(BucketJoinProcCtx context,
Map<String,Operator<? extends OperatorDesc>> aliasToOpInfo,
Map<Byte,List<ExprNodeDesc>> keysMap,
String baseBigAlias,
List<String> joinAliases) |
protected void |
convertMapJoinToBucketMapJoin(MapJoinOperator mapJoinOp,
BucketJoinProcCtx context) |
static List<String> |
getBucketFilePathsOfPartition(org.apache.hadoop.fs.Path location,
ParseContext pGraphContext) |
abstract Object |
process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Generic process for all ops that don't have specific implementations.
|
static List<String> |
toColumns(List<ExprNodeDesc> keys) |
protected ParseContext pGraphContext
public AbstractBucketJoinProc(ParseContext pGraphContext)
public AbstractBucketJoinProc()
public abstract Object process(Node nd, Stack<Node> stack, NodeProcessorCtx procCtx, Object... nodeOutputs) throws SemanticException
NodeProcessor
process
in interface NodeProcessor
nd
- operator to processprocCtx
- operator processor contextnodeOutputs
- A variable argument list of outputs from other nodes in the walkSemanticException
public static List<String> getBucketFilePathsOfPartition(org.apache.hadoop.fs.Path location, ParseContext pGraphContext) throws SemanticException
SemanticException
protected boolean canConvertMapJoinToBucketMapJoin(MapJoinOperator mapJoinOp, BucketJoinProcCtx context) throws SemanticException
SemanticException
protected boolean checkConvertBucketMapJoin(BucketJoinProcCtx context, Map<String,Operator<? extends OperatorDesc>> aliasToOpInfo, Map<Byte,List<ExprNodeDesc>> keysMap, String baseBigAlias, List<String> joinAliases) throws SemanticException
SemanticException
protected void convertMapJoinToBucketMapJoin(MapJoinOperator mapJoinOp, BucketJoinProcCtx context) throws SemanticException
SemanticException
public static List<String> toColumns(List<ExprNodeDesc> keys)
Copyright © 2017 The Apache Software Foundation. All rights reserved.