Package

org.apache.spark

sql

Permalink

package sql

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. sql
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. case class CheckValue[T](check: String, value: T)(implicit x: Numeric[T]) extends Product with Serializable

    Permalink
  2. case class ColumnCheck(checkFunction: (Check, String) ⇒ Check) extends Product with Serializable

    Permalink
  3. case class ColumnCombinationCheck(checkFunction: (Check, Seq[String]) ⇒ Check) extends Product with Serializable

    Permalink
  4. case class ColumnComparisonCheck(checkFunction: (Check, (String, String)) ⇒ Check) extends Product with Serializable

    Permalink
  5. case class Columns(names: List[String]) extends Product with Serializable

    Permalink
  6. case class DataCheck(checkFunction: (Check) ⇒ Check) extends Product with Serializable

    Permalink
  7. type DataFrame = Dataset[Row]

    Permalink
  8. case class DoubleFieldStatAccumulator(nulls: LongAccumulator, nonNulls: LongAccumulator, sum: DoubleAccumulator, mins: CollectionAccumulator[Double], maxs: CollectionAccumulator[Double], m2: DoubleAccumulator) extends FieldStatAccumulator with Product with Serializable

    Permalink
  9. sealed trait FieldStatAccumulator extends Serializable

    Permalink
  10. case class Interim(outputFunction: InterimOutput, subgraph: String, component: String, port: String, subPath: String, numRows: Int, child: LogicalPlan, detailedStats: Boolean = false) extends UnaryNode with IgnoreCachedData with Product with Serializable

    Permalink
  11. case class InterimExec(outputFunction: InterimOutput, subgraph: String, component: String, port: String, subPath: String, child: SparkPlan, numRows: Int, detailedStats: Boolean, sparkSession: SparkSession) extends SparkPlan with InterimExec2 with Product with Serializable

    Permalink
  12. trait InterimExec2 extends SparkPlan with InterimExecBase

    Permalink
  13. trait InterimExecBase extends SparkPlan

    Permalink
  14. trait InterimOutput extends Serializable

    Permalink
  15. case class InterimOutputHive2(session: String, workflowID: String, workflowVersion: String, jobid: String) extends Serializable with InterimOutput with Product

    Permalink
  16. case class InterimStat(dataFrameSchema: StructType, basicStats: Boolean, statsAccs: Array[FieldStatAccumulator], rowAccumulator: CollectionAccumulator[InterimRow], counterAccumulator: LongAccumulator, partitionCounter: LongAccumulator, rowAccSchema: StructType, schema: StructType, numPartitions: Int, numRows: Int, schemaJson: Seq[InternalRow], schemaSchema: StructType) extends Serializable with Product

    Permalink
  17. case class InterimStore(sparkSession: SparkSession, interims: LinkedHashMap[RDDInterimKey, InterimStat] = ...) extends LazyLogging with Product with Serializable

    Permalink
  18. case class InterimStrategy(spark: SparkSession) extends SparkStrategy with Product with Serializable

    Permalink

    Spark strategy converts logical plan to sequence of spark plan.

    Spark strategy converts logical plan to sequence of spark plan. This class represents custom interim strategy. Logical operators other than Interim are converted using the regular SparkStrategy which is applied because of planLater method

    * GenericStrategy.planLater scala doc: Returns a placeholder for a physical plan that executes plan. This placeholder will be filled in automatically by the QueryPlanner using the other execution strategies that are available.

  19. case class LongFieldStatAccumulator(nulls: LongAccumulator, nonNulls: LongAccumulator, sum: LongAccumulator, mins: CollectionAccumulator[Long], maxs: CollectionAccumulator[Long], m2: LongAccumulator) extends FieldStatAccumulator with Product with Serializable

    Permalink
  20. case class OtherFieldStatAccumulator(nulls: LongAccumulator, nonNulls: LongAccumulator) extends FieldStatAccumulator with Product with Serializable

    Permalink
  21. class ProphecyDataFrame extends AnyRef

    Permalink
  22. case class ProphecySparkSession(spark: SparkSession) extends Product with Serializable

    Permalink
  23. type Strategy = SparkStrategy

    Permalink
    Annotations
    @DeveloperApi() @Unstable()
  24. case class StreamQueryListener(query: io.prophecy.libs.StreamingTarget, maxEmptyTicks: Int = 3) extends StreamingQueryListener with Product with Serializable

    Permalink
  25. case class StringFieldStatAccumulator(nulls: LongAccumulator, nonNulls: LongAccumulator, mins: CollectionAccumulator[String], maxs: CollectionAccumulator[String]) extends FieldStatAccumulator with Product with Serializable

    Permalink

Value Members

  1. object CheckValue extends Serializable

    Permalink
  2. object ColumnCheck extends Serializable

    Permalink
  3. object ColumnCombinationCheck extends Serializable

    Permalink
  4. object ColumnComparisonCheck extends Serializable

    Permalink
  5. object Columns extends Serializable

    Permalink
  6. object DataCheck extends Serializable

    Permalink
  7. object DataFrameDQExtensions

    Permalink
  8. object FieldStatAccumulator extends Serializable

    Permalink
  9. object InterimExecBase extends Serializable

    Permalink
  10. object InterimOutputHive

    Permalink
  11. object InterimOutputHive2 extends Serializable

    Permalink
  12. object InterimStore extends Serializable

    Permalink
  13. object MetricsCollector extends Serializable with LazyLogging

    Permalink
  14. object ProphecyDataFrame

    Permalink
  15. object ProphecyDebugger

    Permalink
  16. object ProphecyExtensions

    Permalink
  17. object ProphecySparkSession extends Serializable

    Permalink
  18. object ProphecyTimer extends Serializable

    Permalink
  19. package catalyst

    Permalink
  20. package crosssupport

    Permalink
  21. package databricks

    Permalink
  22. package event

    Permalink
  23. package execution

    Permalink
  24. package executionmetrics

    Permalink

    data schema is in snake case spark doesn't gives us a native converter from snake case to camel case, we have to do that in this class.

  25. package prophecy

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped