Uses of Interface
org.apache.hadoop.hive.ql.optimizer.Transform

Packages that use Transform
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.correlation   
org.apache.hadoop.hive.ql.optimizer.index   
org.apache.hadoop.hive.ql.optimizer.lineage   
org.apache.hadoop.hive.ql.optimizer.listbucketingpruner   
org.apache.hadoop.hive.ql.optimizer.metainfo.annotation   
org.apache.hadoop.hive.ql.optimizer.pcr   
org.apache.hadoop.hive.ql.optimizer.ppr   
org.apache.hadoop.hive.ql.optimizer.stats.annotation   
org.apache.hadoop.hive.ql.optimizer.unionproc   
org.apache.hadoop.hive.ql.ppd   
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer
 

Classes in org.apache.hadoop.hive.ql.optimizer that implement Transform
 class BucketingSortingReduceSinkOptimizer
          This transformation does optimization for enforcing bucketing and sorting.
 class BucketMapJoinOptimizer
          this transformation does bucket map join optimization.
 class ColumnPruner
          Implementation of one of the rule-based optimization steps.
 class GlobalLimitOptimizer
          This optimizer is used to reduce the input size for the query for queries which are specifying a limit.
 class GroupByOptimizer
          This transformation does group by optimization.
 class JoinReorder
          Implementation of rule-based join table reordering optimization.
 class LimitPushdownOptimizer
          Make RS calculate top-K selection for limit clause.
 class MapJoinProcessor
          Implementation of one of the rule-based map join optimization.
 class NonBlockingOpDeDupProc
          merges SEL-SEL or FIL-FIL into single operator
 class SamplePruner
          The transformation step that does sample pruning.
 class SimpleFetchAggregation
           
 class SimpleFetchOptimizer
          Tries to convert simple fetch query to single fetch task, which fetches rows directly from location of table/partition.
 class SkewJoinOptimizer
          SkewJoinOptimizer.
 class SortedDynPartitionOptimizer
          When dynamic partitioning (with or without bucketing and sorting) is enabled, this optimization sorts the records on partition, bucket and sort columns respectively before inserting records into the destination table.
 class SortedMergeBucketMapJoinOptimizer
           
 class StatsOptimizer
          There is a set of queries which can be answered entirely from statistics stored in metastore.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.correlation
 

Classes in org.apache.hadoop.hive.ql.optimizer.correlation that implement Transform
 class CorrelationOptimizer
          Implementation of Correlation Optimizer.
 class ReduceSinkDeDuplication
          If two reducer sink operators share the same partition/sort columns and order, they can be merged.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.index
 

Classes in org.apache.hadoop.hive.ql.optimizer.index that implement Transform
 class RewriteGBUsingIndex
          RewriteGBUsingIndex is implemented as one of the Rule-based Optimizations.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.lineage
 

Classes in org.apache.hadoop.hive.ql.optimizer.lineage that implement Transform
 class Generator
          This class generates the lineage information for the columns and tables from the plan before it goes through other optimization phases.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner
 

Classes in org.apache.hadoop.hive.ql.optimizer.listbucketingpruner that implement Transform
 class ListBucketingPruner
          The transformation step that does list bucketing pruning.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation
 

Classes in org.apache.hadoop.hive.ql.optimizer.metainfo.annotation that implement Transform
 class AnnotateWithOpTraits
           
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.pcr
 

Classes in org.apache.hadoop.hive.ql.optimizer.pcr that implement Transform
 class PartitionConditionRemover
          The transformation step that does partition condition remover.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.ppr
 

Classes in org.apache.hadoop.hive.ql.optimizer.ppr that implement Transform
 class PartitionPruner
          The transformation step that does partition pruning.
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.stats.annotation
 

Classes in org.apache.hadoop.hive.ql.optimizer.stats.annotation that implement Transform
 class AnnotateWithStatistics
           
 

Uses of Transform in org.apache.hadoop.hive.ql.optimizer.unionproc
 

Classes in org.apache.hadoop.hive.ql.optimizer.unionproc that implement Transform
 class UnionProcessor
          Implementation of the union processor.
 

Uses of Transform in org.apache.hadoop.hive.ql.ppd
 

Classes in org.apache.hadoop.hive.ql.ppd that implement Transform
 class PredicatePushDown
          Implements predicate pushdown.
 class PredicateTransitivePropagate
          propagates filters to other aliases based on join condition
 



Copyright © 2014 The Apache Software Foundation. All rights reserved.