Package

org.apache.spark.sql

prophecy

Permalink

package prophecy

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

Type Members

  1. trait ActorPathLogging extends AnyRef

    Permalink
  2. case class FieldDetailedStat(field: String, ndv: Long, quantiles: Option[Seq[Quantile]] = None, topN: Option[Seq[FieldValueAndCount]] = None) extends Product with Serializable

    Permalink
  3. case class FieldStat[T](field: String, nulls: Option[Long] = None, nonNulls: Option[Long] = None, min: Option[T] = None, max: Option[T] = None, mean: Option[Double] = None, stddev: Option[Double] = None) extends Product with Serializable

    Permalink
  4. case class FieldValueAndCount(value: Option[String], count: Long) extends Product with Serializable

    Permalink
  5. case class InterimKey(subgraph: String, component: String, port: String) extends Serializable with Product

    Permalink
  6. case class JobMetricsMetadata(uuid: Option[String], jobURI: Option[String], fabricId: Option[String], timeStarted: Long, isInteractive: Option[Boolean], taskRunId: String, pipelineUri: Option[String], userId: Option[String], branch: Option[String] = None, prophecyUrl: Option[String] = None) extends SparkListenerEvent with Product with Serializable

    Permalink
  7. case class JobPipelineEndEvent(status: PipelineStatus) extends SparkListenerEvent with Product with Serializable

    Permalink
  8. class NoopEventActor extends Actor with ActorPathLogging

    Permalink
  9. case class ProphecyDetailedStatEvent(key: InterimKey, jobId: String, detailedStats: Seq[FieldDetailedStat]) extends SparkListenerEvent with Product with Serializable

    Permalink
  10. class ProphecyEventActor extends Actor with ActorPathLogging

    Permalink
  11. class ProphecyEventSendingListener extends SparkListener

    Permalink
  12. case class ProphecyInterimEvent(key: InterimKey, jobId: String, totalRecords: Long, sampleJsonRows: List[String], schemaJson: String, numPartitions: Option[Int] = None, stats: Option[Seq[FieldStat[_]]], rowsPerPartition: Option[Seq[PartitionRowCount]] = None) extends SparkListenerEvent with Product with Serializable

    Permalink
  13. case class Quantile(quantile: Int, value: Double) extends Product with Serializable

    Permalink
  14. case class RDDInterimKey(subgraph: String, component: String, port: String, rddId: Int) extends Serializable with Product

    Permalink

Value Members

  1. object FieldDetailedStat extends Serializable

    Permalink
  2. object FieldValueAndCount extends Serializable

    Permalink
  3. object InterimKey extends Serializable

    Permalink
  4. object Main2 extends App

    Permalink
  5. object NoopEventActor

    Permalink
  6. object ProphecyDetailedStatEvent extends Serializable

    Permalink
  7. object ProphecyEventActor extends LazyLogging

    Permalink
  8. object ProphecyEventSendingListener

    Permalink
  9. object Quantile extends Serializable

    Permalink
  10. def compress(s: String): String

    Permalink
    Annotations
    @Py4JWhitelist()
  11. def createSparkSession(): SparkSession

    Permalink
    Annotations
    @Py4JWhitelist()
  12. def decompress(s: String): String

    Permalink
    Annotations
    @Py4JWhitelist()
  13. def fsPrefix(path: String, spark: SparkSession): String

    Permalink
    Annotations
    @Py4JWhitelist()
  14. package util

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped