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.

  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

  3. class StatsReportListener extends StreamingListener

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

  4. trait StreamingListener extends AnyRef

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

  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

  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