|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
java.lang.Objectorg.apache.hadoop.hive.ql.parse.ParseContext
public class ParseContext
Parse Context: The current parse context. This is passed to the optimizer which then transforms the operator tree using the parse context. All the optimizations are performed sequentially and then the new parse context populated. Note that since the parse context contains the operator tree, it can be easily retrieved by the next optimization step or finally for task generation after the plan has been completely optimized.
Methods inherited from class java.lang.Object |
---|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait |
Constructor Detail |
---|
public ParseContext()
public 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, HashMap<TableScanOperator,Table> topToTable, 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)
conf
- qb
- current QBast
- current parse treeopToPartPruner
- map from table scan operator to partition pruneropToPartList
- topOps
- list of operators for the top querytopSelOps
- list of operators for the selects introduced for column pruningopParseCtx
- operator parse context - contains a mapping from operator to
operator parse state (row resolver etc.)joinContext
- context needed join processing (map join specifically)topToTable
- the top tables being processedloadTableWork
- list of destination tables being loadedloadFileWork
- list of destination files being loadedctx
- parse contextidToTableNameMap
- uCtx
- destTableId
- listMapJoinOpsNoReducer
- list of map join operators with no reducergroupOpToInputTables
- prunedPartitions
- opToSamplePruner
- operator to sample pruner mapglobalLimitCtx
- nameToSplitSample
- rootTasks
- Method Detail |
---|
public QB getQB()
public void setQB(QB qb)
qb
- the qb to setpublic Context getContext()
public void setContext(Context ctx)
ctx
- the context to setpublic HiveConf getConf()
public void setConf(HiveConf conf)
conf
- the conf to setpublic ASTNode getParseTree()
public void setParseTree(ASTNode ast)
ast
- the parsetree to setpublic HashMap<TableScanOperator,ExprNodeDesc> getOpToPartPruner()
public void setOpToPartPruner(HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner)
opToPartPruner
- the opToPartPruner to setpublic HashMap<TableScanOperator,PrunedPartitionList> getOpToPartList()
public void setOpToPartList(HashMap<TableScanOperator,PrunedPartitionList> opToPartList)
public HashMap<TableScanOperator,Table> getTopToTable()
public void setTopToTable(HashMap<TableScanOperator,Table> topToTable)
topToTable
- the topToTable to setpublic HashMap<String,Operator<? extends OperatorDesc>> getTopOps()
public void setTopOps(HashMap<String,Operator<? extends OperatorDesc>> topOps)
topOps
- the topOps to setpublic HashMap<String,Operator<? extends OperatorDesc>> getTopSelOps()
public void setTopSelOps(HashMap<String,Operator<? extends OperatorDesc>> topSelOps)
topSelOps
- the topSelOps to setpublic LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> getOpParseCtx()
public void setOpParseCtx(LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx)
opParseCtx
- the opParseCtx to setpublic HashMap<String,SplitSample> getNameToSplitSample()
public void setNameToSplitSample(HashMap<String,SplitSample> nameToSplitSample)
public List<LoadTableDesc> getLoadTableWork()
public void setLoadTableWork(List<LoadTableDesc> loadTableWork)
loadTableWork
- the loadTableWork to setpublic List<LoadFileDesc> getLoadFileWork()
public void setLoadFileWork(List<LoadFileDesc> loadFileWork)
loadFileWork
- the loadFileWork to setpublic HashMap<String,String> getIdToTableNameMap()
public void setIdToTableNameMap(HashMap<String,String> idToTableNameMap)
public int getDestTableId()
public void setDestTableId(int destTableId)
public UnionProcContext getUCtx()
public void setUCtx(UnionProcContext uCtx)
public Map<JoinOperator,QBJoinTree> getJoinContext()
public void setJoinContext(Map<JoinOperator,QBJoinTree> joinContext)
joinContext
- the joinContext to setpublic List<AbstractMapJoinOperator<? extends MapJoinDesc>> getListMapJoinOpsNoReducer()
public void setListMapJoinOpsNoReducer(List<AbstractMapJoinOperator<? extends MapJoinDesc>> listMapJoinOpsNoReducer)
listMapJoinOpsNoReducer
- the listMapJoinOpsNoReducer to setpublic void setHasNonPartCols(boolean val)
val
- public boolean getHasNonPartCols()
public HashMap<TableScanOperator,FilterDesc.sampleDesc> getOpToSamplePruner()
public void setOpToSamplePruner(HashMap<TableScanOperator,FilterDesc.sampleDesc> opToSamplePruner)
opToSamplePruner
- the opToSamplePruner to setpublic Map<GroupByOperator,Set<String>> getGroupOpToInputTables()
public void setGroupOpToInputTables(Map<GroupByOperator,Set<String>> groupOpToInputTables)
groupOpToInputTables
- public Map<String,PrunedPartitionList> getPrunedPartitions()
public void setPrunedPartitions(Map<String,PrunedPartitionList> prunedPartitions)
prunedPartitions
- public void setLineageInfo(LineageInfo lInfo)
lInfo
- The lineage information.public LineageInfo getLineageInfo()
public Map<MapJoinOperator,QBJoinTree> getMapJoinContext()
public void setMapJoinContext(Map<MapJoinOperator,QBJoinTree> mapJoinContext)
public GlobalLimitCtx getGlobalLimitCtx()
public void setGlobalLimitCtx(GlobalLimitCtx globalLimitCtx)
public HashSet<ReadEntity> getSemanticInputs()
public void replaceRootTask(Task<? extends Serializable> rootTask, List<? extends Task<? extends Serializable>> tasks)
public FetchTask getFetchTask()
public void setFetchTask(FetchTask fetchTask)
public PrunedPartitionList getPrunedPartitions(String alias, TableScanOperator ts) throws HiveException
HiveException
public Map<TableScanOperator,Map<String,ExprNodeDesc>> getOpToPartToSkewedPruner()
public void setOpPartToSkewedPruner(HashMap<TableScanOperator,Map<String,ExprNodeDesc>> opToPartToSkewedPruner)
opToPartToSkewedPruner
- the opToSkewedPruner to set
|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |