Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.hadoop.hive.ql.optimizer Classes and Interfaces - 334 results found.
NameDescriptionTypePackageFramework
AbstractBucketJoinProcthis transformation does bucket map join optimization.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
AbstractJoinTaskDispatcherCommon iteration methods for converting joins and sort-merge joins.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
AbstractSMBJoinProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
AnnotateOpTraitsProcCtxClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotationApache Hive
AnnotateStatsProcCtxClassorg.apache.hadoop.hive.ql.optimizer.stats.annotationApache Hive
AnnotateWithOpTraitsClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotationApache Hive
AnnotateWithStatisticsClassorg.apache.hadoop.hive.ql.optimizer.stats.annotationApache Hive
ASTConverterClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
AvgPartitionSizeBasedBigTableSelectorForAutoSMJClassorg.apache.hadoop.hive.ql.optimizerApache Hive
BigTableSelectorForAutoSMJInterfaceorg.apache.hadoop.hive.ql.optimizerApache Hive
BucketingSortingCtxThis class contains the bucketing sorting context that is passed while walking the operator tree in inferring bucket/sort columns.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
BucketingSortingCtx .BucketCol An implementation of BucketSortCol which contains known aliases/indexes of equivalent columns which data is determined to be bucketed on.Classorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtxApache Hive
BucketingSortingCtx .BucketSortCol Classes that implement this interface provide a way to store information about equivalent columns as their names and indexes in the schema change going into and out of operators.Interfaceorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtxApache Hive
BucketingSortingCtx .SortCol An implementation of BucketSortCol which contains known aliases/indexes of equivalent columns which data is determined to be sorted on.Classorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingCtxApache Hive
BucketingSortingInferenceOptimizerBucketingSortingInferenceOptimizer.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
BucketingSortingOpProcFactoryOperator factory for the rule processors for inferring bucketing/sorting columns.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
BucketingSortingOpProcFactory .DefaultInferrerClassorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingOpProcFactory .FileSinkInferrerProcessor for FileSink operator.Classorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingOpProcFactory .ForwardingInferrerClassorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingOpProcFactory .GroupByInferrerProcessor for GroupBy operator.Classorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingOpProcFactory .JoinInferrerProcessor for Join Operator.Classorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingOpProcFactory .MultiGroupByInferrerProcessor for GroupByOperator, the special case where it follows a ForwardOperator There is a multi group by optimization which puts multiple group by operators in aClassorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingOpProcFactory .SelectInferrerProcessor for Select operator.Classorg.apache.hadoop.hive.ql.optimizer.physical.BucketingSortingOpProcFactoryApache Hive
BucketingSortingReduceSinkOptimizerThis transformation does optimization for enforcing bucketing and sorting.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
BucketJoinProcCtxClassorg.apache.hadoop.hive.ql.optimizerApache Hive
BucketMapJoinOptimizerthis transformation does bucket map join optimization.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
BucketMapjoinProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
CalciteSemanticExceptionException from SemanticAnalyzer.Classorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
CalciteSemanticException .UnsupportedFeatureClassorg.apache.hadoop.hive.ql.optimizer.calcite.CalciteSemanticExceptionApache Hive
ColumnPruner the current operator tree.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
ColumnPruner .ColumnPrunerWalkerWalks the op tree in post order fashion (skips selects with file sink or script op children).Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerApache Hive
ColumnPrunerProcCtxThis class implements the processor context for Column Pruner.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
ColumnPrunerProcFactoryFactory for generating the different node processors used by ColumnPruner.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
ColumnPrunerProcFactory .ColumnPrunerDefaultProcThe Default Node Processor for Column Pruning.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerFilterProcNode Processor for Column Pruning on Filter Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerGroupByProcNode Processor for Column Pruning on Group By Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerJoinProcThe Node Processor for Column Pruning on Join Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerLateralViewForwardProcThe Node Processor for Column Pruning on Lateral View Forward Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerLateralViewJoinProcThe Node Processor for Column Pruning on Lateral View Join Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerLimitProcClassorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerMapJoinProcThe Node Processor for Column Pruning on Map Join Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerPTFProc- Pruning can only be done for Windowing.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerReduceSinkProcThe Node Processor for Column Pruning on Reduce Sink Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerScriptProcClassorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerSelectProcThe Node Processor for Column Pruning on Select Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
ColumnPrunerProcFactory .ColumnPrunerTableScanProcThe Node Processor for Column Pruning on Table Scan Operators.Classorg.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactoryApache Hive
CommonJoinResolverClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
CommonJoinTaskDispatcherIterator each tasks.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
ConstantPropagate from root to child.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
ConstantPropagate .ConstantPropagateWalkerWalks the op tree in root first order.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateApache Hive
ConstantPropagateProcCtxThis class implements the processor context for Constant Propagate.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
ConstantPropagateProcFactoryFactory for generating the different node processors used by ConstantPropagate.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
ConstantPropagateProcFactory .ConstantPropagateDefaultProcThe Default Node Processor for Constant Propagation.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateFileSinkProcThe Node Processor for constant propagation for FileSink Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateFilterProcNode Processor for Constant Propagation on Filter Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateGroupByProcNode Processor for Constant Propagate for Group By Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateJoinProcThe Node Processor for Constant Propagation for Join Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateReduceSinkProcThe Node Processor for Constant Propagation for ReduceSink Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateSelectProcThe Node Processor for Constant Propagation for Select Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateStopProcThe Node Processor for Constant Propagation for Operators which is designed to stop propagate.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConstantPropagateProcFactory .ConstantPropagateTableScanProcThe Node Processor for Constant Propagation for Table Scan Operators.Classorg.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactoryApache Hive
ConvertJoinMapJoinConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicateClassorg.apache.hadoop.hive.ql.optimizerApache Hive
CorrelationOptimizer the paper "YSmart: Yet Another SQL-to-MapReduce Translator" (Rubao Lee, Tian Luo, Yin Huai, Fusheng Wang, Yongqiang He, and Xiaodong Zhang)Classorg.apache.hadoop.hive.ql.optimizer.correlationApache Hive
CorrelationUtilitiesUtilities for both CorrelationOptimizer and ReduceSinkDeDuplication.Classorg.apache.hadoop.hive.ql.optimizer.correlationApache Hive
CrossProductCheckClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
CrossProductCheck .ExtractReduceSinkInfoClassorg.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheckApache Hive
CrossProductCheck .MapJoinCheckClassorg.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheckApache Hive
DynamicPartitionPruningOptimizationThis optimization looks for expressions of the kind "x IN (RS[n])".Classorg.apache.hadoop.hive.ql.optimizerApache Hive
DynamicPartitionPruningOptimization .DynamicPartitionPrunerProcClassorg.apache.hadoop.hive.ql.optimizer.DynamicPartitionPruningOptimizationApache Hive
ExprNodeConverterClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
ExprProcCtxThe processor context for the lineage information.Classorg.apache.hadoop.hive.ql.optimizer.lineageApache Hive
ExprProcCtxThe processor context for partition pruner.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
ExprProcFactoryExpression processor factory for lineage.Classorg.apache.hadoop.hive.ql.optimizer.lineageApache Hive
ExprProcFactoryExpression processor factory for partition pruning.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
ExprProcFactory .ColumnExprProcessorProcessor for column expressions.Classorg.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactoryApache Hive
ExprProcFactory .DefaultExprProcessorProcessor for constants and null expressions.Classorg.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactoryApache Hive
ExprProcFactory .GenericExprProcessorProcessor for any function or field expression.Classorg.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactoryApache Hive
ExprProcFactory .PPRColumnExprProcessorProcessor for ppr column expressions.Classorg.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactoryApache Hive
ExprPrunerInfoThe processor context for partition pruner.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
FilterSelectivityEstimatorClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
GeneratorThis class generates the lineage information for the columns and tables from the plan before it goes through otherClassorg.apache.hadoop.hive.ql.optimizer.lineageApache Hive
GenMapRedUtilsClassorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRFileSink1Processor for the rule - table scan followed by reduce sink.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMROperatorProcessor for the rule - no specific rule fired.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRProcContextProcessor Context for creating map reduce task.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRProcContext .GenMapRedCtxGenMapRedCtx is used to keep track of the current state.Classorg.apache.hadoop.hive.ql.optimizer.GenMRProcContextApache Hive
GenMRProcContext .GenMRUnionCtxClassorg.apache.hadoop.hive.ql.optimizer.GenMRProcContextApache Hive
GenMRRedSink1Processor for the rule - table scan followed by reduce sink.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRRedSink2Processor for the rule - reduce sink followed by reduce sink.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRRedSink3Processor for the rule - union followed by reduce sink.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRSkewJoinProcessorGenMRSkewJoinProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
GenMRTableScan1Processor for the rule - table scan.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenMRUnion1Processor for the rule - TableScan followed by Union.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GenSparkSkewJoinProcessorCopied from GenMRSkewJoinProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
GlobalLimitOptimizerThis optimizer is used to reduce the input size for the query for queries which are specifying a limit.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GroupByOptimizerThis transformation does group by optimization.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
GroupByOptimizer .GroupByOptimizerSortMatchClassorg.apache.hadoop.hive.ql.optimizer.GroupByOptimizerApache Hive
HiveAggregateClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveAlgorithmsConfClassorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveAlgorithmsUtilClassorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveCalciteUtilGeneric utility functions needed for Calcite based Hive CBO.Classorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveCalciteUtil .ConstantFinderWalks over an expression and determines whether it is constant.Classorg.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtilApache Hive
HiveCalciteUtil .JoinLeafPredicateInfoJoinLeafPredicateInfo represents leaf predicate in Join condition (conjuctive lement).Classorg.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtilApache Hive
HiveCalciteUtil .JoinPredicateInfoJoinPredicateInfo represents Join condition; JoinPredicate Info uses JoinLeafPredicateInfo to represent individual conjunctive elements in theClassorg.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtilApache Hive
HiveConfigContextClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveCost 1.Classorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveCostModelCost model interface.Classorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveCostModel .JoinAlgorithmInterfaceorg.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveCostModelApache Hive
HiveDefaultCostModelDefault implementation of the cost model.Classorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveDefaultCostModel .DefaultJoinAlgorithmDefault join algorithm.Classorg.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveDefaultCostModelApache Hive
HiveDefaultRelMetadataProviderClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveExpandDistinctAggregatesRulePlanner rule that expands distinct aggregates (such as COUNT(DISTINCT x)) from aClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveFilterClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveFilterJoinRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveFilterJoinRule .HiveFilterJoinMergeRuleRule that tries to push filter expressions into a join condition and into the inputs of the join.Classorg.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRuleApache Hive
HiveFilterJoinRule .HiveFilterJoinTransposeRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRuleApache Hive
HiveFilterProjectTransposeRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveFilterSetOpTransposeRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveGBOpConvUtil 1.Classorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
HiveGroupingIDClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveInsertExchange4JoinRuleNot an optimization rule.Classorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveJoinClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveJoin .MapJoinStreamingRelationClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoinApache Hive
HiveJoinAddNotNullRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveJoinToMultiJoinRuleRule that merges a join with multijoin/join children if the equi compared the same set of input columns.Classorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveLimitClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveOnTezCostModelCost model for Tez execution engine.Classorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveOnTezCostModel .TezBucketJoinAlgorithmBUCKET_JOIN is a hash joins where one bucket of the non streaming tables is kept in memory at the time.Classorg.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModelApache Hive
HiveOnTezCostModel .TezCommonJoinAlgorithmCOMMON_JOIN is Sort Merge Join.Classorg.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModelApache Hive
HiveOnTezCostModel .TezMapJoinAlgorithmClassorg.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModelApache Hive
HiveOnTezCostModel .TezSMBJoinAlgorithmSMB_JOIN is a Sort Merge Join.Classorg.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveOnTezCostModelApache Hive
HiveOpConverterClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
HiveOpConverter .HIVEAGGOPMODEClassorg.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverterApache Hive
HiveOpConverterPostProcClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
HivePartitionPruneRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HivePreFilteringRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveProjectClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveProjectMergeRuleClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveRelCollationClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveRelDistributionClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveRelFieldTrimmerClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
HiveRelMdCollationClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdCostHiveRelMdCost supplies the implementation of cost model.Classorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveRelMdDistinctRowCountClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdDistributionClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdMemoryClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdParallelismClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdRowCountClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdSelectivityClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdSizeClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelMdUniqueKeysClassorg.apache.hadoop.hive.ql.optimizer.calcite.statsApache Hive
HiveRelNodeInterfaceorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveRelNode .ImplementorClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveRelNodeApache Hive
HiveRelOptUtilClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveSortClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveSortExchangeClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveTableScanRelational expression representing a scan of a HiveDB collection.Classorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveTypeSystemImplClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
HiveUnionClassorg.apache.hadoop.hive.ql.optimizer.calcite.reloperatorsApache Hive
HiveVolcanoPlannerRefinement of VolcanoPlanner for Hive.Classorg.apache.hadoop.hive.ql.optimizer.calcite.costApache Hive
HiveWindowingFixRuleRule to fix windowing issue when it is done over aggregation columns (more info in HIVE-10627).Classorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
IdentityProjectRemoverThis optimization tries to remove SelectOperator from tree which don't do any processing except forwarding columns from its parent to its children.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
IndexUtilsUtility class for index support.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
IndexWhereProcCtxClassorg.apache.hadoop.hive.ql.optimizer.physical.indexApache Hive
IndexWhereProcessorIndexWhereProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physical.indexApache Hive
IndexWhereResolverClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
IndexWhereTaskDispatcherIndexWhereTaskDispatcher.Classorg.apache.hadoop.hive.ql.optimizer.physical.indexApache Hive
IntraQueryCorrelationIntraQueryCorrelation records a sub-tree of the query plan tree which can be evaluated in a single MR job.Classorg.apache.hadoop.hive.ql.optimizer.correlationApache Hive
JoinCondTypeCheckProcFactory 1.Classorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
JoinCondTypeCheckProcFactory .JoinCondColumnExprProcessorProcessor for table columns.Classorg.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactoryApache Hive
JoinCondTypeCheckProcFactory .JoinCondDefaultExprProcessorThe default processor for typechecking.Classorg.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactoryApache Hive
JoinReorder hints to specify which tables are to be streamed and they are moved to have largest tag so that they are processed last.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
JoinTypeCheckCtx 1.Classorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
LBExprProcCtxThe processor context for list bucketing pruner.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LBExprProcFactoryExpression processor factory for list bucketing pruning.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LBExprProcFactory .LBPRColumnExprProcessorProcessor for lbpr column expressions.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBExprProcFactoryApache Hive
LBOpPartitionWalkerCtxClassorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LBOpWalkerCtxContext used by list bucketing to walk operator trees to generate expression tree.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LBPartitionProcFactoryWalk through top operators in tree to find all partitions.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LBPartitionProcFactory .LBPRPartitionFilterPrunerRetrieve partitions for the filter.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBPartitionProcFactoryApache Hive
LBProcFactoryOperator factory for list bucketing pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LBProcFactory .LBPRFilterPrunerDetermines the list bucketing pruner for the filter.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingpruner.LBProcFactoryApache Hive
LeftmostBigTableSelectorForAutoSMJClassorg.apache.hadoop.hive.ql.optimizerApache Hive
LimitPushdownOptimizerMake RS calculate top-K selection for limit clause.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
LineageCtxThis class contains the lineage context that is passed while walking the operator tree in Lineage.Classorg.apache.hadoop.hive.ql.optimizer.lineageApache Hive
LineageCtx .IndexClassorg.apache.hadoop.hive.ql.optimizer.lineage.LineageCtxApache Hive
ListBucketingPrunerThe transformation step that does list bucketing pruning.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
ListBucketingPruner .DynamicMultiDimensionalCollectionNote: this class is not designed to be used in general but for list bucketing pruner only.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPrunerApache Hive
ListBucketingPrunerUtilsUtility for list bucketing prune.Classorg.apache.hadoop.hive.ql.optimizer.listbucketingprunerApache Hive
LocalMapJoinProcFactoryNode processor factory for map join resolver.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
LocalMapJoinProcFactory .LocalMapJoinProcessorLocalMapJoinProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactoryApache Hive
LocalMapJoinProcFactory .MapJoinFollowedByGroupByProcessorMapJoinFollowByProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactoryApache Hive
MapJoinFactoryOperator factory for MapJoin processing.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
MapJoinProcessor map-joins and during this optimization, all user specified map joins are converted to MapJoins - the reduce sink operator above the join are converted to map sink operators.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
MapJoinProcessor .CurrentMapJoinClassorg.apache.hadoop.hive.ql.optimizer.MapJoinProcessorApache Hive
MapJoinProcessor .DefaultClassorg.apache.hadoop.hive.ql.optimizer.MapJoinProcessorApache Hive
MapJoinProcessor .MapJoinDefaultClassorg.apache.hadoop.hive.ql.optimizer.MapJoinProcessorApache Hive
MapJoinProcessor .MapJoinFSClassorg.apache.hadoop.hive.ql.optimizer.MapJoinProcessorApache Hive
MapJoinProcessor .MapJoinWalkerCtxClassorg.apache.hadoop.hive.ql.optimizer.MapJoinProcessorApache Hive
MapJoinResolverAn implementation of PhysicalPlanResolver.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
MapJoinResolver .LocalMapJoinProcCtxA container of current task and parse context.Classorg.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolverApache Hive
MergeJoinProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
MetadataOnlyOptimizerMetadataOnlyOptimizer determines to which TableScanOperators "metadata only" optimization can be applied.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
NonBlockingOpDeDupProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
NullScanOptimizerThis optimizer attempts following two optimizations: 1.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
NullScanTaskDispatcherIterate over all tasks one by one and removes all input paths from task if conditions as defined in rules match.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
OpProcFactoryOperator factory for the rule processors for lineage.Classorg.apache.hadoop.hive.ql.optimizer.lineageApache Hive
OpProcFactoryOperator factory for partition pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
OpProcFactory .DefaultLineageDefault processor.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .FilterPPRDetermines the partition pruner for the filter.Classorg.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactoryApache Hive
OpProcFactory .GroupByLineageProcessor for GroupBy operator.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .JoinLineageProcessor for Join Operator.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .LateralViewJoinLineageProcessor for Join Operator.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .ReduceSinkLineageReduceSink processor.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .SelectLineageProcessor for Select operator.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .TableScanLineageProcessor for TableScan Operator.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .TransformLineageProcessor for Script and UDTF Operators.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OpProcFactory .UnionLineage In this case we call mergeDependency as opposed to putDependency in order to account for visits from different parents.Classorg.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactoryApache Hive
OptimizerClassorg.apache.hadoop.hive.ql.optimizerApache Hive
OpTraitsRulesProcFactoryClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotationApache Hive
OpTraitsRulesProcFactory .DefaultRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpTraitsRulesProcFactory .GroupByRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpTraitsRulesProcFactory .JoinRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpTraitsRulesProcFactory .MultiParentRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpTraitsRulesProcFactory .ReduceSinkRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpTraitsRulesProcFactory .SelectRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpTraitsRulesProcFactory .TableScanRuleClassorg.apache.hadoop.hive.ql.optimizer.metainfo.annotation.OpTraitsRulesProcFactoryApache Hive
OpWalkerCtxContext class for operator tree walker for partition pruner.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
PartExprEvalUtilsClassorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
PartitionConditionRemoverThe transformation step that does partition condition remover.Classorg.apache.hadoop.hive.ql.optimizer.pcrApache Hive
PartitionExpressionForMetastoreThe basic implementation of PartitionExpressionProxy that uses ql package classes.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
PartitionPruneClassorg.apache.hadoop.hive.ql.optimizer.calcite.rulesApache Hive
PartitionPrune .ExtractPartPruningPredicateClassorg.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPruneApache Hive
PartitionPrune .ExtractRemainingPredicateClassorg.apache.hadoop.hive.ql.optimizer.calcite.rules.PartitionPruneApache Hive
PartitionPrunerThe transformation step that does partition pruning.Classorg.apache.hadoop.hive.ql.optimizer.pprApache Hive
PcrExprProcCtxThe processor context for partition condition remover.Classorg.apache.hadoop.hive.ql.optimizer.pcrApache Hive
PcrExprProcFactoryExpression processor factory for partition condition removing.Classorg.apache.hadoop.hive.ql.optimizer.pcrApache Hive
PcrExprProcFactory .ColumnExprProcessorProcessor for column expressions.Classorg.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactoryApache Hive
PcrExprProcFactory .DefaultExprProcessorProcessor for constants and null expressions.Classorg.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactoryApache Hive
PcrExprProcFactory .FieldExprProcessorClassorg.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactoryApache Hive
PcrExprProcFactory .GenericFuncExprProcessorProcessor for Generic functions If it is AND, OR or NOT, we replace the node to be the constant true orClassorg.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactoryApache Hive
PcrExprProcFactory .NodeInfoWrapperClassorg.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactoryApache Hive
PcrExprProcFactory .WalkStateClassorg.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactoryApache Hive
PcrOpProcFactoryPcrOpProcFactory contains processors that process expression tree of filter operators following table scan operators.Classorg.apache.hadoop.hive.ql.optimizer.pcrApache Hive
PcrOpProcFactory .DefaultPCRClassorg.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactoryApache Hive
PcrOpProcFactory .FilterPCRRemove partition condition in a filter operator when possible.Classorg.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactoryApache Hive
PcrOpWalkerCtxContext class for operator tree walker for partition condition remover.Classorg.apache.hadoop.hive.ql.optimizer.pcrApache Hive
PcrOpWalkerCtx .OpToDeleteInfoClassorg.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtxApache Hive
PhysicalContextphysical context used by physical resolvers.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
PhysicalOptimizerA hierarchy physical optimizer, which contains a list of PhysicalPlanResolver.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
PhysicalPlanResolverPhysical plan optimization interface.Interfaceorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
PlanModifierForASTConvClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
PlanModifierForReturnPathClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
PlanModifierUtilClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
PrunerExpressionOperatorFactoryExpression processor factory for pruning.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
PrunerExpressionOperatorFactory .ColumnExprProcessorProcessor for column expressions.Classorg.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactoryApache Hive
PrunerExpressionOperatorFactory .DefaultExprProcessorProcessor for constants and null expressions.Classorg.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactoryApache Hive
PrunerExpressionOperatorFactory .FieldExprProcessorClassorg.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactoryApache Hive
PrunerExpressionOperatorFactory .GenericFuncExprProcessorIf all children are candidates and refer only to one table alias then this expr is a candidate else it is not a candidate but its children could beClassorg.apache.hadoop.hive.ql.optimizer.PrunerExpressionOperatorFactoryApache Hive
PrunerOperatorFactoryOperator factory for pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
PrunerOperatorFactory .DefaultPrunerDefault processor which just merges its children.Classorg.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactoryApache Hive
PrunerOperatorFactory .FilterPrunerDetermines the partition pruner for the filter.Classorg.apache.hadoop.hive.ql.optimizer.PrunerOperatorFactoryApache Hive
PrunerUtilsGeneral utility common functions for the Pruner to do optimization.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
QueryPlanTreeTransformationQueryPlanTreeTransformation contains static methods used to transform the query plan tree (operator tree) based on the correlation we haveClassorg.apache.hadoop.hive.ql.optimizer.correlationApache Hive
ReduceSinkDeDuplicationIf two reducer sink operators share the same partition/sort columns and order, they can be merged.Classorg.apache.hadoop.hive.ql.optimizer.correlationApache Hive
ReduceSinkDeDuplication .AbsctractReducerReducerProcClassorg.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplicationApache Hive
ReduceSinkMapJoinProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
RelOptHiveTableClassorg.apache.hadoop.hive.ql.optimizer.calciteApache Hive
RemoveDynamicPruningBySizeClassorg.apache.hadoop.hive.ql.optimizerApache Hive
RewriteCanApplyCtxRewriteCanApplyCtx class stores the context for the RewriteCanApplyProcFactory to determine if any index can be used and if the input queryClassorg.apache.hadoop.hive.ql.optimizer.indexApache Hive
RewriteCanApplyProcFactoryFactory of methods used by RewriteGBUsingIndex to determine if the rewrite optimization can be applied to the input query.Classorg.apache.hadoop.hive.ql.optimizer.indexApache Hive
RewriteGBUsingIndexRewriteGBUsingIndex is implemented as one of the Rule-based Optimizations.Classorg.apache.hadoop.hive.ql.optimizer.indexApache Hive
RewriteParseContextGeneratorRewriteParseContextGenerator is a class that offers methods to generate operator tree for input queries.Classorg.apache.hadoop.hive.ql.optimizer.indexApache Hive
RewriteQueryUsingAggregateIndexCtxRewriteQueryUsingAggregateIndexCtx class stores the context for the RewriteQueryUsingAggregateIndexClassorg.apache.hadoop.hive.ql.optimizer.indexApache Hive
RexNodeConverterClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
SamplePrunerThe transformation step that does sample pruning.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
SamplePruner .AddPathReturnStatusClassorg.apache.hadoop.hive.ql.optimizer.SamplePrunerApache Hive
SamplePruner .DefaultPPRDefaultPPR default processor which does nothing.Classorg.apache.hadoop.hive.ql.optimizer.SamplePrunerApache Hive
SamplePruner .FilterPPRFilterPPR filter processor.Classorg.apache.hadoop.hive.ql.optimizer.SamplePrunerApache Hive
SamplePruner .LimitPruneRetStatusClassorg.apache.hadoop.hive.ql.optimizer.SamplePrunerApache Hive
SamplePruner .SamplePrunerCtxClassorg.apache.hadoop.hive.ql.optimizer.SamplePrunerApache Hive
SamplingOptimizerClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SetReducerParallelismSetReducerParallelism determines how many reducers should be run for a given reduce sink.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
SetSparkReducerParallelismSetSparkReducerParallelism determines how many reducers should be run for a given reduce sink, clone from SetReducerParallelism.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SimpleFetchAggregationClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SimpleFetchOptimizerTries to convert simple fetch query to single fetch task, which fetches rows directly from location of table/partition.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
SizeBasedBigTableSelectorForAutoSMJClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SkewJoinOptimizerClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SkewJoinOptimizer .SkewJoinOptProcCtxClassorg.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizerApache Hive
SkewJoinOptimizer .SkewJoinProcClassorg.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizerApache Hive
SkewJoinProcFactoryNode processor factory for skew join resolver.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SkewJoinProcFactory .SkewJoinDefaultProcessorSkewJoinDefaultProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactoryApache Hive
SkewJoinProcFactory .SkewJoinJoinProcessorSkewJoinJoinProcessor.Classorg.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactoryApache Hive
SkewJoinResolverAn implementation of PhysicalPlanResolver.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SkewJoinResolver .SkewJoinProcCtxA container of current task and parse context.Classorg.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolverApache Hive
SortBucketJoinProcCtxClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SortedDynPartitionOptimizerWhen dynamic partitioning (with or without bucketing and sorting) is enabled, this optimization sorts the records on partition, bucket and sort columns respectively before inserting recordsClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SortedMergeBucketMapJoinOptimizerClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SortedMergeBucketMapjoinProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SortedMergeJoinProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SortMergeJoinResolverClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SortMergeJoinTaskDispatcherIterator over each task.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SparkCrossProductCheckCheck each MapJoin and ShuffleJoin Operator to see if they are performing a cross product.Classorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SparkJoinHintOptimizerThis processes joins in which user specified a hint to identify the small-table.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkJoinOptimizerConverts a join to a more optimized join for the Spark path.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkMapJoinOptimizerSparkMapJoinOptimizer cloned from ConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicateClassorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkMapJoinProcessorClassorg.apache.hadoop.hive.ql.optimizerApache Hive
SparkMapJoinResolverClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
SparkReduceSinkMapJoinProcClassorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkReduceSinkMapJoinProc .SparkMapJoinFollowedByGroupByProcessorClassorg.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProcApache Hive
SparkSkewJoinProcFactorySpark-version of SkewJoinProcFactory.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkSkewJoinProcFactory .SparkSkewJoinJoinProcessorClassorg.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinProcFactoryApache Hive
SparkSkewJoinResolverSpark version of SkewJoinResolver.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkSkewJoinResolver .SparkSkewJoinProcCtxClassorg.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinResolverApache Hive
SparkSMBJoinHintOptimizerConverts from a bucket-mapjoin created from hints to SMB mapjoin.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkSortMergeJoinFactoryOperator factory for Spark SMBJoin processing.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SparkSortMergeJoinOptimizerConverts a common join operator to an SMB join if eligible.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SplitSparkWorkResolverDo a BFS on the sparkWork graph, and look for any work that has more than one child.Classorg.apache.hadoop.hive.ql.optimizer.sparkApache Hive
SqlFunctionConverterClassorg.apache.hadoop.hive.ql.optimizer.calcite.translatorApache Hive
SqlFunctionConverter .CalciteUDAFClassorg.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverterApache Hive
StageIDsRearrangerClassorg.apache.hadoop.hive.ql.optimizer.physicalApache Hive
StageIDsRearranger .TaskTraverseClassorg.apache.hadoop.hive.ql.optimizer.physical.StageIDsRearrangerApache Hive
StatsOptimizerThere is a set of queries which can be answered entirely from statistics stored in metastore.Classorg.apache.hadoop.hive.ql.optimizerApache Hive
StatsRulesProcFactoryClassorg.apache.hadoop.hive.ql.optimizer.stats.annotationApache Hive
StatsRulesProcFactory .DefaultStatsRuleDefault rule is to aggregate the statistics from all its parent operators.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .FilterStatsRuleFILTER operator does not change the average row size but it does change the number of rows emitted.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .GroupByStatsRuleGROUPBY operator changes the number of rows.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .JoinStatsRuleJOIN operator can yield any of the following three cases The values of join keys are disjoint in both relations in which case T(RXS) = 0 (we need histograms for this)JoinClassorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .LimitStatsRuleLIMIT operator changes the number of rows and thereby the data size.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .ReduceSinkStatsRuleReduceSink operator does not change any of the statistics.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .SelectStatsRuleSELECT operator doesn't change the number of rows emitted from the parent operator.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
StatsRulesProcFactory .TableScanStatsRuleCollect basic statistics like number of rows, data size and column level statistics from the table.Classorg.apache.hadoop.hive.ql.optimizer.stats.annotation.StatsRulesProcFactoryApache Hive
TableSizeBasedBigTableSelectorForAutoSMJClassorg.apache.hadoop.hive.ql.optimizerApache Hive
TezBucketJoinProcCtxClassorg.apache.hadoop.hive.ql.optimizerApache Hive