public abstract class VectorMapJoinCommonOperator extends MapJoinOperator implements VectorizationContextRegion
Operator.OperatorFunc, Operator.State
firstSmallTable, hashMapRowGetters, loader, mapJoinTables, spilledMapJoinTables
emptyList, joinKeys, joinKeysObjectInspectors, posBigTable
alias, aliasFilterTags, condn, countAfterReport, dummyObj, dummyObjVectors, filterMaps, filterTags, forwardCache, heartbeatInterval, intermediate, joinFilterObjectInspectors, joinFilters, joinValues, joinValuesObjectInspectors, joinValuesStandardObjectInspectors, noOuterJoin, NOTSKIPBIGTABLE, nullsafes, numAliases, offsets, order, rowContainerStandardObjectInspectors, skipVectors, spillTableDesc, totalSz
childOperators, 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 |
---|
VectorMapJoinCommonOperator() |
VectorMapJoinCommonOperator(VectorizationContext vContext,
OperatorDesc conf) |
Modifier and Type | Method and Description |
---|---|
protected void |
commonSetup(VectorizedRowBatch batch) |
protected void |
determineCommonInfo(boolean isOuter) |
protected void |
displayBatchColumns(VectorizedRowBatch batch,
String batchName) |
protected HashTableLoader |
getHashTableLoader(org.apache.hadoop.conf.Configuration hconf)
This override lets us substitute our own fast vectorized hash table loader.
|
VectorizationContext |
getOuputVectorizationContext() |
OperatorType |
getType()
Return the type of the specific operator among the
types in OperatorType.
|
protected Collection<Future<?>> |
initializeOp(org.apache.hadoop.conf.Configuration hconf)
Operator specific initialization.
|
protected org.apache.commons.lang3.tuple.Pair<MapJoinTableContainer[],MapJoinTableContainerSerDe[]> |
loadHashTable(ExecMapperContext mapContext,
MapredContext mrContext) |
protected VectorizedRowBatch |
setupOverflowBatch() |
protected void |
setupVOutContext(List<String> outputColumnNames)
Setup the vectorized row batch description of the output of the native vectorized map join
operator.
|
cleanUpInputFileChangedOp, closeOp, completeInitializationOp, endGroup, generateMapMetaData, getName, getOperatorName, getRefKey, getValueObjectInspectors, process, reloadHashTable, reProcessBigTable, setMapJoinKey, spillBigTableRow, startGroup
checkAndGenObject, getFilteredValue, getFilterTag, getNextSize, getPosToAliasMap, hasFilter, internalForward, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, reportProgress, setPosToAliasMap
acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, 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, initializeLocalWork, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logStats, opAllowedBeforeSortMergeJoin, opAllowedConvertMapJoin, 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, toString
protected boolean isOuterJoin
protected byte posSingleVectorMapJoinSmallTable
protected VectorizationContext vContext
protected VectorizationContext vOutContext
protected int[] outputProjection
protected String[] outputTypeNames
protected VectorExpression[] bigTableFilterExpressions
protected VectorExpression[] bigTableKeyExpressions
protected VectorExpression[] bigTableValueExpressions
protected int[] bigTableKeyColumnMap
protected int[] bigTableValueColumnMap
protected VectorColumnOutputMapping bigTableRetainedMapping
protected VectorColumnOutputMapping bigTableOuterKeyMapping
protected VectorColumnSourceMapping smallTableMapping
protected int[] smallTableOutputVectorColumns
protected int[] bigTableOuterKeyOutputVectorColumns
protected int[] bigTableByteColumnVectorColumns
protected int[] smallTableByteColumnVectorColumns
protected transient String taskName
protected transient boolean useOverflowRepeatedThreshold
protected transient int overflowRepeatedThreshold
protected transient VectorCopyRow bigTableRetainedVectorCopy
protected transient VectorCopyRow bigTableVectorCopyOuterKeys
protected transient VectorDeserializeRow smallTableVectorDeserializeRow
protected transient VectorizedRowBatch overflowBatch
protected transient VectorizedRowBatch spillReplayBatch
protected transient boolean needCommonSetup
protected transient boolean needHashTableSetup
protected transient VectorMapJoinHashTable vectorMapJoinHashTable
public VectorMapJoinCommonOperator()
public VectorMapJoinCommonOperator(VectorizationContext vContext, OperatorDesc conf) throws HiveException
HiveException
protected void determineCommonInfo(boolean isOuter)
protected void setupVOutContext(List<String> outputColumnNames)
protected HashTableLoader getHashTableLoader(org.apache.hadoop.conf.Configuration hconf)
getHashTableLoader
in class MapJoinOperator
protected Collection<Future<?>> initializeOp(org.apache.hadoop.conf.Configuration hconf) throws HiveException
Operator
initializeOp
in class MapJoinOperator
HiveException
protected org.apache.commons.lang3.tuple.Pair<MapJoinTableContainer[],MapJoinTableContainerSerDe[]> loadHashTable(ExecMapperContext mapContext, MapredContext mrContext) throws HiveException
loadHashTable
in class MapJoinOperator
HiveException
protected VectorizedRowBatch setupOverflowBatch() throws HiveException
HiveException
protected void commonSetup(VectorizedRowBatch batch) throws HiveException
HiveException
protected void displayBatchColumns(VectorizedRowBatch batch, String batchName)
public OperatorType getType()
Operator
getType
in class MapJoinOperator
public VectorizationContext getOuputVectorizationContext()
getOuputVectorizationContext
in interface VectorizationContextRegion
Copyright © 2017 The Apache Software Foundation. All rights reserved.