Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-17769

Wrong order of log events on a task failure

    XMLWordPrintableJSON

Details

    Description

      In this example, errors from the close() method call are logged before the switched from RUNNING to FAILED log line with the actual exception (which is confusing, because the exceptions coming from close() could be considered as the failure root cause, because they are first in the log)

      2020-05-14 10:12:42,660 INFO  org.apache.flink.streaming.connectors.kinesis.FlinkKinesisProducer [] - Started Kinesis producer instance for region 'eu-central-1'
      2020-05-14 10:12:42,660 DEBUG org.apache.flink.streaming.api.operators.BackendRestorerProcedure [] - Creating operator state backend for StreamSource_cbc357ccb763df2852fee8c4fc7d55f2_(1/1) with empty state.
      2020-05-14 10:12:42,823 INFO  org.apache.flink.streaming.connectors.kinesis.FlinkKinesisProducer [] - Closing producer
      2020-05-14 10:12:42,823 INFO  org.apache.flink.streaming.connectors.kinesis.FlinkKinesisProducer [] - Flushing outstanding 2 records
      2020-05-14 10:12:42,826 ERROR org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Error during disposal of stream operator.
      org.apache.flink.kinesis.shaded.com.amazonaws.services.kinesis.producer.DaemonException: The child process has been shutdown and can no longer accept messages.
      2020-05-14 10:12:42,834 WARN  org.apache.flink.runtime.taskmanager.Task                    [] - Source: Custom Source -> Sink: Unnamed (1/1) (4a49aea047aeb3e67cf79c788df0e558) switched from RUNNING to FAILED.
      

      Attachments

        Issue Links

          Activity

            People

              ym Yuan Mei
              rmetzger Robert Metzger
              Votes:
              0 Vote for this issue
              Watchers:
              6 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: