Package

org.apache.spark.sql.execution

common

Permalink

package common

Visibility
  1. Public
  2. All

Type Members

  1. case class AQPAverage(weight: MapColumnToWeight, actualColumn: Expression) extends DeclarativeAggregate with Product with Serializable

    Permalink
  2. case class AQPCount(weight: MapColumnToWeight, columns: Seq[Expression]) extends DeclarativeAggregate with Product with Serializable

    Permalink
  3. case class AQPFunctionParameter(columns: Seq[Expression], weight: MapColumnToWeight, actualAggregateDataType: DataType) extends Expression with Product with Serializable

    Permalink

    Created by ashahid on 5/10/16.

  4. case class AQPInfo(error: Double, confidence: Double, sampleRatioAttribute: Masquerader, analysisType: Option[Type], isAQPDebug: Boolean, isDebugFixedSeed: Boolean, poissonType: PoissonType, bootstrapMultiplicities: Option[Attribute], bsMultiplictyAliasID: ExprId, numBSTrials: Int, behavior: Type, numBaseAggs: Int) extends Product with Serializable

    Permalink
  5. trait AQPInfoStoreTestHook extends AnyRef

    Permalink
  6. case class AQPSum(weight: MapColumnToWeight, child: Expression) extends DeclarativeAggregate with GroupAggregate with Product with Serializable

    Permalink
  7. case class AbsoluteError(child: Expression) extends UnaryExpression with ErrorEstimateFunction with Product with Serializable

    Permalink

    Expression that returns the dsid of the server containing the row.

    Expression that returns the dsid of the server containing the row.

    Annotations
    @ExpressionDescription()
  8. case class Behavior(behaviorExpr: Expression, child: LogicalPlan, forcedRoute: Boolean = false) extends UnaryNode with Product with Serializable

    Permalink
  9. case class ByPassErrorCalculationsConditionally(analyzerInvoc: AnalyzerInvocation, isAQPDebug: Boolean) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
  10. case class CoalesceDisparateTypes(children: Seq[Expression]) extends Expression with Unevaluable with Product with Serializable

    Permalink
  11. case class Confidence(confidenceExpr: Expression, child: LogicalPlan) extends UnaryNode with Product with Serializable

    Permalink
  12. trait ConstantErrorEstimate extends UnaryExpression

    Permalink
  13. case class DummyLeafNode() extends LeafNode with Product with Serializable

    Permalink
  14. case class EnsureSampleWeightageColumn(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
  15. case class Error(errorExpr: Expression, child: LogicalPlan) extends UnaryNode with Product with Serializable

    Permalink
  16. abstract class ErrorAggregateFunction extends DeclarativeAggregate

    Permalink
  17. case class ErrorAggregateNumericConverter(child: Expression, masqueradingType: DataType) extends UnaryExpression with Product with Serializable

    Permalink
  18. case class ErrorAndConfidence(error: Double, confidence: Double, child: LogicalPlan, sampleRatioAttribute: MapColumnToWeight, bootstrapMultiplicities: Option[Attribute], isAQPDebug: Boolean, isFixedSeed: Boolean, analysisType: Option[Type], bsMultiplictyAliasID: ExprId, numBootstrapTrials: Int, behavior: Type, sampleTable: String, ruleNumProcessing: Int = 1) extends UnaryNode with Product with Serializable

    Permalink
  19. case class ErrorDefaults(child: LogicalPlan) extends UnaryNode with Product with Serializable

    Permalink
  20. trait ErrorEstimateFunction extends UnaryExpression

    Permalink

    Created by ashahid on 3/17/16.

  21. case class ErrorEstimateRule(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
    Annotations
    @transient()
  22. case class GetErrorBounds(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
    Annotations
    @transient()
  23. case class LowerBound(child: Expression) extends UnaryExpression with ErrorEstimateFunction with Product with Serializable

    Permalink
    Annotations
    @ExpressionDescription()
  24. final case class MapColumnToWeight(child: Expression) extends UnaryExpression with Product with Serializable

    Permalink
  25. case class MoveUpBootstrapReferencerConditionally(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
    Annotations
    @transient()
  26. case class PlaceHolderPlan(hiddenChild: LogicalPlan, makeVisible: Boolean, isDistributed: Boolean, allowOpeningOfPlaceHolderPlan: Boolean = true) extends SnappyUnaryNode with Product with Serializable

    Permalink
  27. final class PositionCounter extends AnyRef

    Permalink
  28. case class PostReplaceSampleTableQueryRoutingRules(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
    Annotations
    @transient()
  29. case class QueryRoutingRules(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
    Annotations
    @transient()
  30. case class RelativeError(child: Expression) extends UnaryExpression with ErrorEstimateFunction with Product with Serializable

    Permalink
    Annotations
    @ExpressionDescription()
  31. case class ReplaceWithSampleTable(catalog: SnappyAQPSessionCatalog, analyzerInvocation: AnalyzerInvocation, numBootStrapTrials: Int, isAQPDebug: Boolean, isFixedSeed: Boolean, isDefaultClosedForm: Boolean, conf: SQLConf) extends Rule[LogicalPlan] with Product with Serializable

    Permalink
  32. final class SnappyHashAggregate extends SnappyHashAggregateExec

    Permalink
  33. final class SnappyPartialHashAggregate extends SnappyHashAggregateExec

    Permalink
  34. final class SnappyPartialSortedAggregate extends SortAggregateExec

    Permalink
  35. final class SnappySortAggregate extends SortAggregateExec

    Permalink
  36. case class TokenizedLiteralWrapper(child: TokenizedLiteral) extends UnaryExpression with Unevaluable with Product with Serializable

    Permalink
  37. case class UpperBound(child: Expression) extends UnaryExpression with ErrorEstimateFunction with Product with Serializable

    Permalink
    Annotations
    @ExpressionDescription()
  38. case class WeightageRule(analyzerInvoc: AnalyzerInvocation) extends Rule[LogicalPlan] with Product with Serializable

    Permalink

Value Members

  1. object AQPRules

    Permalink
  2. object AnalysisType extends Enumeration

    Permalink
  3. object CatchErrorPlan

    Permalink
  4. object CleanupErrorEstimateAttribute extends Rule[SparkPlan]

    Permalink
  5. object ConstantAbsoluteError extends UnaryExpression with ConstantErrorEstimate

    Permalink
  6. object ConstantLowerBound extends UnaryExpression with ConstantErrorEstimate

    Permalink
  7. object ConstantRelativeError extends UnaryExpression with ConstantErrorEstimate

    Permalink
  8. object ConstantUpperBound extends UnaryExpression with ConstantErrorEstimate

    Permalink
  9. object GetErrorBounds extends Serializable

    Permalink
  10. object HAC extends Enumeration

    Permalink
  11. object HideSubqueryNodes extends Rule[SparkPlan]

    Permalink
  12. object ImplementSnappyAggregate extends Rule[SparkPlan]

    Permalink
  13. object MakeSubqueryNodesInvisible extends Rule[LogicalPlan]

    Permalink
  14. object MakeSubqueryNodesVisible extends Rule[LogicalPlan]

    Permalink
  15. object MapColumnToWeight extends Serializable

    Permalink
  16. object MoveUpBootstrapReferencerConditionally extends Serializable

    Permalink
  17. object PlaceHolderPlan extends Serializable

    Permalink
  18. object QueryRoutingRules extends Logging with Serializable

    Permalink
  19. object ReplaceWithSampleTable extends Serializable

    Permalink
  20. object ResultsExpressionCreator

    Permalink
  21. object RuleNumbers

    Permalink
  22. object UnHideSubqueryNodes extends Rule[SparkPlan]

    Permalink
  23. object UnevaluableErrorEstimate extends UnaryExpression with Unevaluable

    Permalink

Ungrouped