Uses of Class
org.apache.hadoop.hive.ql.exec.JoinOperator

Packages that use JoinOperator
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.physical   
org.apache.hadoop.hive.ql.parse   
 

Uses of JoinOperator in org.apache.hadoop.hive.ql.optimizer
 

Methods in org.apache.hadoop.hive.ql.optimizer that return types with arguments of type JoinOperator
 Set<JoinOperator> BucketJoinProcCtx.getConvertedJoinOps()
           
 Set<JoinOperator> SkewJoinOptimizer.SkewJoinOptProcCtx.getDoneJoins()
           
 Set<JoinOperator> BucketJoinProcCtx.getRejectedJoinOps()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type JoinOperator
 MapJoinOperator ConvertJoinMapJoin.convertJoinMapJoin(JoinOperator joinOp, OptimizeTezProcContext context, int bigTablePosition)
           
static MapJoinOperator MapJoinProcessor.convertJoinOpMapJoinOp(HiveConf hconf, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtxMap, JoinOperator op, QBJoinTree joinTree, int mapJoinPos, boolean noCheckOuterJoin)
           
static MapJoinOperator MapJoinProcessor.convertMapJoin(HiveConf conf, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtxMap, JoinOperator op, QBJoinTree joinTree, int mapJoinPos, boolean noCheckOuterJoin, boolean validateMapJoinTree)
          convert a regular join to a a map-side join.
 MapJoinOperator MapJoinProcessor.generateMapJoinOperator(ParseContext pctx, JoinOperator op, QBJoinTree joinTree, int mapJoinPos)
           
static void MapJoinProcessor.genMapJoinOpAndLocalWork(HiveConf conf, MapredWork newWork, JoinOperator op, int mapJoinPos)
          Convert the join to a map-join and also generate any local work needed.
 int AvgPartitionSizeBasedBigTableSelectorForAutoSMJ.getBigTablePosition(ParseContext parseCtx, JoinOperator joinOp, Set<Integer> bigTableCandidates)
           
 int BigTableSelectorForAutoSMJ.getBigTablePosition(ParseContext parseContext, JoinOperator joinOp, Set<Integer> joinCandidates)
           
 int LeftmostBigTableSelectorForAutoSMJ.getBigTablePosition(ParseContext parseContext, JoinOperator joinOp, Set<Integer> bigTableCandidates)
           
 int TableSizeBasedBigTableSelectorForAutoSMJ.getBigTablePosition(ParseContext parseCtx, JoinOperator joinOp, Set<Integer> bigTableCandidates)
           
 int ConvertJoinMapJoin.mapJoinConversionPos(JoinOperator joinOp, OptimizeTezProcContext context, int buckets)
           
 

Method parameters in org.apache.hadoop.hive.ql.optimizer with type arguments of type JoinOperator
 void BucketJoinProcCtx.setConvertedJoinOps(Set<JoinOperator> setOfConvertedJoins)
           
 void SkewJoinOptimizer.SkewJoinOptProcCtx.setDoneJoins(Set<JoinOperator> doneJoins)
           
 void BucketJoinProcCtx.setRejectedJoinOps(Set<JoinOperator> rejectedJoinOps)
           
 

Uses of JoinOperator in org.apache.hadoop.hive.ql.optimizer.physical
 

Methods in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type JoinOperator
static void GenMRSkewJoinProcessor.processSkewJoin(JoinOperator joinOp, Task<? extends Serializable> currTask, ParseContext parseCtx)
          Create tasks for processing skew joins.
static boolean GenMRSkewJoinProcessor.skewJoinEnabled(HiveConf conf, JoinOperator joinOp)
           
 

Uses of JoinOperator in org.apache.hadoop.hive.ql.parse
 

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type JoinOperator
 Map<JoinOperator,QBJoinTree> ParseContext.getJoinContext()
           
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type JoinOperator
 void ParseContext.setJoinContext(Map<JoinOperator,QBJoinTree> joinContext)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.parse with type arguments of type JoinOperator
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, HashMap<TableScanOperator,PrunedPartitionList> opToPartList, HashMap<String,Operator<? extends OperatorDesc>> topOps, HashMap<String,Operator<? extends OperatorDesc>> topSelOps, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, Map<SMBMapJoinOperator,QBJoinTree> smbMapJoinContext, HashMap<TableScanOperator,Table> topToTable, HashMap<TableScanOperator,Map<String,String>> topToProps, Map<FileSinkOperator,Table> fsopToTable, List<LoadTableDesc> loadTableWork, List<LoadFileDesc> loadFileWork, Context ctx, HashMap<String,String> idToTableNameMap, int destTableId, UnionProcContext uCtx, List<AbstractMapJoinOperator<? extends MapJoinDesc>> listMapJoinOpsNoReducer, Map<GroupByOperator,Set<String>> groupOpToInputTables, Map<String,PrunedPartitionList> prunedPartitions, HashMap<TableScanOperator,FilterDesc.sampleDesc> opToSamplePruner, GlobalLimitCtx globalLimitCtx, HashMap<String,SplitSample> nameToSplitSample, HashSet<ReadEntity> semanticInputs, List<Task<? extends Serializable>> rootTasks, Map<TableScanOperator,Map<String,ExprNodeDesc>> opToPartToSkewedPruner, Map<String,ReadEntity> viewAliasToInput, List<ReduceSinkOperator> reduceSinkOperatorsAddedByEnforceBucketingSorting, QueryProperties queryProperties)
           
 



Copyright © 2014 The Apache Software Foundation. All rights reserved.