public class VectorMapJoinBaseOperator extends MapJoinOperator implements VectorizationOperator, VectorizationContextRegion
Operator.Counter, Operator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch |
outputBatch |
protected Map<ObjectInspector,VectorAssignRow> |
outputVectorAssignRowMap |
protected org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch |
scratchBatch |
protected int |
tag |
protected VectorizationContext |
vContext |
protected VectorMapJoinDesc |
vectorDesc |
protected VectorizationContext |
vOutContext |
protected VectorizedRowBatchCtx |
vrbCtx |
firstSmallTable, hashMapRowGetters, isTestingNoHashTableLoad, loader, mapJoinTables, spilledMapJoinTablesemptyList, joinKeys, joinKeysObjectInspectors, posBigTablealias, aliasFilterTags, condn, countAfterReport, dummyObj, dummyObjVectors, filterMaps, filterTags, forwardCache, 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 |
VectorMapJoinBaseOperator()
Kryo ctor.
|
|
VectorMapJoinBaseOperator(CompilationOpContext ctx) |
|
VectorMapJoinBaseOperator(CompilationOpContext ctx,
OperatorDesc conf,
VectorizationContext vContext,
VectorDesc vectorDesc) |
| Modifier and Type | Method and Description |
|---|---|
void |
closeOp(boolean aborted)
All done.
|
VectorizationContext |
getInputVectorizationContext() |
static TypeInfo[] |
getOutputTypeInfos(MapJoinDesc desc) |
VectorizationContext |
getOutputVectorizationContext() |
VectorDesc |
getVectorDesc() |
void |
initializeOp(org.apache.hadoop.conf.Configuration hconf)
Operator specific initialization.
|
protected void |
internalForward(Object row,
ObjectInspector outputOI)
'forwards' the (row-mode) record into the (vectorized) output batch
|
protected void |
reProcessBigTable(int partitionId)
For a vectorized row batch from the rows feed from the super MapJoinOperator.
|
canSkipJoinProcessing, canSkipReload, cleanUpInputFileChangedOp, completeInitializationOp, endGroup, generateMapMetaData, getCacheKey, getHashTableLoader, getName, getOperatorName, getRefKey, getType, getValueObjectInspectors, isInputFileChangeSensitive, loadHashTable, process, reloadHashTable, setMapJoinKey, setTestMapJoinTableContainer, spillBigTableRow, startGroupcheckAndGenObject, getFilteredValue, getFilterTag, getNextSize, getPosToAliasMap, hasFilter, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, reportProgress, setPosToAliasMapabort, acceptLimitPushdown, allInitializedParentsAreClosed, areAllParentsInitialized, augmentPlan, cleanUpInputFileChanged, clone, cloneOp, cloneRecursiveChildren, close, columnNamesRowResolvedCanBeObtained, 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, initializeLocalWork, initOperatorId, isUseBucketizedHiveInputFormat, jobClose, jobCloseOp, logicalEquals, logicalEqualsTree, logStats, opAllowedBeforeSortMergeJoin, opAllowedConvertMapJoin, 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 VectorizationContext vContext
protected VectorMapJoinDesc vectorDesc
protected VectorizationContext vOutContext
protected transient org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch outputBatch
protected transient org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch scratchBatch
protected transient Map<ObjectInspector,VectorAssignRow> outputVectorAssignRowMap
protected transient VectorizedRowBatchCtx vrbCtx
protected transient int tag
protected VectorMapJoinBaseOperator()
public VectorMapJoinBaseOperator(CompilationOpContext ctx)
public VectorMapJoinBaseOperator(CompilationOpContext ctx, OperatorDesc conf, VectorizationContext vContext, VectorDesc vectorDesc) throws HiveException
HiveExceptionpublic VectorizationContext getInputVectorizationContext()
getInputVectorizationContext in interface VectorizationOperatorpublic static TypeInfo[] getOutputTypeInfos(MapJoinDesc desc)
public void initializeOp(org.apache.hadoop.conf.Configuration hconf)
throws HiveException
OperatorinitializeOp in class MapJoinOperatorHiveExceptionprotected void internalForward(Object row, ObjectInspector outputOI) throws HiveException
internalForward in class CommonJoinOperator<MapJoinDesc>HiveExceptionpublic void closeOp(boolean aborted)
throws HiveException
CommonJoinOperatorcloseOp in class MapJoinOperatorHiveExceptionprotected void reProcessBigTable(int partitionId)
throws HiveException
reProcessBigTable in class MapJoinOperatorpartitionId - the partition from which to take out spilled big table rowsHiveExceptionpublic VectorizationContext getOutputVectorizationContext()
getOutputVectorizationContext in interface VectorizationContextRegionpublic VectorDesc getVectorDesc()
getVectorDesc in interface VectorizationOperatorCopyright © 2019 The Apache Software Foundation. All Rights Reserved.