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

[GitHub] [incubator-seatunnel] zengqinchris opened a new issue, #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   ### 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
   
   从ftp读取文件导入到mysql中,导致java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient
   
   ### SeaTunnel Version
   
   V2
   
   ### SeaTunnel Config
   
   ```conf
   env {
   execution.parallelism = 1
   #execution.checkpoint.interval = 10000
   #execution.checkpoint.data-uri = "hdfs://hadoop102:9092/checkpoint"
   }
   source {
   FtpFile {
   path = "/home/ftpuser/area_20221.csv"
    host = "0.0.0.0"
    port = 21
    user = "xxx"
    password = "xxx"
    type = "csv"
    delimiter = ","
    schema = {
   fields {
   id = int
                           data_type = string
                           data_version = string
                           data_name = string
                           data_desc = string
                           link_json = string
                           data_json = string
                           status = int
                           is_meta = int
                           tenant_id = int
                           data_type_code = int
                           schema_name = string
                           is_deleted = int
                           gmt_create = string
                           gmt_modified = string
                           create_user_id = int
                           modify_user_id = int
   }
   }
    }
   
   }
   transform {
   }
   sink {
   jdbc {
   url = "jdbc:mysql://0.0.0.0:3306/data_called?characterEncoding=utf8&autoReconnect=true&tinyInt1isBit=false&serverTimezone=Asia/Shanghai"
    driver = "com.mysql.cj.jdbc.Driver"
    user = "xxx"
    password = "xxx"
    max_retries = 3
    query = " insert into datasource_info(id, data_type, data_version, data_name, data_desc, link_json, data_json, status, is_meta, tenant_id, data_type_code, schema_name, is_deleted, gmt_create, gmt_modified, create_user_id, modify_user_id) values (?, ?, ?, ?, ?,?, ?, ?, ?, ?,?, ?, ?,?,?,?,?) "
    }
   
   }
   ```
   
   
   ### Running Command
   
   ```shell
   ../bin/start-seatunnel-flink-connector-v2.sh --config ./flink.669.conf
   ```
   
   
   ### Error Exception
   
   ```log
   Job has been submitted with JobID c23182891641f5a22c7bf13da8384818
   
   ------------------------------------------------------------
    The program finished with the following exception:
   
   org.apache.flink.client.program.ProgramInvocationException: The main method caused an error: Flink job executed failed
           at org.apache.flink.client.program.PackagedProgram.callMainMethod(PackagedProgram.java:372)
           at org.apache.flink.client.program.PackagedProgram.invokeInteractiveModeForExecution(PackagedProgram.java:222)
           at org.apache.flink.client.ClientUtils.executeProgram(ClientUtils.java:114)
           at org.apache.flink.client.cli.CliFrontend.executeProgram(CliFrontend.java:812)
           at org.apache.flink.client.cli.CliFrontend.run(CliFrontend.java:246)
           at org.apache.flink.client.cli.CliFrontend.parseAndRun(CliFrontend.java:1054)
           at org.apache.flink.client.cli.CliFrontend.lambda$main$10(CliFrontend.java:1132)
           at java.security.AccessController.doPrivileged(Native Method)
           at javax.security.auth.Subject.doAs(Subject.java:422)
           at org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1729)
           at org.apache.flink.runtime.security.contexts.HadoopSecurityContext.runSecured(HadoopSecurityContext.java:41)
           at org.apache.flink.client.cli.CliFrontend.main(CliFrontend.java:1132)
   Caused by: org.apache.seatunnel.core.starter.exception.CommandExecuteException: Flink job executed failed
           at org.apache.seatunnel.core.starter.flink.command.FlinkApiTaskExecuteCommand.execute(FlinkApiTaskExecuteCommand.java:55)
           at org.apache.seatunnel.core.starter.Seatunnel.run(Seatunnel.java:39)
           at org.apache.seatunnel.core.starter.flink.SeatunnelFlink.main(SeatunnelFlink.java:34)
           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.apache.flink.client.program.PackagedProgram.callMainMethod(PackagedProgram.java:355)
           ... 11 more
   Caused by: org.apache.seatunnel.core.starter.exception.TaskExecuteException: Execute Flink job error
           at org.apache.seatunnel.core.starter.flink.execution.FlinkExecution.execute(FlinkExecution.java:75)
           at org.apache.seatunnel.core.starter.flink.command.FlinkApiTaskExecuteCommand.execute(FlinkApiTaskExecuteCommand.java:53)
           ... 18 more
   Caused by: java.util.concurrent.ExecutionException: org.apache.flink.client.program.ProgramInvocationException: Job failed (JobID: c23182891641f5a22c7bf13da8384818)
           at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
           at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1895)
           at org.apache.flink.client.program.StreamContextEnvironment.getJobExecutionResult(StreamContextEnvironment.java:123)
           at org.apache.flink.client.program.StreamContextEnvironment.execute(StreamContextEnvironment.java:80)
           at org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:1834)
           at org.apache.seatunnel.core.starter.flink.execution.FlinkExecution.execute(FlinkExecution.java:73)
           ... 19 more
   Caused by: org.apache.flink.client.program.ProgramInvocationException: Job failed (JobID: c23182891641f5a22c7bf13da8384818)
           at org.apache.flink.client.deployment.ClusterClientJobClientAdapter.lambda$null$6(ClusterClientJobClientAdapter.java:125)
           at java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:602)
           at java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:577)
           at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
           at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1962)
           at org.apache.flink.runtime.concurrent.FutureUtils.lambda$retryOperationWithDelay$9(FutureUtils.java:394)
           at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:760)
           at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:736)
           at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
           at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1962)
           at org.apache.flink.client.program.rest.RestClusterClient.lambda$pollResourceAsync$24(RestClusterClient.java:670)
           at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:760)
           at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:736)
           at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
           at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1962)
           at org.apache.flink.runtime.concurrent.FutureUtils.lambda$retryOperationWithDelay$9(FutureUtils.java:394)
           at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:760)
           at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:736)
           at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
           at java.util.concurrent.CompletableFuture.postFire(CompletableFuture.java:561)
           at java.util.concurrent.CompletableFuture$UniCompose.tryFire(CompletableFuture.java:929)
           at java.util.concurrent.CompletableFuture$Completion.run(CompletableFuture.java:442)
           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:748)
   Caused by: org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
           at org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:144)
           at org.apache.flink.client.deployment.ClusterClientJobClientAdapter.lambda$null$6(ClusterClientJobClientAdapter.java:123)
           ... 24 more
   Caused by: org.apache.flink.runtime.JobException: Recovery is suppressed by NoRestartBackoffTimeStrategy
           at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:138)
           at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:82)
           at org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:216)
           at org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:206)
           at org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:197)
           at org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:682)
           at org.apache.flink.runtime.scheduler.SchedulerNG.updateTaskExecutionState(SchedulerNG.java:79)
           at org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:435)
           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.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:305)
           at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:212)
           at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:77)
           at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:158)
           at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:26)
           at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:21)
           at scala.PartialFunction$class.applyOrElse(PartialFunction.scala:123)
           at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:21)
           at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:170)
           at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
           at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171)
           at akka.actor.Actor$class.aroundReceive(Actor.scala:517)
           at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:225)
           at akka.actor.ActorCell.receiveMessage(ActorCell.scala:592)
           at akka.actor.ActorCell.invoke(ActorCell.scala:561)
           at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:258)
           at akka.dispatch.Mailbox.run(Mailbox.scala:225)
           at akka.dispatch.Mailbox.exec(Mailbox.scala:235)
           at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
           at akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
           at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
           at akka.dispatch.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
   Caused by: java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient
           at org.apache.hadoop.fs.ftp.FTPInputStream.<init>(FTPInputStream.java:44)
           at org.apache.seatunnel.connectors.seatunnel.file.ftp.system.SeaTunnelFTPFileSystem.open(SeaTunnelFTPFileSystem.java:206)
           at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:950)
           at org.apache.seatunnel.connectors.seatunnel.file.source.reader.TextReadStrategy.read(TextReadStrategy.java:57)
           at org.apache.seatunnel.connectors.seatunnel.file.source.BaseFileSourceReader.lambda$pollNext$0(BaseFileSourceReader.java:60)
           at java.lang.Iterable.forEach(Iterable.java:75)
           at org.apache.seatunnel.connectors.seatunnel.file.source.BaseFileSourceReader.pollNext(BaseFileSourceReader.java:58)
           at org.apache.seatunnel.translation.source.ParallelSource.run(ParallelSource.java:128)
           at org.apache.seatunnel.translation.flink.source.BaseSeaTunnelSourceFunction.run(BaseSeaTunnelSourceFunction.java:83)
           at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:110)
           at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:66)
           at org.apache.flink.streaming.runtime.tasks.SourceStreamTask$LegacySourceFunctionThread.run(SourceStreamTask.java:269)
   ```
   
   
   ### Flink or Spark Version
   
   flink
   
   ### Java or Scala Version
   
   jdk8
   
   ### Screenshots
   
   _No response_
   
   ### 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] [seatunnel] k8slight commented on issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   how to slove when using zeta engine?


-- 
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] closed issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] closed issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient
URL: https://github.com/apache/incubator-seatunnel/issues/3830


-- 
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] [seatunnel] zengqinchris commented on issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   > how to slove when using zeta engine?
   
   ![image](https://github.com/apache/seatunnel/assets/44901627/bf53dcb4-a3e4-4646-baf3-a402210bb8eb)
   


-- 
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] king-bu commented on issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   It feels like the jar package conflict is causing the project to load too many jar packages from the local library


-- 
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] king-bu commented on issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   This problem is solved. 
   Since you are running in flink local mode, add the following configuration to Flink-conf.yaml:
    classloader.resolve-order: parent-first, 
   restart the /bin/start-cluster.sh service on the local server, and then run the following command


-- 
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] king-bu commented on issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   I wonder if the problem has since been solved? How was it solved? Having the same problem? 


-- 
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] [seatunnel] k8slight commented on issue #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   > > how to slove when using zeta engine?
   > 
   > ![image](https://user-images.githubusercontent.com/44901627/240564513-bf53dcb4-a3e4-4646-baf3-a402210bb8eb.png)
   
   THX. I solved it by this.
   ![image](https://github.com/apache/seatunnel/assets/56961637/6b063681-05a6-487c-b2d0-758f06e16010)
   Because the dependencies of the remote repository are not updated
   


-- 
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 #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

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

   This issue has been closed because it has not received response for too long time. You could reopen it if you encountered similar problems in the future.


-- 
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 #3830: [Bug] [FTP] java.lang.LinkageError: org/apache/commons/net/ftp/FTPClient

Posted by github-actions.
github-actions[bot] commented on issue #3830:
URL: https://github.com/apache/incubator-seatunnel/issues/3830#issuecomment-1407521062

   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