Package

org.apache.spark.sql

event

Permalink

package event

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

Type Members

  1. case class ComponentMetrics(jobId: String, fabricId: String, jobRunId: String, taskRunId: String, pipelineUid: String, runType: RunType, userId: String, interim: String) extends ExecutionMetricsEvent with Product with Serializable

    Permalink
  2. case class DatabricksJobGroupMatcher(commandId: String) extends JobGroupMatcher with Product with Serializable

    Permalink
  3. sealed trait ExecutionMetricsEvent extends AnyRef

    Permalink
  4. trait JobGroupMatcher extends AnyRef

    Permalink
  5. case class LivyJobGroupMatcher(statementId: Int) extends JobGroupMatcher with Product with Serializable

    Permalink
  6. case class PipelineMetrics(jobId: String, timestamp: Long, timeTaken: Long, rowsRead: Option[Long], rowsWritten: Option[Long], fabricId: String, status: PipelineStatus, jobRunId: String, taskRunId: String, pipelineUid: String, runType: RunType, userId: String) extends ExecutionMetricsEvent with Product with Serializable

    Permalink
  7. case class PipelineRunContent(pipelineRunId: String, pipelineUID: String, jobId: Option[String], jobName: Option[String], fabricId: Long, submissionTime: Long, status: PipelineStatus, timeTaken: Option[Long], rowsRead: Option[Long], rowsWritten: Option[Long], runType: RunType, code: RecursiveDirectoryContent) extends Product with Serializable

    Permalink
  8. case class PipelineRunStartedEvent(jobId: String, timestamp: Long, fabricId: String, status: PipelineStatus = PipelineStatus.STARTED, jobRunId: String, taskRunId: String, pipelineUid: String, runType: RunType, userId: String) extends ExecutionMetricsEvent with Product with Serializable

    Permalink
  9. sealed trait PipelineStatus extends EnumEntry

    Permalink
  10. trait Result extends AnyRef

    Permalink
  11. sealed trait RunType extends EnumEntry

    Permalink
  12. class SparkExecutionMetricsCollector extends LazyLogging

    Permalink
  13. case class Succeeded(session: String, job: String, msg: String) extends Result with Product with Serializable

    Permalink
  14. case class WorkflowNode(subgraph: String, component: String, processId: Option[String] = None, sessionId: String) extends Product with Serializable

    Permalink
  15. case class WorkflowProcessNodeInfo(subgraph: String, component: String) extends Product with Serializable

    Permalink
  16. case class WorkflowProcessesDetail(session: String, processes: Map[String, WorkflowProcessNodeInfo]) extends Product with Serializable

    Permalink

Value Members

  1. object ComponentMetrics extends Serializable

    Permalink
  2. object ExecutionMetricsEvent

    Permalink
  3. object PipelineMetrics extends Serializable

    Permalink
  4. object PipelineRunContent extends Product with Serializable

    Permalink
  5. object PipelineRunStartedEvent extends Serializable

    Permalink
  6. object PipelineStatus extends Enum[PipelineStatus] with PlayJsonEnum[PipelineStatus]

    Permalink
  7. object RunType extends Enum[RunType] with PlayJsonEnum[RunType]

    Permalink
  8. object SparkExecutionMetricsCollector

    Permalink
  9. object WorkflowNode extends Product with Serializable

    Permalink
  10. object WorkflowProcessNodeInfo extends Product with Serializable

    Permalink
  11. package metadata

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped