public class VectorMapJoinBaseOperator extends MapJoinOperator implements VectorizationContextRegion
Operator.OperatorFunc, Operator.State| Modifier and Type | Field and Description |
|---|---|
protected VectorizedRowBatch |
outputBatch |
protected Map<ObjectInspector,VectorAssignRowSameBatch> |
outputVectorAssignRowMap |
protected VectorizedRowBatch |
scratchBatch |
protected int |
tag |
protected VectorizationContext |
vOutContext |
protected VectorizedRowBatchCtx |
vrbCtx |
firstSmallTable, hashMapRowGetters, loader, mapJoinTables, spilledMapJoinTablesemptyList, joinKeys, joinKeysObjectInspectors, posBigTablealias, aliasFilterTags, condn, countAfterReport, dummyObj, dummyObjVectors, filterMaps, filterTags, forwardCache, 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 |
|---|
VectorMapJoinBaseOperator() |
VectorMapJoinBaseOperator(VectorizationContext vContext,
OperatorDesc conf) |
| Modifier and Type | Method and Description |
|---|---|
void |
closeOp(boolean aborted)
All done.
|
VectorizationContext |
getOuputVectorizationContext() |
Collection<Future<?>> |
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.
|
cleanUpInputFileChangedOp, completeInitializationOp, endGroup, generateMapMetaData, getHashTableLoader, getName, getOperatorName, getRefKey, getType, getValueObjectInspectors, loadHashTable, process, reloadHashTable, setMapJoinKey, spillBigTableRow, startGroupcheckAndGenObject, getFilteredValue, getFilterTag, getNextSize, getPosToAliasMap, hasFilter, opAllowedAfterMapJoin, opAllowedBeforeMapJoin, reportProgress, setPosToAliasMapacceptLimitPushdown, 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, toStringprotected VectorizationContext vOutContext
protected transient VectorizedRowBatch outputBatch
protected transient VectorizedRowBatch scratchBatch
protected transient Map<ObjectInspector,VectorAssignRowSameBatch> outputVectorAssignRowMap
protected transient VectorizedRowBatchCtx vrbCtx
protected transient int tag
public VectorMapJoinBaseOperator()
public VectorMapJoinBaseOperator(VectorizationContext vContext, OperatorDesc conf) throws HiveException
HiveExceptionpublic Collection<Future<?>> 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 getOuputVectorizationContext()
getOuputVectorizationContext in interface VectorizationContextRegionCopyright © 2017 The Apache Software Foundation. All rights reserved.