public class MergeFileWork extends MapWork
SAMPLING_ON_PREV_MR, SAMPLING_ON_START
vectorColumnNameMap, vectorColumnTypeMap, vectorScratchColumnTypeMap
opProps, opTraits, statistics, vectorMode
Constructor and Description |
---|
MergeFileWork(List<org.apache.hadoop.fs.Path> inputPaths,
org.apache.hadoop.fs.Path outputDir,
boolean hasDynamicPartitions,
String srcTblInputFormat) |
MergeFileWork(List<org.apache.hadoop.fs.Path> inputPaths,
org.apache.hadoop.fs.Path outputDir,
String srcTblInputFormat) |
Modifier and Type | Method and Description |
---|---|
String |
getInputformat() |
Class<? extends org.apache.hadoop.mapred.InputFormat> |
getInputformatClass() |
List<org.apache.hadoop.fs.Path> |
getInputPaths() |
ListBucketingCtx |
getListBucketingCtx() |
String |
getMergeLevel() |
Long |
getMinSplitSize() |
org.apache.hadoop.fs.Path |
getOutputDir() |
String |
getSourceTableInputFormat() |
boolean |
hasDynamicPartitions() |
boolean |
isGatheringStats() |
boolean |
isListBucketingAlterTableConcatenate() |
void |
resolveConcatenateMerge(HiveConf conf)
alter table ...
|
void |
resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf conf,
org.apache.hadoop.fs.Path path,
TableDesc tblDesc,
ArrayList<String> aliases,
PartitionDesc partDesc) |
void |
setHasDynamicPartitions(boolean hasDynamicPartitions) |
void |
setInputPaths(List<org.apache.hadoop.fs.Path> inputPaths) |
void |
setListBucketingCtx(ListBucketingCtx listBucketingCtx) |
void |
setOutputDir(org.apache.hadoop.fs.Path outputDir) |
void |
setSourceTableInputFormat(String srcTblInputFormat) |
addIndexIntermediateFile, addMapWork, configureJobConf, deriveExplainAttributes, getAliases, getAliasToPartnInfo, getAliasToWork, getAllRootOperators, getBaseSrc, getBucketedColsByDirectory, getDoSplitsGrouping, getDummyTableScan, getEventSourceColumnNameMap, getEventSourcePartKeyExprMap, getEventSourceTableDescMap, getHadoopSupportsSplittable, getIndexIntermediateFile, getMapAliases, getMaxSplitSize, getMinSplitSizePerNode, getMinSplitSizePerRack, getNameToSplitSample, getNumMapTasks, getPartitionDescs, getPaths, getPathToAliases, getPathToPartitionInfo, getSamplingType, getSamplingTypeString, getSortedColsByDirectory, getTmpHDFSPath, getTruncatedPathToAliases, getVectorModeOn, getWorks, initialize, internTable, isInputFormatSorted, isLeftInputJoin, isMapperCannotSpanPartns, isUseBucketizedHiveInputFormat, isUseOneNullRowInputFormat, logPathToAliases, mergeAliasedInput, mergingInto, replaceRoots, setAliasToPartnInfo, setAliasToWork, setBaseSrc, setDoSplitsGrouping, setDummyTableScan, setEventSourceColumnNameMap, setEventSourcePartKeyExprMap, setEventSourceTableDescMap, setHadoopSupportsSplittable, setInputformat, setInputFormatSorted, setLeftInputJoin, setMapAliases, setMapperCannotSpanPartns, setMaxSplitSize, setMinSplitSize, setMinSplitSizePerNode, setMinSplitSizePerRack, setNameToSplitSample, setNumMapTasks, setPathToAliases, setPathToPartitionInfo, setSamplingType, setTmpHDFSPath, setUseBucketizedHiveInputFormat, setUseOneNullRowInputFormat
addDummyOp, addSortCols, getAllLeafOperators, getAllOperators, getDummyOps, getMapRedLocalWork, getName, getSortCols, getTag, getVectorColumnNameMap, getVectorColumnTypeMap, getVectorScratchColumnTypeMap, setDummyOps, setGatheringStats, setMapRedLocalWork, setName, setTag, setVectorColumnNameMap, setVectorColumnTypeMap, setVectorScratchColumnTypeMap
clone, getOpProps, getStatistics, getTraits, getVectorMode, setOpProps, setStatistics, setTraits, setVectorMode
public MergeFileWork(List<org.apache.hadoop.fs.Path> inputPaths, org.apache.hadoop.fs.Path outputDir, String srcTblInputFormat)
public List<org.apache.hadoop.fs.Path> getInputPaths()
public void setInputPaths(List<org.apache.hadoop.fs.Path> inputPaths)
public org.apache.hadoop.fs.Path getOutputDir()
public void setOutputDir(org.apache.hadoop.fs.Path outputDir)
public Long getMinSplitSize()
getMinSplitSize
in class MapWork
public String getInputformat()
getInputformat
in class MapWork
public Class<? extends org.apache.hadoop.mapred.InputFormat> getInputformatClass()
public boolean isGatheringStats()
isGatheringStats
in class BaseWork
public boolean hasDynamicPartitions()
public void setHasDynamicPartitions(boolean hasDynamicPartitions)
public void resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf conf, org.apache.hadoop.fs.Path path, TableDesc tblDesc, ArrayList<String> aliases, PartitionDesc partDesc)
resolveDynamicPartitionStoredAsSubDirsMerge
in class MapWork
public void resolveConcatenateMerge(HiveConf conf)
public ListBucketingCtx getListBucketingCtx()
public void setListBucketingCtx(ListBucketingCtx listBucketingCtx)
listBucketingCtx
- the listBucketingCtx to setpublic boolean isListBucketingAlterTableConcatenate()
public String getSourceTableInputFormat()
public void setSourceTableInputFormat(String srcTblInputFormat)
public String getMergeLevel()
Copyright © 2017 The Apache Software Foundation. All rights reserved.