package prophecy
- Alphabetic
- By Inheritance
- prophecy
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
- trait ActorPathLogging extends AnyRef
- sealed abstract class ConnectionError extends EnumEntry
- sealed abstract class ConnectionException extends Exception
- sealed abstract class ErrorCode extends IntEnumEntry
- case class FieldDetailedStat(field: String, ndv: Long, quantiles: Option[Seq[Quantile]] = None, topN: Option[Seq[FieldValueAndCount]] = None) extends Product with Serializable
- 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
- case class FieldValueAndCount(value: Option[String], count: Long) extends Product with Serializable
- case class IndexUrlFailedException(parameter: String*) extends ConnectionException with Product with Serializable
- case class InterimKey(subgraph: String, component: String, port: String, runIdOpt: Option[String] = None) extends Serializable with Product
- case class InterimSummary(appended: List[InterimKey], planned: List[InterimKey], executed: List[InterimKey], found: List[InterimKey]) extends Product with Serializable
- 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
- case class JobPipelineEndEvent(status: PipelineStatus) extends SparkListenerEvent with Product with Serializable
- case class LibraryMismatchException(exception: Throwable, parameters: String*) extends ConnectionException with Product with Serializable
- class NoopEventActor extends Actor with ActorPathLogging
- case class ProphecyDetailedStatEvent(key: InterimKey, jobId: String, detailedStats: Seq[FieldDetailedStat]) extends SparkListenerEvent with Product with Serializable
- class ProphecyEventActor extends Actor with ActorPathLogging with FutureExtensions
- class ProphecyEventSendingListener extends SparkListener
- 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
- case class ProphecyJobCompleteEvent(session: String, interimSummary: Option[InterimSummary] = None) extends SparkListenerEvent with Product with Serializable
- case class Quantile(quantile: Int, value: Double) extends Product with Serializable
- case class RDDInterimKey(subgraph: String, component: String, port: String, runIdOpt: Option[String] = None, rddId: Int) extends Serializable with Product
-
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.
- case class ServerSideConnectionException(errorCode: ConnectionError, e: Throwable, parameter: String*) extends ConnectionException with Product with Serializable
- class StatsAccumulator extends AccumulatorV2[Double, Double]
- case class UnknownException(exception: Option[Throwable], parameters: String*) extends ConnectionException with Product with Serializable
- case class WebsocketUpgradeException(errorCode: ConnectionError, parameter: String*) extends ConnectionException with Product with Serializable
Value Members
-
def
compress(s: String): String
- Annotations
- @Py4JWhitelist()
-
def
createSparkSession(): SparkSession
- Annotations
- @Py4JWhitelist()
-
def
decompress(s: String): String
- Annotations
- @Py4JWhitelist()
-
def
fsPrefix(path: String, spark: SparkSession): String
- Annotations
- @Py4JWhitelist()
- object ConnectionError extends Enum[ConnectionError]
- object ErrorCode extends IntEnum[ErrorCode] with IntPlayJsonValueEnum[ErrorCode]
- object FieldDetailedStat extends Serializable
- object FieldValueAndCount extends Serializable
- object InterimKey extends Serializable
- object InterimSummary extends Serializable
- object Main2 extends App
- object NoopEventActor
- object ProphecyDetailedStatEvent extends Serializable
- object ProphecyEventActor extends AutoCloseable with LazyLogging
- object ProphecyEventSendingListener extends LazyLogging
- object ProphecyJobCompleteEvent extends Serializable
- object Quantile extends Serializable
- object ReconnectableWSActor