public abstract class VectorMapJoinInnerBigOnlyGenerateResultOperator extends VectorMapJoinGenerateResultOperator
Operator.OperatorFunc, Operator.State
Modifier and Type | Field and Description |
---|---|
protected int[] |
allMatchs |
protected int[] |
equalKeySeriesAllMatchIndices |
protected int[] |
equalKeySeriesDuplicateCounts |
protected long[] |
equalKeySeriesValueCounts |
protected VectorMapJoinHashMultiSetResult[] |
hashMultiSetResults |
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 |
---|
VectorMapJoinInnerBigOnlyGenerateResultOperator() |
VectorMapJoinInnerBigOnlyGenerateResultOperator(VectorizationContext vContext,
OperatorDesc conf) |
Modifier and Type | Method and Description |
---|---|
protected void |
commonSetup(VectorizedRowBatch batch) |
protected void |
finishInnerBigOnly(VectorizedRowBatch batch,
int allMatchCount,
int equalKeySeriesCount,
int spillCount,
VectorMapJoinHashTableResult[] hashTableResults,
int hashMapResultCount)
Generate the inner big table only join output results for one vectorized row batch.
|
protected void |
finishInnerBigOnlyRepeated(VectorizedRowBatch batch,
JoinUtil.JoinResult joinResult,
VectorMapJoinHashMultiSetResult hashMultiSetResult) |
protected int |
generateHashMultiSetResultRepeatedAll(VectorizedRowBatch batch,
VectorMapJoinHashMultiSetResult hashMultiSetResult)
Generate the inner big table only 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 VectorMapJoinHashMultiSetResult[] hashMultiSetResults
protected transient int[] allMatchs
protected transient long[] equalKeySeriesValueCounts
protected transient int[] equalKeySeriesAllMatchIndices
protected transient int[] equalKeySeriesDuplicateCounts
protected transient int[] spills
protected transient int[] spillHashMapResultIndices
public VectorMapJoinInnerBigOnlyGenerateResultOperator()
public VectorMapJoinInnerBigOnlyGenerateResultOperator(VectorizationContext vContext, OperatorDesc conf) throws HiveException
HiveException
protected void commonSetup(VectorizedRowBatch batch) throws HiveException
commonSetup
in class VectorMapJoinGenerateResultOperator
HiveException
protected void finishInnerBigOnly(VectorizedRowBatch batch, int allMatchCount, int equalKeySeriesCount, int spillCount, VectorMapJoinHashTableResult[] hashTableResults, int hashMapResultCount) 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.equalKeySeriesCount
- Number of single value matches.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.hashMapResultCount
- Number of entries in hashMapResults.HiveException
IOException
protected int generateHashMultiSetResultRepeatedAll(VectorizedRowBatch batch, VectorMapJoinHashMultiSetResult hashMultiSetResult) throws HiveException
batch
- The big table batch with any matching and any non matching rows both as
selected in use.hashMultiSetResult
- The hash multi-set results for the batch.HiveException
protected void finishInnerBigOnlyRepeated(VectorizedRowBatch batch, JoinUtil.JoinResult joinResult, VectorMapJoinHashMultiSetResult hashMultiSetResult) throws HiveException, IOException
HiveException
IOException
Copyright © 2017 The Apache Software Foundation. All rights reserved.