public abstract class AbstractMapOperator extends Operator<MapWork> implements Serializable, Cloneable
| Modifier and Type | Class and Description |
|---|---|
static class |
AbstractMapOperator.Counter
Counter.
|
Operator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected org.apache.hadoop.io.LongWritable |
deserialize_error_count |
protected long |
numRows |
protected org.apache.hadoop.io.LongWritable |
recordCounter |
abortOp, 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 |
AbstractMapOperator()
Kryo ctor.
|
|
AbstractMapOperator(CompilationOpContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
void |
clearConnectedOperators() |
void |
closeOp(boolean abort)
Operator specific close routine.
|
Map<Integer,DummyStoreOperator> |
getConnectedOperators() |
abstract Deserializer |
getCurrentDeserializer() |
protected String |
getNominalPath(org.apache.hadoop.fs.Path fpath) |
abstract void |
initEmptyInputChildren(List<Operator<?>> children,
org.apache.hadoop.conf.Configuration hconf) |
abstract void |
initializeContexts() |
void |
initializeMapOperator(org.apache.hadoop.conf.Configuration hconf) |
abstract void |
process(org.apache.hadoop.io.Writable value) |
abstract void |
setChildren(org.apache.hadoop.conf.Configuration hconf) |
void |
setConnectedOperators(int tag,
DummyStoreOperator dummyOp) |
abort, acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, cleanUpInputFileChangedOp, 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, getName, getNextCntr, getNumChild, getNumParent, getOperatorId, getOperatorName, getOpTraits, getOutputObjInspector, getParentOperators, getReduceOutputName, getSchema, getStatistics, getStats, getType, initEvaluators, initEvaluators, initEvaluatorsAndReturnStruct, initialize, initialize, initializeChildren, initializeLocalWork, initializeOp, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logicalEquals, logicalEqualsTree, logStats, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, opAllowedBeforeSortMergeJoin, opAllowedConvertMapJoin, passExecContext, preorderMap, process, 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 final transient org.apache.hadoop.io.LongWritable deserialize_error_count
protected final transient org.apache.hadoop.io.LongWritable recordCounter
protected transient long numRows
protected AbstractMapOperator()
public AbstractMapOperator(CompilationOpContext ctx)
protected String getNominalPath(org.apache.hadoop.fs.Path fpath)
public abstract void initEmptyInputChildren(List<Operator<?>> children, org.apache.hadoop.conf.Configuration hconf) throws SerDeException, Exception
SerDeExceptionExceptionpublic abstract void setChildren(org.apache.hadoop.conf.Configuration hconf)
throws Exception
Exceptionpublic void initializeMapOperator(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
HiveExceptionpublic abstract void initializeContexts()
throws HiveException
HiveExceptionpublic abstract Deserializer getCurrentDeserializer()
public abstract void process(org.apache.hadoop.io.Writable value)
throws HiveException
HiveExceptionpublic void closeOp(boolean abort)
throws HiveException
OperatorcloseOp in class Operator<MapWork>HiveExceptionpublic void clearConnectedOperators()
public void setConnectedOperators(int tag,
DummyStoreOperator dummyOp)
public Map<Integer,DummyStoreOperator> getConnectedOperators()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.