Packages

c

org.apache.spark.sql.execution.streaming

ContinuousExecutionContext

class ContinuousExecutionContext extends StreamExecutionContext

Holds the all mutable state and metrics for a epoch when using continuous execution mode

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ContinuousExecutionContext
  2. StreamExecutionContext
  3. ProgressContext
  4. Logging
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new ContinuousExecutionContext(id: UUID, runId: UUID, name: String, triggerClock: Clock, sources: Seq[SparkDataStream], sink: Table, progressReporter: ProgressReporter, epochId: Long, sparkSession: SparkSession)

Type Members

  1. implicit class LogStringContext extends AnyRef
    Definition Classes
    Logging

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. var batchId: Long
    Definition Classes
    StreamExecutionContext
  6. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
  7. var currentStatus: StreamingQueryStatus
    Definition Classes
    ProgressContext
  8. var currentTriggerStartTimestamp: Long
    Attributes
    protected
    Definition Classes
    ProgressContext
  9. var endOffsets: StreamProgress

    Stores the end offsets for this batch.

    Stores the end offsets for this batch. Only the scheduler thread should modify this field, and only in atomic steps. Other threads should make a shallow copy if they are going to access this field more than once, since the field's value may change at any time.

    Definition Classes
    StreamExecutionContext
  10. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  11. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  12. var execStatsOnLatestExecutedBatch: Option[ExecutionStats]
    Attributes
    protected
    Definition Classes
    ProgressContext
  13. var executionPlan: IncrementalExecution
    Definition Classes
    StreamExecutionContext
  14. def finishNoExecutionTrigger(lastExecutedEpochId: Long): Unit

    Finalizes the trigger which did not execute a batch.

    Finalizes the trigger which did not execute a batch.

    Definition Classes
    ProgressContext
  15. def finishTrigger(hasNewData: Boolean, lastExecution: IncrementalExecution, lastEpoch: Long): Unit

    Override of finishTrigger to extract the map from IncrementalExecution.

    Override of finishTrigger to extract the map from IncrementalExecution.

    Definition Classes
    ProgressContext
  16. def finishTrigger(hasNewData: Boolean, sourceToNumInputRowsMap: Map[SparkDataStream, Long], lastExecution: IncrementalExecution, lastEpochId: Long): Unit

    Finalizes the query progress and adds it to list of recent status updates.

    Finalizes the query progress and adds it to list of recent status updates.

    hasNewData

    Whether the sources of this stream had new data for this trigger.

    Definition Classes
    ProgressContext
  17. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  18. def getDuration(key: String): Option[Long]

    Retrieve a measured duration

    Retrieve a measured duration

    Definition Classes
    ProgressContext
  19. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  20. val id: UUID
    Definition Classes
    StreamExecutionContext
  21. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
    Attributes
    protected
    Definition Classes
    Logging
  22. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
    Attributes
    protected
    Definition Classes
    Logging
  23. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  24. def isTraceEnabled(): Boolean
    Attributes
    protected
    Definition Classes
    Logging
  25. var lastTriggerStartTimestamp: Long
    Attributes
    protected
    Definition Classes
    ProgressContext
  26. var latestOffsets: StreamProgress

    Tracks the latest offsets for each input source.

    Tracks the latest offsets for each input source. Only the scheduler thread should modify this field, and only in atomic steps. Other threads should make a shallow copy if they are going to access this field more than once, since the field's value may change at any time.

    Definition Classes
    StreamExecutionContext
  27. def log: Logger
    Attributes
    protected
    Definition Classes
    Logging
  28. def logDebug(msg: => String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  29. def logDebug(entry: LogEntry, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  30. def logDebug(entry: LogEntry): Unit
    Attributes
    protected
    Definition Classes
    Logging
  31. def logDebug(msg: => String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  32. def logError(msg: => String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  33. def logError(entry: LogEntry, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  34. def logError(entry: LogEntry): Unit
    Attributes
    protected
    Definition Classes
    Logging
  35. def logError(msg: => String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  36. def logInfo(msg: => String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  37. def logInfo(entry: LogEntry, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  38. def logInfo(entry: LogEntry): Unit
    Attributes
    protected
    Definition Classes
    Logging
  39. def logInfo(msg: => String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  40. def logName: String
    Attributes
    protected
    Definition Classes
    Logging
  41. def logTrace(msg: => String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  42. def logTrace(entry: LogEntry, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  43. def logTrace(entry: LogEntry): Unit
    Attributes
    protected
    Definition Classes
    Logging
  44. def logTrace(msg: => String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  45. def logWarning(msg: => String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  46. def logWarning(entry: LogEntry, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  47. def logWarning(entry: LogEntry): Unit
    Attributes
    protected
    Definition Classes
    Logging
  48. def logWarning(msg: => String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  49. var metricWarningLogged: Boolean

    Flag that signals whether any error with input metrics have already been logged

    Flag that signals whether any error with input metrics have already been logged

    Attributes
    protected
    Definition Classes
    ProgressContext
  50. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  51. var newData: Map[SparkDataStream, LogicalPlan]

    Holds the most recent input data for each source.

    Holds the most recent input data for each source.

    Definition Classes
    StreamExecutionContextProgressContext
  52. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  53. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  54. var offsetSeqMetadata: OffsetSeqMetadata

    Metadata associated with the offset seq of a batch in the query.

    Metadata associated with the offset seq of a batch in the query.

    Definition Classes
    StreamExecutionContextProgressContext
  55. def onExecutionComplete(): Unit
    Definition Classes
    StreamExecutionContext
  56. def onExecutionFailure(): Unit
    Definition Classes
    StreamExecutionContext
  57. def recordTriggerOffsets(from: StreamProgress, to: StreamProgress, latest: StreamProgress): Unit

    Record the offsets range this trigger will process.

    Record the offsets range this trigger will process. Call this before updating committedOffsets in StreamExecution to make sure that the correct range is recorded.

    Definition Classes
    ProgressContext
  58. def reportTimeTaken(triggerDetailKey: String, timeTakenMs: Long): Unit

    Reports an input duration for a particular detail key in the next query progress update.

    Reports an input duration for a particular detail key in the next query progress update. Can be used directly instead of reportTimeTaken(key)(body) when the duration is measured asynchronously.

    Definition Classes
    ProgressContext
  59. def reportTimeTaken[T](triggerDetailKey: String)(body: => T): T

    Records the duration of running body for the next query progress update.

    Records the duration of running body for the next query progress update.

    Definition Classes
    ProgressContext
  60. var sinkCommitProgress: Option[StreamWriterCommitProgress]
    Definition Classes
    ProgressContext
  61. var startOffsets: StreamProgress

    Stores the start offset for this batch.

    Stores the start offset for this batch. Only the scheduler thread should modify this field, and only in atomic steps. Other threads should make a shallow copy if they are going to access this field more than once, since the field's value may change at any time.

    Definition Classes
    StreamExecutionContext
  62. def startTrigger(): Unit

    Begins recording statistics about query progress for a given trigger.

    Begins recording statistics about query progress for a given trigger.

    Definition Classes
    ProgressContext
  63. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  64. def toString(): String
    Definition Classes
    AnyRef → Any
  65. def updateStatusMessage(message: String): Unit

    Updates the message returned in status.

    Updates the message returned in status.

    Definition Classes
    ProgressContext
  66. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  67. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  68. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  69. def withLogContext(context: HashMap[String, String])(body: => Unit): Unit
    Attributes
    protected
    Definition Classes
    Logging

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

Inherited from StreamExecutionContext

Inherited from ProgressContext

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped