Uses of Class
org.apache.hadoop.hive.ql.plan.LoadTableDesc

Packages that use LoadTableDesc
org.apache.hadoop.hive.ql   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
 

Uses of LoadTableDesc in org.apache.hadoop.hive.ql
 

Methods in org.apache.hadoop.hive.ql that return types with arguments of type LoadTableDesc
 Map<LoadTableDesc,WriteEntity> Context.getLoadTableOutputMap()
           
 

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

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type LoadTableDesc
 List<LoadTableDesc> ParseContext.getLoadTableWork()
           
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type LoadTableDesc
 void ParseContext.setLoadTableWork(List<LoadTableDesc> loadTableWork)
           
 

Constructors in org.apache.hadoop.hive.ql.parse with parameters of type LoadTableDesc
IndexUpdater(LoadTableDesc loadTableWork, Set<ReadEntity> inputs, org.apache.hadoop.conf.Configuration conf)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.parse with type arguments of type LoadTableDesc
IndexUpdater(List<LoadTableDesc> loadTableWork, Set<ReadEntity> inputs, org.apache.hadoop.conf.Configuration conf)
           
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)
           
 

Uses of LoadTableDesc in org.apache.hadoop.hive.ql.plan
 

Methods in org.apache.hadoop.hive.ql.plan that return LoadTableDesc
 LoadTableDesc StatsWork.getLoadTableDesc()
           
 LoadTableDesc MoveWork.getLoadTableWork()
           
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type LoadTableDesc
 void MoveWork.setLoadTableWork(LoadTableDesc loadTableWork)
           
 

Constructors in org.apache.hadoop.hive.ql.plan with parameters of type LoadTableDesc
MoveWork(HashSet<ReadEntity> inputs, HashSet<WriteEntity> outputs, LoadTableDesc loadTableWork, LoadFileDesc loadFileWork, boolean checkFileFormat)
           
StatsWork(LoadTableDesc loadTableDesc)
           
 



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