Class PipelinesErrors

Object
org.apache.spark.sql.pipelines.graph.PipelinesErrors

public class PipelinesErrors extends Object
  • Constructor Details

    • PipelinesErrors

      public PipelinesErrors()
  • Method Details

    • checkStreamingErrorsAndRetry

      public static void checkStreamingErrorsAndRetry(Throwable ex, PipelineUpdateContext env, GraphExecution graphExecution, ResolvedFlow flow, boolean shouldRethrow, int prevFailureCount, int maxRetries, scala.Function0<scala.runtime.BoxedUnit> onRetry)
      Checks an error for streaming specific handling. This is a pretty messy signature as a result of unifying some divergences between the triggered caller in TriggeredGraphExecution and the continuous caller in StreamWatchdog.

      Parameters:
      ex - the error to check
      env - the update context
      graphExecution - the graph execution
      flow - the resolved logical flow
      shouldRethrow - whether to throw an UpdateTerminationException wrapping ex. This is set to true for ContinuousFlowExecution so we can eagerly stop the execution.
      prevFailureCount - the number of failures that have occurred so far
      maxRetries - the max retries that were available (whether or not they're exhausted now)
      onRetry - (undocumented)
    • org$apache$spark$internal$Logging$$log_

      public static org.slf4j.Logger org$apache$spark$internal$Logging$$log_()
    • org$apache$spark$internal$Logging$$log__$eq

      public static void org$apache$spark$internal$Logging$$log__$eq(org.slf4j.Logger x$1)
    • LogStringContext

      public static org.apache.spark.internal.Logging.LogStringContext LogStringContext(scala.StringContext sc)