public class SMBMapJoinOperator extends AbstractMapJoinOperator<SMBJoinDesc> implements Serializable
Operator.OperatorFunc, Operator.StateemptyList, joinKeys, joinKeysObjectInspectors, posBigTablealias, aliasFilterTags, condn, countAfterReport, dummyObj, dummyObjVectors, filterMaps, filterTags, forwardCache, hconf, heartbeatInterval, intermediate, joinFilterObjectInspectors, joinFilters, joinValues, joinValuesObjectInspectors, joinValuesStandardObjectInspectors, noOuterJoin, NOTSKIPBIGTABLE, nullsafes, numAliases, offsets, order, rowContainerStandardObjectInspectors, skipVectors, spillTableDesc, totalSzchildOperators, childOperatorsArray, childOperatorsTag, colExprMap, conf, CONTEXT_NAME_KEY, done, groupKeyObject, HIVECOUNTERCREATEDFILES, HIVECOUNTERFATAL, id, inputObjInspectors, isLogDebugEnabled, isLogInfoEnabled, isLogTraceEnabled, operatorId, out, outputObjInspector, parentOperators, PLOG, reporter, state, statsMap| Constructor and Description |
|---|
SMBMapJoinOperator() |
SMBMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc> mapJoinOp) |
| 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() |
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.apache.commons.logging.Log l4j) |
protected Collection<Future<?>> |
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, startGroupacceptLimitPushdown, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, completeInitializationOp, createDummy, defaultEndGroup, defaultStartGroup, dump, dump, 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, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logStats, opAllowedBeforeSortMergeJoin, 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, supportAutomaticSortMergeJoin, supportSkewJoinOptimization, supportUnionRemoveOptimization, toString, toStringpublic SMBMapJoinOperator()
public SMBMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc> mapJoinOp)
protected Collection<Future<?>> 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.apache.commons.logging.Log 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 OperatorType getType()
OperatorgetType in class AbstractMapJoinOperator<SMBJoinDesc>public boolean isConvertedAutomaticallySMBJoin()
public void setConvertedAutomaticallySMBJoin(boolean convertedAutomaticallySMBJoin)
public boolean opAllowedConvertMapJoin()
opAllowedConvertMapJoin in class Operator<SMBJoinDesc>Copyright © 2017 The Apache Software Foundation. All rights reserved.