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

Source Coordinator Thread already exists. There should never be more than one thread driving the actions of a Source Coordinator.

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Critical
    • Resolution: Feedback Received
    • 1.13.3
    • None
    • None
    • flink-cdc 2.1

    Description

       

      When I am synchronizing large tables, have the following problems :

      2021-11-09 20:33:04,222 INFO com.ververica.cdc.connectors.mysql.source.enumerator.MySqlSourceEnumerator [] - Assign split MySqlSnapshotSplit{tableId=db.table, splitId='db.table:383', splitKeyType=[`id` BIGINT NOT NULL], splitStart=[9798290], splitEnd=[9823873], highWatermark=null} to subtask 1
      2021-11-09 20:33:04,248 INFO org.apache.flink.runtime.checkpoint.CheckpointCoordinator [] - Triggering checkpoint 101 (type=CHECKPOINT) @ 1636461183945 for job 3cee105643cfee78b80cd0a41143b5c1.
      2021-11-09 20:33:10,734 ERROR org.apache.flink.runtime.util.FatalExitExceptionHandler [] - FATAL: Thread 'SourceCoordinator-Source: mysqlcdc-source -> Sink: kafka-sink' produced an uncaught exception. Stopping the process...
      java.lang.Error: Source Coordinator Thread already exists. There should never be more than one thread driving the actions of a Source Coordinator. Existing Thread: Thread[SourceCoordinator-Source: mysqlcdc-source -> Sink: kafka-sink,5,main]
      at org.apache.flink.runtime.source.coordinator.SourceCoordinatorProvider$CoordinatorExecutorThreadFactory.newThread(SourceCoordinatorProvider.java:119) [flink-dist_2.12-1.13.3.jar:1.13.3]
      at java.util.concurrent.ThreadPoolExecutor$Worker.<init>(ThreadPoolExecutor.java:619) ~[?:1.8.0_191]
      at java.util.concurrent.ThreadPoolExecutor.addWorker(ThreadPoolExecutor.java:932) ~[?:1.8.0_191]
      at java.util.concurrent.ThreadPoolExecutor.processWorkerExit(ThreadPoolExecutor.java:1025) ~[?:1.8.0_191]
      at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1167) ~[?:1.8.0_191]
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) ~[?:1.8.0_191]

      Attachments

        Issue Links

          Activity

            People

              Unassigned Unassigned
              wangminchao WangMinChao
              Votes:
              0 Vote for this issue
              Watchers:
              4 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: