Package

org.apache.spark.sql.execution

closedform

Permalink

package closedform

Visibility
  1. Public
  2. All

Type Members

  1. case class ClosedFormColumnExtractor(child: Expression, name: String, confidence: Double, confFactor: Double, aggType: Type, error: Double, dataType: DataType, behavior: Type, nullable: Boolean)(exprId: ExprId = NamedExpression.newExprId, qualifier: Option[String] = None) extends UnaryExpression with NamedExpression with Product with Serializable

    Permalink
  2. case class ClosedFormErrorEstimate(child: Expression, rawWeight: Expression, _confidence: Double, _aggregateType: Type, _error: Double, _errorEstimateProjs: Seq[(Int, Type, String, String, ExprId, NamedExpression)], _behavior: Type) extends ErrorAggregateFunction with GroupAggregate with Product with Serializable

    Permalink
  3. trait ClosedFormStats extends StatVarianceCounter

    Permalink
  4. case class ErrorEstimateAttribute(name: String, dataType: DataType, nullable: Boolean = true, metadata: Metadata = Metadata.empty, exprId: ExprId, realExprId: ExprId)(qualifier: Option[String] = None) extends Attribute with Unevaluable with Product with Serializable

    Permalink
  5. class ErrorLimitExceededException extends RuntimeException

    Permalink

    The exception thrown when error percent is more than specified.

  6. final class MultiTableStatCounterWithFullCount extends StatCounterWithFullCount

    Permalink
  7. class StatCounterAggregator extends InternalRow with BaseGenericInternalRow with ClosedFormStats

    Permalink
  8. case class StatCounterAggregatorCreator(aggType: Type) extends LeafExpression with Product with Serializable

    Permalink
  9. case class StatCounterMergerer(left: Expression, right: Expression, aggregateType: Type) extends BinaryOperator with Product with Serializable

    Permalink
  10. case class StatCounterUpdater(buffer: Expression, col: Expression, rawWeight: Expression, colDataType: DataType, isCount: Boolean) extends TernaryExpression with Product with Serializable

    Permalink
  11. class StatCounterWithFullCount extends InternalRow with BaseGenericInternalRow with ClosedFormStats

    Permalink

    A class for tracking the statistics of a set of numbers (count, mean, variance and weightedCount) in a numerically robust way.

    A class for tracking the statistics of a set of numbers (count, mean, variance and weightedCount) in a numerically robust way. Includes support for merging two counters.

    Taken from Spark's StatCounter implementation removing max and min.

Value Members

  1. object ErrorAggregate extends Enumeration

    Permalink
  2. object StatCounterWithFullCount extends Logging with Serializable

    Permalink

Ungrouped