public class VectorMapOperator extends AbstractMapOperator
| Modifier and Type | Class and Description |
|---|---|
protected class |
VectorMapOperator.RowDeserializePartitionContext |
protected class |
VectorMapOperator.VectorDeserializePartitionContext |
protected class |
VectorMapOperator.VectorizedInputFileFormatPartitionContext |
protected class |
VectorMapOperator.VectorPartitionContext |
AbstractMapOperator.CounterOperator.OperatorFunc, Operator.Statedeserialize_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| Constructor and Description |
|---|
VectorMapOperator()
Kryo ctor.
|
VectorMapOperator(CompilationOpContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
void |
cleanUpInputFileChangedOp() |
void |
closeOp(boolean abort)
Operator specific close routine.
|
VectorMapOperator.VectorPartitionContext |
createAndInitPartitionContext(PartitionDesc partDesc,
org.apache.hadoop.conf.Configuration hconf) |
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 |
process(Object row,
int tag)
Process the row.
|
void |
process(org.apache.hadoop.io.Writable value) |
void |
setChildren(org.apache.hadoop.conf.Configuration hconf) |
clearConnectedOperators, 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, initializeOp, 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, toStringpublic VectorMapOperator()
public VectorMapOperator(CompilationOpContext ctx)
public VectorMapOperator.VectorPartitionContext createAndInitPartitionContext(PartitionDesc partDesc, org.apache.hadoop.conf.Configuration hconf) throws SerDeException, Exception
SerDeExceptionExceptionpublic 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 initializeMapOperator(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
initializeMapOperator in class AbstractMapOperatorHiveExceptionpublic void initializeContexts()
throws HiveException
initializeContexts in class AbstractMapOperatorHiveExceptionpublic void cleanUpInputFileChangedOp()
throws HiveException
cleanUpInputFileChangedOp in class Operator<MapWork>HiveExceptionpublic Deserializer getCurrentDeserializer()
getCurrentDeserializer in class AbstractMapOperatorpublic void process(org.apache.hadoop.io.Writable value)
throws HiveException
process in class AbstractMapOperatorHiveExceptionpublic 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 void closeOp(boolean abort)
throws HiveException
OperatorcloseOp in class AbstractMapOperatorHiveExceptionpublic String getName()
Nodepublic static String getOperatorName()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.