org.apache.hadoop.hive.ql.exec
Class MapOperator

java.lang.Object
  extended by org.apache.hadoop.hive.ql.exec.Operator<MapWork>
      extended by org.apache.hadoop.hive.ql.exec.MapOperator
All Implemented Interfaces:
Serializable, Cloneable, Node
Direct Known Subclasses:
VectorMapOperator

public class MapOperator
extends Operator<MapWork>
implements Serializable, Cloneable

Map operator. This triggers overall map side processing. This is a little different from regular operators in that it starts off by processing a Writable data structure from a Table (instead of a Hive Object).

See Also:
Serialized Form

Nested Class Summary
static class MapOperator.Counter
          Counter.
 
Nested classes/interfaces inherited from class org.apache.hadoop.hive.ql.exec.Operator
Operator.OperatorFunc, Operator.State
 
Field Summary
 
Fields inherited from class org.apache.hadoop.hive.ql.exec.Operator
HIVECOUNTERCREATEDFILES, HIVECOUNTERFATAL
 
Constructor Summary
MapOperator()
           
 
Method Summary
 void cleanUpInputFileChangedOp()
           
 void closeOp(boolean abort)
          close extra child operators that are initialized but are not executed.
 String getName()
          Implements the getName function for the Node Interface.
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 initializeAsRoot(org.apache.hadoop.conf.Configuration hconf, MapWork mapWork)
          Initializes this map op as the root of the tree.
 void initializeOp(org.apache.hadoop.conf.Configuration hconf)
          Operator specific initialization.
static org.apache.hadoop.io.Writable[] populateVirtualColumnValues(ExecMapperContext ctx, List<VirtualColumn> vcs, org.apache.hadoop.io.Writable[] vcValues, Deserializer deserializer)
           
 void process(org.apache.hadoop.io.Writable value)
           
 void processOp(Object row, int tag)
          Process the row.
 void setChildren(org.apache.hadoop.conf.Configuration hconf)
           
 
Methods inherited from class org.apache.hadoop.hive.ql.exec.Operator
acceptLimitPushdown, augmentPlan, cleanUpInputFileChanged, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, dump, dump, endGroup, flush, getChildOperators, getChildren, getColumnExprMap, getConf, getConfiguration, getDone, getExecContext, getGroupKeyObject, getGroupKeyObjectInspector, getIdentifier, getInputObjInspectors, getNumChild, getNumParent, getOperatorId, getOpTraits, getOutputObjInspector, getParentOperators, getSchema, getStatistics, getStats, initialize, 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, setExecContext, setGroupKeyObject, setGroupKeyObjectInspector, setId, setInputObjInspectors, setOperatorId, setOpTraits, setOutputCollector, setParentOperators, setReporter, setSchema, setStatistics, setUseBucketizedHiveInputFormat, startGroup, supportAutomaticSortMergeJoin, supportSkewJoinOptimization, supportUnionRemoveOptimization, toString, toString
 
Methods inherited from class java.lang.Object
equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
 

Constructor Detail

MapOperator

public MapOperator()
Method Detail

initializeAsRoot

public void initializeAsRoot(org.apache.hadoop.conf.Configuration hconf,
                             MapWork mapWork)
                      throws HiveException
Initializes this map op as the root of the tree. It sets JobConf & MapRedWork and starts initialization of the operator tree rooted at this op.

Parameters:
hconf -
mrwork -
Throws:
HiveException

setChildren

public void setChildren(org.apache.hadoop.conf.Configuration hconf)
                 throws HiveException
Throws:
HiveException

initializeOp

public void initializeOp(org.apache.hadoop.conf.Configuration hconf)
                  throws HiveException
Description copied from class: Operator
Operator specific initialization.

Throws:
HiveException

closeOp

public void closeOp(boolean abort)
             throws HiveException
close extra child operators that are initialized but are not executed.

Throws:
HiveException

cleanUpInputFileChangedOp

public void cleanUpInputFileChangedOp()
                               throws HiveException
Overrides:
cleanUpInputFileChangedOp in class Operator<MapWork>
Throws:
HiveException

process

public void process(org.apache.hadoop.io.Writable value)
             throws HiveException
Throws:
HiveException

populateVirtualColumnValues

public static org.apache.hadoop.io.Writable[] populateVirtualColumnValues(ExecMapperContext ctx,
                                                                          List<VirtualColumn> vcs,
                                                                          org.apache.hadoop.io.Writable[] vcValues,
                                                                          Deserializer deserializer)

processOp

public void processOp(Object row,
                      int tag)
               throws HiveException
Description copied from class: Operator
Process the row.

Specified by:
processOp in class Operator<MapWork>
Parameters:
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.
Throws:
HiveException

getName

public String getName()
Description copied from class: Operator
Implements the getName function for the Node Interface.

Specified by:
getName in interface Node
Overrides:
getName in class Operator<MapWork>
Returns:
the name of the operator

getOperatorName

public static String getOperatorName()

getType

public org.apache.hadoop.hive.ql.plan.api.OperatorType getType()
Description copied from class: Operator
Return the type of the specific operator among the types in OperatorType.

Specified by:
getType in class Operator<MapWork>
Returns:
OperatorType.*


Copyright © 2014 The Apache Software Foundation. All rights reserved.