org.apache.spark.streaming

scheduler

package scheduler

Visibility
  1. Public
  2. All

Type Members

  1. case class BatchInfo(batchTime: Time, submissionTime: Long, processingStartTime: Option[Long], processingEndTime: Option[Long]) extends Product with Serializable

    Class having information on completed batches.

  2. class StatsReportListener extends StreamingListener

    A simple StreamingListener that logs summary statistics across Spark Streaming batches

  3. trait StreamingListener extends AnyRef

    A listener interface for receiving information about an ongoing streaming computation.

  4. case class StreamingListenerBatchCompleted(batchInfo: BatchInfo) extends StreamingListenerEvent with Product with Serializable

  5. case class StreamingListenerBatchStarted(batchInfo: BatchInfo) extends StreamingListenerEvent with Product with Serializable

  6. sealed trait StreamingListenerEvent extends AnyRef

    Base trait for events related to StreamingListener

Ungrouped