public class SMBMapJoinOperator extends AbstractMapJoinOperator<SMBJoinDesc> implements Serializable
Operator.Counter, Operator.OperatorFunc, Operator.StateemptyList, joinKeys, joinKeysObjectInspectors, posBigTablealias, aliasFilterTags, condn, countAfterReport, dummyObj, dummyObjVectors, filterMaps, filterTags, forwardCache, hconf, heartbeatInterval, intermediate, joinFilterObjectInspectors, joinFilters, joinValues, joinValuesObjectInspectors, joinValuesStandardObjectInspectors, 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 |
SMBMapJoinOperator()
Kryo ctor.
|
|
SMBMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc> mapJoinOp) |
|
SMBMapJoinOperator(CompilationOpContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
protected boolean |
allInitializedParentsAreClosed() |
void |
cleanUpInputFileChangedOp() |
void |
closeOp(boolean abort)
All done.
|
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 |
initializeLocalWork(org.apache.hadoop.conf.Configuration hconf) |
void |
initializeMapredLocalWork(MapJoinDesc mjConf,
org.apache.hadoop.conf.Configuration hconf,
MapredLocalWork localWork,
org.slf4j.Logger l4j) |
protected void |
initializeOp(org.apache.hadoop.conf.Configuration hconf)
Operator specific initialization.
|
boolean |
isConvertedAutomaticallySMBJoin() |
boolean |
opAllowedConvertMapJoin() |
void |
process(Object row,
int tag)
Process the row.
|
void |
setConvertedAutomaticallySMBJoin(boolean convertedAutomaticallySMBJoin) |
protected List<Object> |
smbJoinComputeKeys(Object row,
byte alias) |
getValueObjectInspectorscheckAndGenObject, endGroup, getFilteredValue, getFilterTag, getNextSize, getPosToAliasMap, hasFilter, internalForward, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, reportProgress, setPosToAliasMap, startGroupabort, acceptLimitPushdown, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, 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, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logicalEquals, logicalEqualsTree, logStats, opAllowedBeforeSortMergeJoin, 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, supportAutomaticSortMergeJoin, supportSkewJoinOptimization, supportUnionRemoveOptimization, toString, toStringprotected SMBMapJoinOperator()
public SMBMapJoinOperator(CompilationOpContext ctx)
public SMBMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc> mapJoinOp)
protected void initializeOp(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
OperatorinitializeOp in class AbstractMapJoinOperator<SMBJoinDesc>HiveExceptionpublic void initializeLocalWork(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
initializeLocalWork in class Operator<SMBJoinDesc>HiveExceptionpublic void initializeMapredLocalWork(MapJoinDesc mjConf, org.apache.hadoop.conf.Configuration hconf, MapredLocalWork localWork, org.slf4j.Logger l4j) throws HiveException
HiveExceptionpublic void cleanUpInputFileChangedOp()
throws HiveException
cleanUpInputFileChangedOp in class Operator<SMBJoinDesc>HiveExceptionprotected List<Object> smbJoinComputeKeys(Object row, byte alias) throws HiveException
HiveExceptionpublic void process(Object row, int tag) throws HiveException
Operatorprocess in class Operator<SMBJoinDesc>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
CommonJoinOperatorcloseOp in class AbstractMapJoinOperator<SMBJoinDesc>HiveExceptionprotected boolean allInitializedParentsAreClosed()
allInitializedParentsAreClosed in class Operator<SMBJoinDesc>public String getName()
getName in interface NodegetName in class CommonJoinOperator<SMBJoinDesc>public static String getOperatorName()
public org.apache.hadoop.hive.ql.plan.api.OperatorType getType()
OperatorgetType in class AbstractMapJoinOperator<SMBJoinDesc>public boolean isConvertedAutomaticallySMBJoin()
public void setConvertedAutomaticallySMBJoin(boolean convertedAutomaticallySMBJoin)
public boolean opAllowedConvertMapJoin()
opAllowedConvertMapJoin in class Operator<SMBJoinDesc>Copyright © 2019 The Apache Software Foundation. All Rights Reserved.