Package

org.apache.spark.sql.execution

bootstrap

Permalink

package bootstrap

Visibility
  1. Public
  2. All

Type Members

  1. case class ApproxColumn(column: Expression, multiplicityResultExpr: Expression, confidence: Double, baseAggregateType: Type, error: Double, behavior: Type) extends Expression with Product with Serializable

    Permalink
  2. case class ApproxColumnDebug(column: Expression, numBootstrapTrials: Int) extends Expression with Product with Serializable

    Permalink
  3. case class ApproxColumnExtractor(child: Expression, name: String, ordinal: Int, dataType: DataType, nullable: Boolean)(exprId: ExprId = NamedExpression.newExprId, qualifier: Option[String] = None) extends UnaryExpression with NamedExpression with Product with Serializable

    Permalink
  4. case class ArrayOpsExpression(array1: Expression, array2: Expression, opType: Int, behaviour: Int, numBootstrapTrials: Int, dataType: DataType) extends Expression with Product with Serializable

    Permalink
  5. case class BootstrapAddTrialsAsArray(actualColumn: Expression, buffer: Expression, numTrials: Int, opType: Int, isAQPDebug: Boolean, dataType: DataType) extends Expression with Product with Serializable

    Permalink
  6. case class BootstrapAddTrialsAvgCountPart(actualColumn: Expression, buffer: Expression, numTrials: Int, sumBuffer: Expression, dataType: DataType) extends Expression with Product with Serializable

    Permalink
  7. case class BootstrapAddTrialsAvgSumPart(buffer: Expression, dataType: DataType) extends Expression with Product with Serializable

    Permalink
  8. case class BootstrapAverage(columnExpression: Expression, _numBootstrapTrials: Int, _confidence: Double, _error: Double, _errorEstimateProjs: Seq[(Int, Type, String, String, ExprId, NamedExpression)], _isAQPDebug: Boolean, _behavior: Type) extends DeclarativeBootstrapAggregateFunction with GroupAggregate with Product with Serializable

    Permalink

    Created by ashahid on 5/4/16.

  9. case class BootstrapCount(columns: Seq[Expression], _numBootstrapTrials: Int, _confidence: Double, _error: Double, _errorEstimateProjs: Seq[(Int, Type, String, String, ExprId, NamedExpression)], _isAQPDebug: Boolean, _behavior: Type) extends DeclarativeBootstrapAggregateFunction with Product with Serializable

    Permalink
  10. case class BootstrapMultiplicityAggregate(weight: Expression, bootstrapMultiplicities: Expression, numBootstrapTrials: Int) extends DeclarativeAggregate with GroupAggregate with Product with Serializable

    Permalink
  11. case class BootstrapReferencer(child: LogicalPlan, bsAliasID: ExprId, bootstrapMultiplicities: Expression) extends UnaryNode with Product with Serializable

    Permalink
  12. case class BootstrapResultEvalAndCache(child: Expression) extends UnaryExpression with Product with Serializable

    Permalink
  13. case class BootstrapSum(actualColumn: Expression, _numBootstrapTrials: Int, _confidence: Double, _error: Double, _errorEstimateProjs: Seq[(Int, Type, String, String, ExprId, NamedExpression)], _isAQPDebug: Boolean, _behavior: Type) extends DeclarativeBootstrapAggregateFunction with GroupAggregate with Product with Serializable

    Permalink

    Created by ashahid on 6/2/16.

  14. final class ByteMutableRow extends InternalRow with BaseGenericInternalRow with Externalizable with KryoSerializable

    Permalink
  15. case class ByteStructCreator(numGroups: Int) extends LeafExpression with Product with Serializable

    Permalink
  16. case class CachedFieldWrapper(cachedFieldName: String, className: String, isNullable: Boolean) extends LeafExpression with Product with Serializable

    Permalink
  17. case class DebugFixedSeed(initSeed: Int = 1) extends LeafExpression with Product with Serializable

    Permalink
  18. case class DebugIndpndntPredictable(poissonValueGenerator: Expression, numBootstrapTrials: Int) extends UnaryExpression with SuperPoisson with Product with Serializable

    Permalink
  19. abstract class DeclarativeBootstrapAggregateFunction extends ErrorAggregateFunction

    Permalink
  20. class DoubleMutableRow extends InternalRow with BaseGenericInternalRow with Externalizable with KryoSerializable

    Permalink
  21. class DoubleMutableRowDebug extends DoubleMutableRow

    Permalink
  22. case class DoubleStructCreator(numTrials: Int, isAQPDebug: Boolean) extends LeafExpression with Product with Serializable

    Permalink
  23. case class MergeMultiplicityExpression(leftArray: Expression, rightArray: Expression, numGroups: Int, numBootstrapTrials: Int, dataType: DataType) extends Expression with Product with Serializable

    Permalink
  24. case class Poisson(poissonValueGenerator: Expression, numBootstrapTrials: Int) extends UnaryExpression with SuperPoisson with Product with Serializable

    Permalink
  25. class PoissonGenerator extends RandomDataGenerator[Int]

    Permalink
  26. case class ResamplePlaceholder(child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Permalink
  27. case class SnappyPoissonSeed(usedFixedSeed: Boolean = false) extends LeafExpression with Product with Serializable

    Permalink
  28. trait SuperPoisson extends UnaryExpression

    Permalink
  29. trait Tag extends AnyRef

    Permalink
  30. case class TaggedAlias(tag: TransformableTag, child: Expression, name: String)(exprId: ExprId = NamedExpression.newExprId, qualifier: Option[String] = None) extends Expression with NamedExpression with Product with Serializable

    Permalink
  31. case class TaggedAttribute(tag: Tag, name: String, dataType: DataType, nullable: Boolean = true, metadata: Metadata = Metadata.empty)(exprId: ExprId = NamedExpression.newExprId, qualifier: Option[String] = None) extends Attribute with Unevaluable with Product with Serializable

    Permalink
  32. trait TransformableTag extends Tag

    Permalink
  33. case class UpdateMultiplicityExpression(children: Seq[Expression], numBootstrapTrials: Int, dataType: DataType) extends Expression with Product with Serializable

    Permalink

Value Members

  1. object ApproxColumn extends Serializable

    Permalink
  2. object ArrayOpsExpression extends Serializable

    Permalink
  3. object BootStrapUtils

    Permalink
  4. object Bootstrap extends TransformableTag

    Permalink
  5. object BootstrapAddTrialsAsArray extends Serializable

    Permalink
  6. object BootstrapCount extends Serializable

    Permalink
  7. object BootstrapFunctions

    Permalink

    The functions used in this class are used by the the generated classes.

    The functions used in this class are used by the the generated classes. The function names should match exactly with the string fields. Take care while changing function names. Created by ashahid on 6/24/16.

  8. object BootstrapMultiplicity

    Permalink
  9. object BootstrapMultiplicityAggregate extends Serializable

    Permalink
  10. object BootstrapStructType

    Permalink
  11. object CleanupBootstrapAnalysisExpressions extends Rule[SparkPlan]

    Permalink
  12. object ClusterUtils

    Permalink
  13. object CurrentThreadExecutor extends AbstractExecutorService with ExecutionContextExecutorService

    Permalink
  14. object DoubleMutableRow extends Serializable

    Permalink
  15. object Poisson extends Serializable

    Permalink
  16. object PoissonCreator

    Permalink
  17. object PropagateBootstrapColumns extends Rule[SparkPlan]

    Permalink
  18. object PruneProjects extends Rule[SparkPlan]

    Permalink
  19. object PushUpSeed extends Rule[SparkPlan]

    Permalink

    Postpone materializing seed.

  20. object Seed extends TransformableTag

    Permalink

Ungrouped