public abstract class AbstractMapJoinOperator<T extends MapJoinDesc> extends CommonJoinOperator<T> implements Serializable
Operator.Counter, Operator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected RowContainer<List<Object>> |
emptyList |
protected List<ExprNodeEvaluator>[] |
joinKeys
The expressions for join inputs's join keys.
|
protected List<ObjectInspector>[] |
joinKeysObjectInspectors
The ObjectInspectors for the join inputs's join keys.
|
protected byte |
posBigTable |
alias, aliasFilterTags, condn, countAfterReport, dummyObj, dummyObjVectors, filterMaps, filterTags, forwardCache, hconf, heartbeatInterval, intermediate, joinFilterObjectInspectors, joinFilters, joinValues, joinValuesObjectInspectors, joinValuesStandardObjectInspectors, LOG, needsPostEvaluation, noOuterJoin, NOTSKIPBIGTABLE, nullsafes, numAliases, offsets, order, residualJoinFilters, residualJoinFiltersOIs, rowContainerPostFilteredOuterJoin, rowContainerStandardObjectInspectors, skipVectors, spillTableDesc, totalSzabortOp, 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, numRows, operatorId, out, outputObjInspector, parentOperators, reporter, runTimeNumRows, state, statsMap| Modifier | Constructor and Description |
|---|---|
protected |
AbstractMapJoinOperator()
Kryo ctor.
|
|
AbstractMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc> mjop) |
|
AbstractMapJoinOperator(CompilationOpContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
void |
closeOp(boolean abort)
All done.
|
org.apache.hadoop.hive.ql.plan.api.OperatorType |
getType()
Return the type of the specific operator among the
types in OperatorType.
|
protected List<ObjectInspector> |
getValueObjectInspectors(byte alias,
List<ObjectInspector>[] aliasToObjectInspectors) |
protected void |
initializeOp(org.apache.hadoop.conf.Configuration hconf)
Operator specific initialization.
|
checkAndGenObject, endGroup, getFilteredValue, getFilterTag, getName, getNextSize, getOperatorName, getPosToAliasMap, hasFilter, internalForward, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, reportProgress, setPosToAliasMap, startGroupabort, acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, cleanUpInputFileChangedOp, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, completeInitializationOp, createDummy, defaultEndGroup, defaultStartGroup, dump, dump, 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, 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, supportAutomaticSortMergeJoin, supportSkewJoinOptimization, supportUnionRemoveOptimization, toString, toStringprotected transient List<ExprNodeEvaluator>[] joinKeys
protected transient List<ObjectInspector>[] joinKeysObjectInspectors
protected transient byte posBigTable
protected transient RowContainer<List<Object>> emptyList
protected AbstractMapJoinOperator()
public AbstractMapJoinOperator(CompilationOpContext ctx)
public AbstractMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc> mjop)
protected void initializeOp(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
OperatorinitializeOp in class CommonJoinOperator<T extends MapJoinDesc>HiveExceptionprotected List<ObjectInspector> getValueObjectInspectors(byte alias, List<ObjectInspector>[] aliasToObjectInspectors)
getValueObjectInspectors in class CommonJoinOperator<T extends MapJoinDesc>public org.apache.hadoop.hive.ql.plan.api.OperatorType getType()
OperatorgetType in class Operator<T extends MapJoinDesc>public void closeOp(boolean abort)
throws HiveException
CommonJoinOperatorcloseOp in class CommonJoinOperator<T extends MapJoinDesc>HiveExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.