public class MapOperator extends AbstractMapOperator
| Modifier and Type | Class and Description |
|---|---|
protected static class |
MapOperator.MapOpCtx |
AbstractMapOperator.CounterOperator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected long |
cntr |
protected MapOperator.MapOpCtx[] |
currentCtxs |
protected long |
logEveryNRows |
deserialize_error_count, numRows, recordCounterabortOp, alias, asyncInitOperations, bucketingVersion, cContext, childOperators, childOperatorsArray, childOperatorsTag, conf, CONTEXT_NAME_KEY, done, groupKeyObject, HIVE_COUNTER_CREATED_DYNAMIC_PARTITIONS, HIVE_COUNTER_CREATED_FILES, HIVE_COUNTER_FATAL, id, indexForTezUnion, inputObjInspectors, LOG, operatorId, out, outputObjInspector, parentOperators, reporter, runTimeNumRows, state, statsMap| Modifier | Constructor and Description |
|---|---|
protected |
MapOperator()
Kryo ctor.
|
|
MapOperator(CompilationOpContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
void |
cleanUpInputFileChangedOp() |
Deserializer |
getCurrentDeserializer() |
String |
getName()
Gets the name of the node.
|
static String |
getOperatorName() |
org.apache.hadoop.hive.ql.plan.api.OperatorType |
getType()
Return the type of the specific operator among the
types in OperatorType.
|
void |
initEmptyInputChildren(List<Operator<?>> children,
org.apache.hadoop.conf.Configuration hconf) |
void |
initializeContexts() |
void |
initializeMapOperator(org.apache.hadoop.conf.Configuration hconf) |
void |
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) |
clearConnectedOperators, closeOp, getConnectedOperators, getNominalPath, setConnectedOperatorsabort, acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, completeInitializationOp, createDummy, defaultEndGroup, defaultStartGroup, dump, dump, endGroup, flush, flushRecursive, forward, forward, forward, getAdditionalCounters, getBucketingVersion, getChildOperators, getChildren, getColumnExprMap, getCompilationOpContext, getConf, getConfiguration, getCounterName, getDone, getExecContext, getGroupKeyObject, getIdentifier, getIndexForTezUnion, getInputObjInspectors, getIsReduceSink, getMarker, getNextCntr, getNumChild, getNumParent, getOperatorId, getOpTraits, getOutputObjInspector, getParentOperators, getReduceOutputName, getSchema, getStatistics, getStats, initEvaluators, initEvaluators, initEvaluatorsAndReturnStruct, initialize, initialize, initializeChildren, initializeLocalWork, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logicalEquals, logicalEqualsTree, logStats, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, opAllowedBeforeSortMergeJoin, opAllowedConvertMapJoin, passExecContext, preorderMap, processGroup, removeChild, removeChildAndAdoptItsChildren, removeParent, removeParents, replaceChild, replaceParent, reset, setAlias, setBucketingVersion, setChildOperators, setColumnExprMap, setCompilationOpContext, setConf, setDone, setExecContext, setGroupKeyObject, setIndexForTezUnion, setInputContext, setInputObjInspectors, setMarker, setNextVectorBatchGroupStatus, setOpTraits, setOutputCollector, setParentOperators, setReporter, setSchema, setStatistics, setUseBucketizedHiveInputFormat, startGroup, supportAutomaticSortMergeJoin, supportSkewJoinOptimization, supportUnionRemoveOptimization, toString, toStringprotected transient long cntr
protected transient long logEveryNRows
protected transient MapOperator.MapOpCtx[] currentCtxs
protected MapOperator()
public MapOperator(CompilationOpContext ctx)
public void initEmptyInputChildren(List<Operator<?>> children, org.apache.hadoop.conf.Configuration hconf) throws SerDeException, Exception
initEmptyInputChildren in class AbstractMapOperatorSerDeExceptionExceptionpublic void setChildren(org.apache.hadoop.conf.Configuration hconf)
throws Exception
setChildren in class AbstractMapOperatorExceptionpublic void 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
initializeMapOperator in class AbstractMapOperatorHiveExceptionpublic void cleanUpInputFileChangedOp()
throws HiveException
cleanUpInputFileChangedOp in class Operator<MapWork>HiveExceptionpublic void process(org.apache.hadoop.io.Writable value)
throws HiveException
process in class AbstractMapOperatorHiveExceptionprotected 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()
Nodepublic static String getOperatorName()
public org.apache.hadoop.hive.ql.plan.api.OperatorType getType()
Operatorpublic void initializeContexts()
initializeContexts in class AbstractMapOperatorpublic Deserializer getCurrentDeserializer()
getCurrentDeserializer in class AbstractMapOperatorCopyright © 2019 The Apache Software Foundation. All Rights Reserved.