public class PTFOperator extends Operator<PTFDesc> implements Serializable
Operator.OperatorFunc, Operator.State
Modifier and Type | Field and Description |
---|---|
protected KeyWrapper |
currentKeys |
protected KeyWrapper |
newKeys |
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 |
---|
PTFOperator() |
Modifier and Type | Method and Description |
---|---|
protected void |
closeOp(boolean abort)
Operator specific close routine.
|
static void |
connectLeadLagFunctionsToPartition(PTFDesc ptfDesc,
PTFPartition.PTFPartitionIterator<Object> pItr) |
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.
|
protected Collection<Future<?>> |
initializeOp(org.apache.hadoop.conf.Configuration jobConf)
Operator specific initialization.
|
void |
process(Object row,
int tag)
Process the row.
|
protected void |
reconstructQueryDef(org.apache.hadoop.conf.Configuration hiveConf)
Initialize the visitor to use the QueryDefDeserializer Use the order
defined in QueryDefWalker to visit the QueryDef
|
protected void |
setupKeysWrapper(ObjectInspector inputOI) |
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, 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, toString
protected transient KeyWrapper currentKeys
protected transient KeyWrapper newKeys
protected Collection<Future<?>> initializeOp(org.apache.hadoop.conf.Configuration jobConf) throws HiveException
Operator
initializeOp
in class Operator<PTFDesc>
HiveException
protected void closeOp(boolean abort) throws HiveException
Operator
closeOp
in class Operator<PTFDesc>
HiveException
public void process(Object row, int tag) throws HiveException
Operator
process
in class Operator<PTFDesc>
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.HiveException
protected void reconstructQueryDef(org.apache.hadoop.conf.Configuration hiveConf) throws HiveException
hiveConf
- HiveException
protected void setupKeysWrapper(ObjectInspector inputOI) throws HiveException
HiveException
public String getName()
Operator
public static String getOperatorName()
public OperatorType getType()
Operator
public static void connectLeadLagFunctionsToPartition(PTFDesc ptfDesc, PTFPartition.PTFPartitionIterator<Object> pItr) throws HiveException
HiveException
Copyright © 2017 The Apache Software Foundation. All rights reserved.