public class PTFOperator extends Operator<PTFDesc> implements Serializable
Operator.Counter, Operator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected KeyWrapper |
currentKeys |
protected KeyWrapper |
newKeys |
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, numRows, operatorId, out, outputObjInspector, parentOperators, reporter, runTimeNumRows, state, statsMap| Modifier | Constructor and Description |
|---|---|
protected |
PTFOperator()
Kryo ctor.
|
|
PTFOperator(CompilationOpContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
protected void |
closeOp(boolean abort)
Operator specific close routine.
|
static void |
connectLeadLagFunctionsToPartition(LeadLagInfo leadLagInfo,
PTFPartition.PTFPartitionIterator<Object> pItr) |
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.
|
protected void |
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) |
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, 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 KeyWrapper currentKeys
protected transient KeyWrapper newKeys
protected PTFOperator()
public PTFOperator(CompilationOpContext ctx)
protected void initializeOp(org.apache.hadoop.conf.Configuration jobConf)
throws HiveException
OperatorinitializeOp in class Operator<PTFDesc>HiveExceptionprotected void closeOp(boolean abort)
throws HiveException
OperatorcloseOp in class Operator<PTFDesc>HiveExceptionpublic void process(Object row, int tag) throws HiveException
Operatorprocess 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.HiveExceptionprotected void reconstructQueryDef(org.apache.hadoop.conf.Configuration hiveConf)
throws HiveException
hiveConf - HiveExceptionprotected void setupKeysWrapper(ObjectInspector inputOI) throws HiveException
HiveExceptionpublic String getName()
Nodepublic static String getOperatorName()
public org.apache.hadoop.hive.ql.plan.api.OperatorType getType()
Operatorpublic static void connectLeadLagFunctionsToPartition(LeadLagInfo leadLagInfo, PTFPartition.PTFPartitionIterator<Object> pItr) throws HiveException
HiveExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.