You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@seatunnel.apache.org by "chaorongzhi (via GitHub)" <gi...@apache.org> on 2023/03/23 10:21:11 UTC

[GitHub] [incubator-seatunnel] chaorongzhi opened a new issue, #4403: [Bug] [connector-v2] [MySQL-CDC] The zeta engine is buggy in Cluster mode with MySQL-CDC as source and clickhouse as sink.

chaorongzhi opened a new issue, #4403:
URL: https://github.com/apache/incubator-seatunnel/issues/4403

   ### Search before asking
   
   - [X] I had searched in the [issues](https://github.com/apache/incubator-seatunnel/issues?q=is%3Aissue+label%3A%22bug%22) and found no similar issues.
   
   
   ### What happened
   
   When I run the seaTunnel source code with idea, the zeta engine is buggy in Cluster mode with MySQL-CDC as source and clickhouse as sink.
   
   ### SeaTunnel Version
   
   dev
   
   ### SeaTunnel Config
   
   ```conf
   env {
     execution.parallelism = 1
     job.mode = "STREAMING"
   }
   
   source {
     MySQL-CDC {
       result_table_name = "mysql-cdc"
       parallelism = 1
       server-id = 5656
       username = "xxx"
       password = "xxx"
       catalog = {
           factory = "MySQL"
       }
       database-names = ["cdc_test"]
       table-names = ["cdc_test.test"]
       base-url = "jdbc:mysql://192.168.xxx.xxx:3306/cdc_test"
     }
   }
   
   sink {
         Clickhouse {
           source_table_name = "mysql-cdc"
           host = "192.168.xxx.xxx:8123"
           database = "default"
           table = "mysql_cdc"
           username = "xxx"
           password = "xxx"
           bulk_size = 1
   
           # cdc options
           primary_key = "id"
           support_upsert = true
           allow_experimental_lightweight_delete = true
         }
   }
   ```
   
   
   ### Running Command
   
   ```shell
   none
   ```
   
   
   ### Error Exception
   
   ```log
   Exception in thread "main" org.apache.seatunnel.core.starter.exception.CommandExecuteException: SeaTunnel job executed failed
   	at org.apache.seatunnel.core.starter.seatunnel.command.ClientExecuteCommand.execute(ClientExecuteCommand.java:181)
   	at org.apache.seatunnel.core.starter.SeaTunnel.run(SeaTunnel.java:40)
   	at org.apache.seatunnel.example.engine.SeaTunnelEngineExample.main(SeaTunnelEngineExample.java:43)
   Caused by: org.apache.seatunnel.engine.common.exception.SeaTunnelEngineException: java.util.concurrent.CompletionException: java.lang.ClassCastException: cannot assign instance of io.debezium.relational.TableId to field org.apache.seatunnel.connectors.cdc.base.source.split.SnapshotSplit.tableId of type io.debezium.relational.TableId in instance of org.apache.seatunnel.connectors.cdc.base.source.split.SnapshotSplit
   	at com.hazelcast.spi.impl.AbstractInvocationFuture.returnOrThrowWithJoinConventions(AbstractInvocationFuture.java:819)
   	at com.hazelcast.spi.impl.AbstractInvocationFuture.resolveAndThrowWithJoinConvention(AbstractInvocationFuture.java:835)
   	at com.hazelcast.spi.impl.AbstractInvocationFuture.join(AbstractInvocationFuture.java:545)
   	at org.apache.seatunnel.engine.server.task.context.SeaTunnelSplitEnumeratorContext.assignSplit(SeaTunnelSplitEnumeratorContext.java:69)
   	at org.apache.seatunnel.api.source.SourceSplitEnumerator$Context.assignSplit(SourceSplitEnumerator.java:101)
   	at org.apache.seatunnel.connectors.cdc.base.source.enumerator.IncrementalSourceEnumerator.assignSplits(IncrementalSourceEnumerator.java:159)
   	at org.apache.seatunnel.connectors.cdc.base.source.enumerator.IncrementalSourceEnumerator.run(IncrementalSourceEnumerator.java:69)
   	at org.apache.seatunnel.engine.server.task.SourceSplitEnumeratorTask.stateProcess(SourceSplitEnumeratorTask.java:276)
   	at org.apache.seatunnel.engine.server.task.SourceSplitEnumeratorTask.call(SourceSplitEnumeratorTask.java:128)
   	at org.apache.seatunnel.engine.server.TaskExecutionService$BlockingWorker.run(TaskExecutionService.java:526)
   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
   	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   	at java.lang.Thread.run(Thread.java:750)
   Caused by: java.lang.ClassCastException: cannot assign instance of io.debezium.relational.TableId to field org.apache.seatunnel.connectors.cdc.base.source.split.SnapshotSplit.tableId of type io.debezium.relational.TableId in instance of org.apache.seatunnel.connectors.cdc.base.source.split.SnapshotSplit
   	at java.io.ObjectStreamClass$FieldReflector.setObjFieldValues(ObjectStreamClass.java:2302)
   	at java.io.ObjectStreamClass.setObjFieldValues(ObjectStreamClass.java:1432)
   	at java.io.ObjectInputStream.defaultReadFields(ObjectInputStream.java:2460)
   	at java.io.ObjectInputStream.readSerialData(ObjectInputStream.java:2378)
   	at java.io.ObjectInputStream.readOrdinaryObject(ObjectInputStream.java:2236)
   	at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1692)
   	at java.io.ObjectInputStream.readArray(ObjectInputStream.java:2142)
   	at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1680)
   	at java.io.ObjectInputStream.readObject(ObjectInputStream.java:508)
   	at java.io.ObjectInputStream.readObject(ObjectInputStream.java:466)
   	at org.apache.seatunnel.common.utils.SerializationUtils.deserialize(SerializationUtils.java:96)
   	at org.apache.seatunnel.engine.server.task.operation.source.AssignSplitOperation.lambda$run$1(AssignSplitOperation.java:63)
   	at org.apache.seatunnel.common.utils.RetryUtils.retryWithException(RetryUtils.java:48)
   	at org.apache.seatunnel.engine.server.task.operation.source.AssignSplitOperation.run(AssignSplitOperation.java:55)
   	at com.hazelcast.spi.impl.operationservice.Operation.call(Operation.java:189)
   	at com.hazelcast.spi.impl.operationservice.impl.OperationRunnerImpl.call(OperationRunnerImpl.java:273)
   	at com.hazelcast.spi.impl.operationservice.impl.OperationRunnerImpl.run(OperationRunnerImpl.java:248)
   	at com.hazelcast.spi.impl.operationservice.impl.OperationRunnerImpl.run(OperationRunnerImpl.java:213)
   	at com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl.run(OperationExecutorImpl.java:411)
   	at com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl.runOrExecute(OperationExecutorImpl.java:438)
   	at com.hazelcast.spi.impl.operationservice.impl.Invocation.doInvokeLocal(Invocation.java:601)
   	at com.hazelcast.spi.impl.operationservice.impl.Invocation.doInvoke(Invocation.java:580)
   	at com.hazelcast.spi.impl.operationservice.impl.Invocation.invoke0(Invocation.java:541)
   	at com.hazelcast.spi.impl.operationservice.impl.Invocation.invoke(Invocation.java:241)
   	at com.hazelcast.spi.impl.operationservice.impl.InvocationBuilderImpl.invoke(InvocationBuilderImpl.java:61)
   	at org.apache.seatunnel.engine.server.utils.NodeEngineUtil.sendOperationToMemberNode(NodeEngineUtil.java:51)
   	at org.apache.seatunnel.engine.server.execution.TaskExecutionContext.sendToMember(TaskExecutionContext.java:47)
   	at org.apache.seatunnel.engine.server.task.context.SeaTunnelSplitEnumeratorContext.assignSplit(SeaTunnelSplitEnumeratorContext.java:64)
   	... 11 more
   	at org.apache.seatunnel.engine.client.job.ClientJobProxy.waitForJobComplete(ClientJobProxy.java:119)
   	at org.apache.seatunnel.core.starter.seatunnel.command.ClientExecuteCommand.execute(ClientExecuteCommand.java:174)
   	... 2 more
   2023-03-23 14:11:33,345 INFO  org.apache.seatunnel.core.starter.seatunnel.command.ClientExecuteCommand - run shutdown hook because get close signal
   [ERROR] Command execution failed.
   org.apache.commons.exec.ExecuteException: Process exited with an error: 1 (Exit value: 1)
       at org.apache.commons.exec.DefaultExecutor.executeInternal (DefaultExecutor.java:404)
       at org.apache.commons.exec.DefaultExecutor.execute (DefaultExecutor.java:166)
       at org.codehaus.mojo.exec.ExecMojo.executeCommandLine (ExecMojo.java:1000)
       at org.codehaus.mojo.exec.ExecMojo.executeCommandLine (ExecMojo.java:947)
       at org.codehaus.mojo.exec.ExecMojo.execute (ExecMojo.java:471)
       at org.apache.maven.plugin.DefaultBuildPluginManager.executeMojo (DefaultBuildPluginManager.java:137)
       at org.apache.maven.lifecycle.internal.MojoExecutor.execute (MojoExecutor.java:210)
       at org.apache.maven.lifecycle.internal.MojoExecutor.execute (MojoExecutor.java:156)
       at org.apache.maven.lifecycle.internal.MojoExecutor.execute (MojoExecutor.java:148)
       at org.apache.maven.lifecycle.internal.LifecycleModuleBuilder.buildProject (LifecycleModuleBuilder.java:117)
       at org.apache.maven.lifecycle.internal.LifecycleModuleBuilder.buildProject (LifecycleModuleBuilder.java:81)
       at org.apache.maven.lifecycle.internal.builder.singlethreaded.SingleThreadedBuilder.build (SingleThreadedBuilder.java:56)
       at org.apache.maven.lifecycle.internal.LifecycleStarter.execute (LifecycleStarter.java:128)
       at org.apache.maven.DefaultMaven.doExecute (DefaultMaven.java:305)
       at org.apache.maven.DefaultMaven.doExecute (DefaultMaven.java:192)
       at org.apache.maven.DefaultMaven.execute (DefaultMaven.java:105)
       at org.apache.maven.cli.MavenCli.execute (MavenCli.java:972)
       at org.apache.maven.cli.MavenCli.doMain (MavenCli.java:293)
       at org.apache.maven.cli.MavenCli.main (MavenCli.java:196)
       at sun.reflect.NativeMethodAccessorImpl.invoke0 (Native Method)
       at sun.reflect.NativeMethodAccessorImpl.invoke (NativeMethodAccessorImpl.java:62)
       at sun.reflect.DelegatingMethodAccessorImpl.invoke (DelegatingMethodAccessorImpl.java:43)
       at java.lang.reflect.Method.invoke (Method.java:498)
       at org.codehaus.plexus.classworlds.launcher.Launcher.launchEnhanced (Launcher.java:282)
       at org.codehaus.plexus.classworlds.launcher.Launcher.launch (Launcher.java:225)
       at org.codehaus.plexus.classworlds.launcher.Launcher.mainWithExitCode (Launcher.java:406)
       at org.codehaus.plexus.classworlds.launcher.Launcher.main (Launcher.java:347)
       at org.codehaus.classworlds.Launcher.main (Launcher.java:47)
   ```
   
   
   ### Flink or Spark Version
   
   none
   
   ### Java or Scala Version
   
   jdk1.8
   
   ### Screenshots
   
   ![image](https://user-images.githubusercontent.com/59403328/227173813-0b1d7410-eccf-4dd1-8d69-edf8c690f271.png)
   
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@seatunnel.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [incubator-seatunnel] EricJoy2048 commented on issue #4403: [Bug] [connector-v2] [MySQL-CDC] The zeta engine is buggy in Cluster mode with MySQL-CDC as source and clickhouse as sink.

Posted by "EricJoy2048 (via GitHub)" <gi...@apache.org>.
EricJoy2048 commented on issue #4403:
URL: https://github.com/apache/incubator-seatunnel/issues/4403#issuecomment-1484536190

   @ic4y  PTAL


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@seatunnel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [incubator-seatunnel] ic4y commented on issue #4403: [Bug] [connector-v2] [MySQL-CDC] The zeta engine is buggy in Cluster mode with MySQL-CDC as source and clickhouse as sink.

Posted by "ic4y (via GitHub)" <gi...@apache.org>.
ic4y commented on issue #4403:
URL: https://github.com/apache/incubator-seatunnel/issues/4403#issuecomment-1484582847

   > @ic4y PTAL
   
   This issue has been fixed. It is recommended to use the latest dev branch for testing.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@seatunnel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [incubator-seatunnel] ic4y commented on issue #4403: [Bug] [connector-v2] [MySQL-CDC] The zeta engine is buggy in Cluster mode with MySQL-CDC as source and clickhouse as sink.

Posted by "ic4y (via GitHub)" <gi...@apache.org>.
ic4y commented on issue #4403:
URL: https://github.com/apache/incubator-seatunnel/issues/4403#issuecomment-1484622309

   This issue should have been fixed in this pr
   https://github.com/apache/incubator-seatunnel/pull/3817


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@seatunnel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [incubator-seatunnel] github-actions[bot] commented on issue #4403: [Bug] [connector-v2] [MySQL-CDC] The zeta engine is buggy in Cluster mode with MySQL-CDC as source and clickhouse as sink.

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on issue #4403:
URL: https://github.com/apache/incubator-seatunnel/issues/4403#issuecomment-1524280810

   This issue has been automatically marked as stale because it has not had recent activity for 30 days. It will be closed in next 7 days if no further activity occurs.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@seatunnel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org