org.apache.spark.sql.streaming

StreamingQueryProgress

class StreamingQueryProgress extends Serializable

Information about progress made in the execution of a StreamingQuery during a trigger. Each event relates to processing done for a single trigger of the streaming query. Events are emitted even when no new data is available to be processed.

Annotations
@Evolving()
Since

2.1.0

Linear Supertypes
Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. StreamingQueryProgress
  2. Serializable
  3. Serializable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. val batchId: Long

    A unique id for the current batch of data being processed.

    A unique id for the current batch of data being processed. Note that in the case of retries after a failure a given batchId my be executed more than once. Similarly, when there is no data to be processed, the batchId will not be incremented.

  8. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. val durationMs: Map[String, Long]

    The amount of time taken to perform various operations in milliseconds.

  10. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  11. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  12. val eventTime: Map[String, String]

    Statistics of event time seen in this batch.

    Statistics of event time seen in this batch. It may contain the following keys:

    "max" -> "2016-12-05T20:54:20.827Z"  // maximum event time seen in this trigger
    "min" -> "2016-12-05T20:54:20.827Z"  // minimum event time seen in this trigger
    "avg" -> "2016-12-05T20:54:20.827Z"  // average event time seen in this trigger
    "watermark" -> "2016-12-05T20:54:20.827Z"  // watermark used in this trigger

    All timestamps are in ISO8601 format, i.e. UTC timestamps.

  13. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  14. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  15. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  16. val id: UUID

    An unique query id that persists across restarts.

    An unique query id that persists across restarts. See StreamingQuery.id().

  17. def inputRowsPerSecond: Double

    The aggregate (across all sources) rate of data arriving.

  18. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  19. def json: String

    The compact JSON representation of this progress.

  20. val name: String

    User-specified name of the query, null if not specified.

  21. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  22. final def notify(): Unit

    Definition Classes
    AnyRef
  23. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  24. def numInputRows: Long

    The aggregate (across all sources) number of records processed in a trigger.

  25. def prettyJson: String

    The pretty (i.

    The pretty (i.e. indented) JSON representation of this progress.

  26. def processedRowsPerSecond: Double

    The aggregate (across all sources) rate at which Spark is processing data.

  27. val runId: UUID

    A query id that is unique for every start/restart.

    A query id that is unique for every start/restart. See StreamingQuery.runId().

  28. val sink: SinkProgress

  29. val sources: Array[SourceProgress]

    detailed statistics on data being read from each of the streaming sources.

  30. val stateOperators: Array[StateOperatorProgress]

    Information about operators in the query that store state.

  31. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  32. val timestamp: String

    Beginning time of the trigger in ISO8601 format, i.

    Beginning time of the trigger in ISO8601 format, i.e. UTC timestamps.

  33. def toString(): String

    Definition Classes
    StreamingQueryProgress → AnyRef → Any
  34. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  35. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  36. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped