Package | Description |
---|---|
org.apache.hadoop.hive.ql.parse | |
org.apache.hadoop.hive.ql.plan |
Modifier and Type | Method and Description |
---|---|
List<LoadFileDesc> |
ColumnStatsAutoGatherContext.getLoadFileWork() |
List<LoadFileDesc> |
ParseContext.getLoadFileWork() |
List<LoadFileDesc> |
SemanticAnalyzer.getLoadFileWork() |
Modifier and Type | Method and Description |
---|---|
protected void |
TaskCompiler.genColumnStatsTask(BaseSemanticAnalyzer.AnalyzeRewriteContext analyzeRewrite,
List<LoadFileDesc> loadFileWork,
Map<String,StatsTask> map,
int outerQueryLimit,
int numBitVector)
A helper function to generate a column stats task on top of map-red task.
|
void |
ParseContext.setLoadFileWork(List<LoadFileDesc> loadFileWork) |
void |
SemanticAnalyzer.setLoadFileWork(List<LoadFileDesc> loadFileWork) |
Constructor and Description |
---|
ParseContext(QueryState queryState,
HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner,
HashMap<TableScanOperator,PrunedPartitionList> opToPartList,
HashMap<String,TableScanOperator> topOps,
Set<JoinOperator> joinOps,
Set<SMBMapJoinOperator> smbMapJoinOps,
List<LoadTableDesc> loadTableWork,
List<LoadFileDesc> loadFileWork,
List<ColumnStatsAutoGatherContext> columnStatsAutoGatherContexts,
Context ctx,
HashMap<String,String> idToTableNameMap,
int destTableId,
UnionProcContext uCtx,
List<AbstractMapJoinOperator<? extends MapJoinDesc>> listMapJoinOpsNoReducer,
Map<String,PrunedPartitionList> prunedPartitions,
Map<String,Table> tabNameToTabObject,
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,
BaseSemanticAnalyzer.AnalyzeRewriteContext analyzeRewrite,
CreateTableDesc createTableDesc,
CreateViewDesc createViewDesc,
MaterializedViewDesc materializedViewUpdateDesc,
QueryProperties queryProperties,
Map<SelectOperator,Table> viewProjectToTableSchema,
Set<FileSinkDesc> acidFileSinks) |
Modifier and Type | Method and Description |
---|---|
LoadFileDesc |
BasicStatsWork.getLoadFileDesc() |
LoadFileDesc |
MoveWork.getLoadFileWork() |
Modifier and Type | Method and Description |
---|---|
void |
MoveWork.setLoadFileWork(LoadFileDesc loadFileWork) |
Constructor and Description |
---|
BasicStatsWork(LoadFileDesc loadFileDesc) |
LoadFileDesc(LoadFileDesc o) |
MoveWork(HashSet<ReadEntity> inputs,
HashSet<WriteEntity> outputs,
LoadTableDesc loadTableWork,
LoadFileDesc loadFileWork,
boolean checkFileFormat) |
MoveWork(HashSet<ReadEntity> inputs,
HashSet<WriteEntity> outputs,
LoadTableDesc loadTableWork,
LoadFileDesc loadFileWork,
boolean checkFileFormat,
boolean srcLocal) |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.