public abstract class AbstractFileMergeOperator<T extends FileMergeDesc> extends Operator<T> implements Serializable
OrcFileMergeOperator
or RCFileMergeOperator
for more details.Operator.OperatorFunc, Operator.State
Modifier and Type | Field and Description |
---|---|
protected boolean |
autoDelete |
static String |
BACKUP_PREFIX |
protected DynamicPartitionCtx |
dpCtx |
protected org.apache.hadoop.fs.Path |
dpPath |
protected boolean |
exception |
protected org.apache.hadoop.fs.Path |
finalPath |
protected org.apache.hadoop.fs.FileSystem |
fs |
protected boolean |
hasDynamicPartitions |
protected Set<org.apache.hadoop.fs.Path> |
incompatFileSet |
protected boolean |
isListBucketingAlterTableConcatenate |
protected org.apache.hadoop.mapred.JobConf |
jc |
protected int |
listBucketingDepth |
static org.apache.commons.logging.Log |
LOG |
protected org.apache.hadoop.fs.Path |
outPath |
protected org.apache.hadoop.fs.Path |
taskTmpPath |
protected org.apache.hadoop.fs.Path |
tmpPath |
protected boolean |
tmpPathFixed |
protected boolean |
tmpPathFixedConcatenate |
alias, childOperators, childOperatorsArray, childOperatorsTag, colExprMap, conf, CONTEXT_NAME_KEY, done, groupKeyObject, HIVECOUNTERCREATEDFILES, HIVECOUNTERFATAL, id, inputObjInspectors, isLogDebugEnabled, isLogInfoEnabled, isLogTraceEnabled, operatorId, out, outputObjInspector, parentOperators, PLOG, reporter, state, statsMap
Constructor and Description |
---|
AbstractFileMergeOperator() |
Modifier and Type | Method and Description |
---|---|
protected void |
checkPartitionsMatch(org.apache.hadoop.fs.Path inputPath)
Validates that each input path belongs to the same partition since each
mapper merges the input to a single output directory
|
void |
closeOp(boolean abort)
Operator specific close routine.
|
protected void |
fixTmpPath(org.apache.hadoop.fs.Path path) |
protected void |
fixTmpPath(org.apache.hadoop.fs.Path inputPath,
int depthDiff)
Fixes tmpPath to point to the correct partition.
|
Collection<Future<?>> |
initializeOp(org.apache.hadoop.conf.Configuration hconf)
Operator specific initialization.
|
void |
jobCloseOp(org.apache.hadoop.conf.Configuration hconf,
boolean success) |
acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, cleanUpInputFileChangedOp, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, completeInitializationOp, createDummy, defaultEndGroup, defaultStartGroup, dump, dump, endGroup, flush, forward, getAdditionalCounters, getChildOperators, getChildren, getColumnExprMap, getConf, getConfiguration, getDone, getExecContext, getGroupKeyObject, getIdentifier, getInputObjInspectors, getName, getNextCntr, getNumChild, getNumParent, getOperatorId, getOperatorName, getOpTraits, getOutputObjInspector, getParentOperators, getSchema, getStatistics, getStats, getType, initEvaluators, initEvaluators, initEvaluatorsAndReturnStruct, initialize, initialize, initializeChildren, initializeLocalWork, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, logStats, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, opAllowedBeforeSortMergeJoin, opAllowedConvertMapJoin, passExecContext, preorderMap, process, processGroup, removeChild, removeChildAndAdoptItsChildren, removeChildren, removeParent, replaceChild, replaceParent, reset, resetId, resetStats, setAlias, setChildOperators, setColumnExprMap, setConf, setDone, setExecContext, setGroupKeyObject, setId, setInputContext, setInputObjInspectors, setOperatorId, setOpTraits, setOutputCollector, setParentOperators, setReporter, setSchema, setStatistics, setUseBucketizedHiveInputFormat, startGroup, supportAutomaticSortMergeJoin, supportSkewJoinOptimization, supportUnionRemoveOptimization, toString, toString
public static final String BACKUP_PREFIX
public static final org.apache.commons.logging.Log LOG
protected org.apache.hadoop.mapred.JobConf jc
protected org.apache.hadoop.fs.FileSystem fs
protected boolean autoDelete
protected boolean exception
protected org.apache.hadoop.fs.Path outPath
protected org.apache.hadoop.fs.Path finalPath
protected org.apache.hadoop.fs.Path dpPath
protected org.apache.hadoop.fs.Path tmpPath
protected org.apache.hadoop.fs.Path taskTmpPath
protected int listBucketingDepth
protected boolean hasDynamicPartitions
protected boolean isListBucketingAlterTableConcatenate
protected boolean tmpPathFixedConcatenate
protected boolean tmpPathFixed
protected Set<org.apache.hadoop.fs.Path> incompatFileSet
protected transient DynamicPartitionCtx dpCtx
public Collection<Future<?>> initializeOp(org.apache.hadoop.conf.Configuration hconf) throws HiveException
Operator
initializeOp
in class Operator<T extends FileMergeDesc>
HiveException
protected void fixTmpPath(org.apache.hadoop.fs.Path inputPath, int depthDiff) throws IOException
inputPath
- - input pathIOException
protected void checkPartitionsMatch(org.apache.hadoop.fs.Path inputPath) throws IOException
inputPath
- - input pathIOException
protected void fixTmpPath(org.apache.hadoop.fs.Path path) throws IOException
IOException
public void closeOp(boolean abort) throws HiveException
Operator
closeOp
in class Operator<T extends FileMergeDesc>
HiveException
public void jobCloseOp(org.apache.hadoop.conf.Configuration hconf, boolean success) throws HiveException
jobCloseOp
in class Operator<T extends FileMergeDesc>
HiveException
Copyright © 2017 The Apache Software Foundation. All rights reserved.