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

jobmaster log taskmanger address when task transition state to failed with error

    XMLWordPrintableJSON

Details

    Description

      when look over jobmaster log to find why job failed, log is like that: 

      // code placeholder
      2019-06-13 10:13:28,066 INFO  org.apache.flink.runtime.executiongraph.ExecutionGraph        - Source: Socket Stream -> Flat Map -> (Flat Map, Flat Map, Flat Map -> Sink: Unnamed) (1/1) (dc39ce18d3f1b4aa15198151e7544162) switched from RUNNING to FAILED.
      java.net.ConnectException: Connection refused
      	at java.net.PlainSocketImpl.socketConnect(Native Method)
      	at java.net.AbstractPlainSocketImpl.doConnect(AbstractPlainSocketImpl.java:350)
      	at java.net.AbstractPlainSocketImpl.connectToAddress(AbstractPlainSocketImpl.java:206)
      	at java.net.AbstractPlainSocketImpl.connect(AbstractPlainSocketImpl.java:188)
      	at java.net.SocksSocketImpl.connect(SocksSocketImpl.java:392)
      	at java.net.Socket.connect(Socket.java:589)
      	at org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction.run(SocketTextStreamFunction.java:96)
      	at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:112)
      	at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:74)
      	at org.apache.flink.streaming.runtime.tasks.SourceStreamTask.run(SourceStreamTask.java:94)
      	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:299)
      	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:718)
      	at java.lang.Thread.run(Thread.java:745)
      2
      
      

      I  know why job failed from this log, but when i want to find out  where the failed task(Lead to job failed) is located, i find it is not obvious. however some environment problems actully needs to know taskmanger address, so we can add this on log

       

      Attachments

        Issue Links

          Activity

            People

              Unassigned Unassigned
              zhaoshijie zzsmdfj
              Votes:
              0 Vote for this issue
              Watchers:
              2 Start watching this issue

              Dates

                Created:
                Updated:

                Time Tracking

                  Estimated:
                  Original Estimate - Not Specified
                  Not Specified
                  Remaining:
                  Remaining Estimate - 0h
                  0h
                  Logged:
                  Time Spent - 10m
                  10m