Packages

p

org.apache.spark.sql

prophecy

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
  2. sealed abstract class ConnectionError extends EnumEntry
  3. sealed abstract class ConnectionException extends Exception
  4. sealed abstract class ErrorCode extends IntEnumEntry
  5. case class FieldDetailedStat(field: String, ndv: Long, quantiles: Option[Seq[Quantile]] = None, topN: Option[Seq[FieldValueAndCount]] = None) extends Product with Serializable
  6. case class FieldStat[FieldDataType, FieldStatType](field: String, nulls: Option[Long] = None, nonNulls: Option[Long] = None, min: Option[FieldDataType] = None, max: Option[FieldDataType] = None, mean: Option[FieldStatType] = None, stddev: Option[FieldStatType] = None) extends Product with Serializable
  7. case class FieldValueAndCount(value: Option[String], count: Long) extends Product with Serializable
  8. case class IndexUrlFailedException(parameter: String*) extends ConnectionException with Product with Serializable
  9. case class InterimKey(subgraph: String, component: String, port: String, runIdOpt: Option[String] = None) extends Serializable with Product
  10. case class InterimSummary(appended: List[InterimKey], planned: List[InterimKey], executed: List[InterimKey], found: List[InterimKey]) extends Product with Serializable
  11. case class JobMetricsMetadata(uuid: Option[String], jobURI: Option[String], fabricId: Option[String], timeStarted: Long, isInteractive: Option[Boolean], taskRunId: String, pipelineUri: String, userId: Option[String], branch: Option[String] = None, prophecyUrl: Option[String] = None, expectedInterims: List[InterimKey], pipelineConfig: Option[String] = None) extends SparkListenerEvent with Product with Serializable
  12. case class JobPipelineEndEvent(status: PipelineStatus) extends SparkListenerEvent with Product with Serializable
  13. case class LibraryMismatchException(exception: Throwable, parameters: String*) extends ConnectionException with Product with Serializable
  14. class NoopEventActor extends Actor with ActorPathLogging
  15. case class ProphecyDetailedStatEvent(key: InterimKey, jobId: String, detailedStats: Seq[FieldDetailedStat]) extends SparkListenerEvent with Product with Serializable
  16. class ProphecyEventActor extends Actor with ActorPathLogging with FutureExtensions
  17. class ProphecyEventSendingListener extends SparkListener
  18. 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
  19. case class ProphecyJobCompleteEvent(session: String, interimSummary: Option[InterimSummary] = None) extends SparkListenerEvent with Product with Serializable
  20. case class Quantile(quantile: Int, value: Double) extends Product with Serializable
  21. case class RDDInterimKey(subgraph: String, component: String, port: String, runIdOpt: Option[String] = None, rddId: Int) extends Serializable with Product
  22. class ReconnectableWSActor extends Actor with ActorPathLogging

    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.

  23. case class ServerSideConnectionException(errorCode: ConnectionError, e: Throwable, parameter: String*) extends ConnectionException with Product with Serializable
  24. class StatsAccumulator extends AccumulatorV2[Double, Double]
  25. case class UnknownException(exception: Option[Throwable], parameters: String*) extends ConnectionException with Product with Serializable
  26. case class WebsocketUpgradeException(errorCode: ConnectionError, parameter: String*) extends ConnectionException with Product with Serializable

Value Members

  1. def compress(s: String): String
    Annotations
    @Py4JWhitelist()
  2. def createSparkSession(): SparkSession
    Annotations
    @Py4JWhitelist()
  3. def decompress(s: String): String
    Annotations
    @Py4JWhitelist()
  4. def fsPrefix(path: String, spark: SparkSession): String
    Annotations
    @Py4JWhitelist()
  5. object ConnectionError extends Enum[ConnectionError]
  6. object ErrorCode extends IntEnum[ErrorCode] with IntPlayJsonValueEnum[ErrorCode]
  7. object FieldDetailedStat extends Serializable
  8. object FieldValueAndCount extends Serializable
  9. object InterimKey extends Serializable
  10. object InterimSummary extends Serializable
  11. object Main2 extends App
  12. object NoopEventActor
  13. object ProphecyDetailedStatEvent extends Serializable
  14. object ProphecyEventActor extends AutoCloseable with LazyLogging
  15. object ProphecyEventSendingListener extends LazyLogging
  16. object ProphecyJobCompleteEvent extends Serializable
  17. object Quantile extends Serializable
  18. object ReconnectableWSActor

Inherited from AnyRef

Inherited from Any

Ungrouped