org.apache.spark.streaming

scheduler

package scheduler

Visibility
  1. Public
  2. All

Type Members

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

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

  2. case class OutputOperationInfo(batchTime: Time, id: Int, name: String, description: String, startTime: Option[Long], endTime: Option[Long], failureReason: Option[String]) extends Product with Serializable

    :: DeveloperApi :: Class having information on output operations.

  3. case class ReceiverInfo(streamId: Int, name: String, active: Boolean, location: String, executorId: String, lastErrorMessage: String = "", lastError: String = "", lastErrorTime: Long = -1L) extends Product with Serializable

    :: DeveloperApi :: Class having information about a receiver

  4. class StatsReportListener extends StreamingListener

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

  5. case class StreamInputInfo(inputStreamId: Int, numRecords: Long, metadata: Map[String, Any] = ...) extends Product with Serializable

    :: DeveloperApi :: Track the information of input stream at specified batch time.

  6. trait StreamingListener extends AnyRef

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

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

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

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

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

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

  11. case class StreamingListenerOutputOperationCompleted(outputOperationInfo: OutputOperationInfo) extends StreamingListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  12. case class StreamingListenerOutputOperationStarted(outputOperationInfo: OutputOperationInfo) extends StreamingListenerEvent with Product with Serializable

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

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

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

    Annotations
    @DeveloperApi()

Value Members

  1. object RateController extends Serializable

  2. object StreamInputInfo extends Serializable

    Annotations
    @DeveloperApi()
  3. package rate

Ungrouped