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. sealed abstract class ConnectionError extends EnumEntry

    Permalink
  3. sealed abstract class ConnectionException extends Exception

    Permalink
  4. sealed abstract class ErrorCode extends IntEnumEntry

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

    Permalink
  6. 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
  7. case class FieldValueAndCount(value: Option[String], count: Long) extends Product with Serializable

    Permalink
  8. case class IndexUrlFailedException(parameter: String*) extends ConnectionException with Product with Serializable

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

    Permalink
  10. 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, expectedInterims: List[InterimKey]) extends SparkListenerEvent with Product with Serializable

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

    Permalink
  12. class NoopEventActor extends Actor with ActorPathLogging

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

    Permalink
  14. class ProphecyEventActor extends Actor with ActorPathLogging

    Permalink
  15. class ProphecyEventSendingListener extends SparkListener

    Permalink
  16. 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
  17. case class ProphecyJobCompleteEvent(session: String) extends SparkListenerEvent with Product with Serializable

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

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

    Permalink
  20. class ReconnectableWSActor extends Actor with ActorPathLogging

    Permalink

    ReconnectableWSActor is an Akka Actor that connects to a websocket at a specified URL, and manages the connection and message consumption.

    ReconnectableWSActor is an Akka Actor that connects to a websocket at a specified URL, and manages the connection and message consumption. The actor has two states: uninitialized and initialized. In the uninitialized state, the actor attempts to connect to the websocket, and if the connection fails, retries after a delay. In the initialized state, the actor consumes messages from a queue in an await-notify fashion. If a message is consumed successfully, the actor proceeds to process the next message in the queue. If the queue is empty and a new message arrives, the actor starts consuming the new message.

  21. case class ServerSideConnectionException(errorCode: ConnectionError, e: Throwable, parameter: String*) extends ConnectionException with Product with Serializable

    Permalink
  22. case class UnknownException() extends ConnectionException with Product with Serializable

    Permalink
  23. case class WebsocketUpgradeException(errorCode: ConnectionError, parameter: String*) extends ConnectionException with Product with Serializable

    Permalink

Value Members

  1. object ConnectionError extends Enum[ConnectionError]

    Permalink
  2. object ErrorCode extends IntEnum[ErrorCode] with IntPlayJsonValueEnum[ErrorCode]

    Permalink
  3. object FieldDetailedStat extends Serializable

    Permalink
  4. object FieldValueAndCount extends Serializable

    Permalink
  5. object InterimKey extends Serializable

    Permalink
  6. object Main2 extends App

    Permalink
  7. object NoopEventActor

    Permalink
  8. object ProphecyDetailedStatEvent extends Serializable

    Permalink
  9. object ProphecyEventActor extends LazyLogging

    Permalink
  10. object ProphecyEventSendingListener extends LazyLogging

    Permalink
  11. object ProphecyJobCompleteEvent extends Serializable

    Permalink
  12. object Quantile extends Serializable

    Permalink
  13. object ReconnectableWSActor

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

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

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

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

    Permalink
    Annotations
    @Py4JWhitelist()
  18. package util

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped