public abstract class VectorMapJoinLeftSemiGenerateResultOperator extends VectorMapJoinGenerateResultOperator
Operator.OperatorFunc, Operator.State
Modifier and Type | Field and Description |
---|---|
protected int[] |
allMatchs |
protected VectorMapJoinHashSetResult[] |
hashSetResults |
protected int[] |
spillHashMapResultIndices |
protected int[] |
spills |
batchCounter
bigTableByteColumnVectorColumns, bigTableFilterExpressions, bigTableKeyColumnMap, bigTableKeyExpressions, bigTableKeyTypeNames, bigTableOuterKeyMapping, bigTableOuterKeyOutputVectorColumns, bigTableRetainedMapping, bigTableRetainedVectorCopy, bigTableValueColumnMap, bigTableValueExpressions, bigTableValueTypeNames, bigTableVectorCopyOuterKeys, isOuterJoin, needCommonSetup, needHashTableSetup, outputProjection, outputTypeNames, overflowBatch, overflowRepeatedThreshold, posSingleVectorMapJoinSmallTable, smallTableByteColumnVectorColumns, smallTableMapping, smallTableOutputVectorColumns, smallTableVectorDeserializeRow, spillReplayBatch, taskName, useOverflowRepeatedThreshold, vContext, vectorMapJoinHashTable, vOutContext
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 |
---|
VectorMapJoinLeftSemiGenerateResultOperator() |
VectorMapJoinLeftSemiGenerateResultOperator(VectorizationContext vContext,
OperatorDesc conf) |
Modifier and Type | Method and Description |
---|---|
protected void |
commonSetup(VectorizedRowBatch batch) |
protected void |
finishLeftSemi(VectorizedRowBatch batch,
int allMatchCount,
int spillCount,
VectorMapJoinHashTableResult[] hashTableResults)
Generate the left semi join output results for one vectorized row batch.
|
protected void |
finishLeftSemiRepeated(VectorizedRowBatch batch,
JoinUtil.JoinResult joinResult,
VectorMapJoinHashTableResult hashSetResult) |
protected int |
generateHashSetResultRepeatedAll(VectorizedRowBatch batch)
Generate the left semi join output results for one vectorized row batch with a repeated key.
|
closeOp, forwardBigTableBatch, forwardOverflow, generateHashMapResultMultiValue, generateHashMapResultRepeatedAll, generateHashMapResultSingleValue, intArrayToRangesString, longArrayToRangesString, performValueExpressions, reloadHashTable, reProcessBigTable, spillBatchRepeated, spillHashMapBatch, verifyMonotonicallyIncreasing
determineCommonInfo, displayBatchColumns, getHashTableLoader, getOuputVectorizationContext, getType, initializeOp, loadHashTable, setupOverflowBatch, setupVOutContext
cleanUpInputFileChangedOp, completeInitializationOp, endGroup, generateMapMetaData, getName, getOperatorName, getRefKey, getValueObjectInspectors, process, 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 transient VectorMapJoinHashSetResult[] hashSetResults
protected transient int[] allMatchs
protected transient int[] spills
protected transient int[] spillHashMapResultIndices
public VectorMapJoinLeftSemiGenerateResultOperator()
public VectorMapJoinLeftSemiGenerateResultOperator(VectorizationContext vContext, OperatorDesc conf) throws HiveException
HiveException
protected void commonSetup(VectorizedRowBatch batch) throws HiveException
commonSetup
in class VectorMapJoinGenerateResultOperator
HiveException
protected void finishLeftSemi(VectorizedRowBatch batch, int allMatchCount, int spillCount, VectorMapJoinHashTableResult[] hashTableResults) throws HiveException, IOException
batch
- The big table batch with any matching and any non matching rows both as
selected in use.allMatchCount
- Number of matches in allMatchs.spillCount
- Number of spills in spills.hashTableResults
- The array of all hash table results for the batch. We need the
VectorMapJoinHashTableResult for the spill information.HiveException
IOException
protected int generateHashSetResultRepeatedAll(VectorizedRowBatch batch) throws HiveException
batch
- The big table batch whose repeated key matches.HiveException
protected void finishLeftSemiRepeated(VectorizedRowBatch batch, JoinUtil.JoinResult joinResult, VectorMapJoinHashTableResult hashSetResult) throws HiveException, IOException
HiveException
IOException
Copyright © 2017 The Apache Software Foundation. All rights reserved.