Package

org.apache.spark.sql.catalyst.plans.logical

statsEstimation

Permalink

package statsEstimation

Visibility
  1. Public
  2. All

Type Members

  1. case class ColumnStatsMap(originalMap: AttributeMap[ColumnStat]) extends Product with Serializable

    Permalink

    This class contains the original column stats from child, and maintains the updated column stats.

    This class contains the original column stats from child, and maintains the updated column stats. We will update the corresponding ColumnStats for a column after we apply a predicate condition. For example, column c has [min, max] value as [0, 100]. In a range condition such as (c > 40 AND c <= 50), we need to set the column's [min, max] value to [40, 100] after we evaluate the first condition c > 40. We also need to set the column's [min, max] value to [40, 50] after we evaluate the second condition c <= 50.

    originalMap

    Original column stats from child.

  2. class DefaultRange extends Range

    Permalink

    This version of Spark does not have min/max for binary/string types, we define their default behaviors by this class.

  3. case class FilterEstimation(plan: Filter, catalystConf: SQLConf) extends Logging with Product with Serializable

    Permalink
  4. case class InnerOuterEstimation(conf: SQLConf, join: Join) extends Logging with Product with Serializable

    Permalink
  5. case class LeftSemiAntiEstimation(conf: SQLConf, join: Join) extends Product with Serializable

    Permalink
  6. class NullRange extends Range

    Permalink

    This is for columns with only null values.

  7. case class NumericRange(min: Decimal, max: Decimal) extends Range with Product with Serializable

    Permalink

    For simplicity we use decimal to unify operations of numeric ranges.

  8. trait Range extends AnyRef

    Permalink

    Value range of a column.

Value Members

  1. object AggregateEstimation

    Permalink
  2. object EstimationUtils

    Permalink
  3. object JoinEstimation extends Logging

    Permalink
  4. object ProjectEstimation

    Permalink
  5. object Range

    Permalink

Ungrouped