public class MapOperator extends Operator<MapWork> implements Serializable, Cloneable
| Modifier and Type | Class and Description |
|---|---|
static class |
MapOperator.Counter
Counter.
|
protected static class |
MapOperator.MapOpCtx |
Operator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected long |
cntr |
protected MapOperator.MapOpCtx[] |
currentCtxs |
protected long |
logEveryNRows |
protected long |
numRows |
alias, childOperators, childOperatorsArray, childOperatorsTag, colExprMap, conf, CONTEXT_NAME_KEY, done, groupKeyObject, HIVECOUNTERCREATEDFILES, HIVECOUNTERFATAL, id, inputObjInspectors, isLogDebugEnabled, isLogInfoEnabled, isLogTraceEnabled, LOG, operatorId, out, outputObjInspector, parentOperators, PLOG, reporter, state, statsMap| Constructor and Description |
|---|
MapOperator() |
| Modifier and Type | Method and Description |
|---|---|
void |
cleanUpInputFileChangedOp() |
void |
closeOp(boolean abort)
Operator specific close routine.
|
Deserializer |
getCurrentDeserializer() |
String |
getName()
Implements the getName function for the Node Interface.
|
static String |
getOperatorName() |
OperatorType |
getType()
Return the type of the specific operator among the
types in OperatorType.
|
void |
initializeContexts() |
void |
initializeMapOperator(org.apache.hadoop.conf.Configuration hconf) |
Collection<Future<?>> |
initializeOp(org.apache.hadoop.conf.Configuration hconf)
Operator specific initialization.
|
static Object[] |
populateVirtualColumnValues(ExecMapperContext ctx,
List<VirtualColumn> vcs,
Object[] vcValues,
Deserializer deserializer) |
void |
process(Object row,
int tag)
Process the row.
|
void |
process(org.apache.hadoop.io.Writable value) |
protected void |
rowsForwarded(int childrenDone,
int rows) |
void |
setChildren(org.apache.hadoop.conf.Configuration hconf) |
acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, 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, getNextCntr, getNumChild, getNumParent, getOperatorId, getOpTraits, getOutputObjInspector, getParentOperators, getSchema, getStatistics, getStats, initEvaluators, initEvaluators, initEvaluatorsAndReturnStruct, initialize, initialize, initializeChildren, initializeLocalWork, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logStats, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, opAllowedBeforeSortMergeJoin, opAllowedConvertMapJoin, passExecContext, preorderMap, 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, toStringprotected transient long numRows
protected transient long cntr
protected transient long logEveryNRows
protected transient MapOperator.MapOpCtx[] currentCtxs
public void setChildren(org.apache.hadoop.conf.Configuration hconf)
throws Exception
Exceptionpublic Collection<Future<?>> initializeOp(org.apache.hadoop.conf.Configuration hconf) throws HiveException
OperatorinitializeOp in class Operator<MapWork>HiveExceptionpublic void initializeMapOperator(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
HiveExceptionpublic void closeOp(boolean abort)
throws HiveException
OperatorcloseOp in class Operator<MapWork>HiveExceptionpublic void cleanUpInputFileChangedOp()
throws HiveException
cleanUpInputFileChangedOp in class Operator<MapWork>HiveExceptionpublic void process(org.apache.hadoop.io.Writable value)
throws HiveException
HiveExceptionprotected final void rowsForwarded(int childrenDone,
int rows)
public static Object[] populateVirtualColumnValues(ExecMapperContext ctx, List<VirtualColumn> vcs, Object[] vcValues, Deserializer deserializer)
public void process(Object row, int tag) throws HiveException
Operatorprocess in class Operator<MapWork>row - The object representing the row.tag - The tag of the row usually means which parent this row comes from.
Rows with the same tag should have exactly the same rowInspector
all the time.HiveExceptionpublic String getName()
Operatorpublic static String getOperatorName()
public OperatorType getType()
Operatorpublic void initializeContexts()
public Deserializer getCurrentDeserializer()
Copyright © 2017 The Apache Software Foundation. All rights reserved.