org.apache.spark.streaming

scheduler

package scheduler

Visibility
  1. Public
  2. All

Type Members

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

    :: DeveloperApi :: Class having information on completed batches.

    :: DeveloperApi :: Class having information on completed batches.

    batchTime

    Time of the batch

    streamIdToNumRecords

    A map of input stream id to record number

    submissionTime

    Clock time of when jobs of this batch was submitted to the streaming scheduler queue

    processingStartTime

    Clock time of when the first job of this batch started processing

    processingEndTime

    Clock time of when the last job of this batch finished processing

    Annotations
    @DeveloperApi()
  2. case class ReceiverInfo(streamId: Int, name: String, endpoint: RpcEndpointRef, active: Boolean, location: String, lastErrorMessage: String = "", lastError: String = "", lastErrorTime: Long = 1L) extends Product with Serializable

    :: DeveloperApi :: Class having information about a receiver

    :: DeveloperApi :: Class having information about a receiver

    Annotations
    @DeveloperApi()
  3. class StatsReportListener extends StreamingListener

    :: DeveloperApi :: A simple StreamingListener that logs summary statistics across Spark Streaming batches

    :: DeveloperApi :: A simple StreamingListener that logs summary statistics across Spark Streaming batches

    Annotations
    @DeveloperApi()
  4. trait StreamingListener extends AnyRef

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

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

    Annotations
    @DeveloperApi()
  5. case class StreamingListenerBatchCompleted(batchInfo: BatchInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  6. case class StreamingListenerBatchStarted(batchInfo: BatchInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  7. case class StreamingListenerBatchSubmitted(batchInfo: BatchInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  8. sealed trait StreamingListenerEvent extends AnyRef

    :: DeveloperApi :: Base trait for events related to StreamingListener

    :: DeveloperApi :: Base trait for events related to StreamingListener

    Annotations
    @DeveloperApi()
  9. case class StreamingListenerReceiverError(receiverInfo: ReceiverInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  10. case class StreamingListenerReceiverStarted(receiverInfo: ReceiverInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  11. case class StreamingListenerReceiverStopped(receiverInfo: ReceiverInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()

Ungrouped