You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@seatunnel.apache.org by ki...@apache.org on 2022/10/29 02:58:48 UTC

[incubator-seatunnel] branch dev updated: [hotfix][e2e][influxdb] Fix testcase and move to seatunnel-connector-v2-e2e (#3186)

This is an automated email from the ASF dual-hosted git repository.

kirs pushed a commit to branch dev
in repository https://gitbox.apache.org/repos/asf/incubator-seatunnel.git


The following commit(s) were added to refs/heads/dev by this push:
     new f8b474135 [hotfix][e2e][influxdb] Fix testcase and move to seatunnel-connector-v2-e2e (#3186)
f8b474135 is described below

commit f8b474135ff22bea3cd21689088bf164547ee5f4
Author: hailin0 <wa...@apache.org>
AuthorDate: Sat Oct 29 10:58:41 2022 +0800

    [hotfix][e2e][influxdb] Fix testcase and move to seatunnel-connector-v2-e2e (#3186)
---
 .../connector-influxdb-e2e}/pom.xml                |  17 +-
 .../influxdb/InfluxDBSourceToAssertIT.java         |  63 +++----
 .../test/resources}/influxdb_source_to_assert.conf |  26 ++-
 seatunnel-e2e/seatunnel-connector-v2-e2e/pom.xml   |   1 +
 .../v2/influxdb/InfluxDBSourceToAssertIT.java      | 115 -------------
 .../src/test/resources/log4j.properties            |  22 ---
 .../seatunnel-flink-connector-v2-e2e/pom.xml       |   1 -
 .../connector-influxdb-spark-e2e/pom.xml           |  50 ------
 .../influxdb/influxdb_source_to_assert.conf        | 182 ---------------------
 .../src/test/resources/log4j.properties            |  22 ---
 .../seatunnel-spark-connector-v2-e2e/pom.xml       |   1 -
 11 files changed, 64 insertions(+), 436 deletions(-)

diff --git a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/pom.xml b/seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/pom.xml
similarity index 78%
rename from seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/pom.xml
rename to seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/pom.xml
index 83353aa6c..a3b93102e 100644
--- a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/pom.xml
+++ b/seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/pom.xml
@@ -13,31 +13,30 @@
     See the License for the specific language governing permissions and
     limitations under the License.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0"
+         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <groupId>org.apache.seatunnel</groupId>
-        <artifactId>seatunnel-flink-connector-v2-e2e</artifactId>
+        <artifactId>seatunnel-connector-v2-e2e</artifactId>
         <version>${revision}</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
-    <artifactId>connector-influxdb-flink-e2e</artifactId>
+    <artifactId>connector-influxdb-e2e</artifactId>
 
     <dependencies>
         <dependency>
             <groupId>org.apache.seatunnel</groupId>
-            <artifactId>connector-flink-e2e-base</artifactId>
+            <artifactId>connector-influxdb</artifactId>
             <version>${project.version}</version>
-            <classifier>tests</classifier>
-            <type>test-jar</type>
             <scope>test</scope>
         </dependency>
         <dependency>
             <groupId>org.apache.seatunnel</groupId>
-            <artifactId>connector-influxdb</artifactId>
+            <artifactId>connector-assert</artifactId>
             <version>${project.version}</version>
             <scope>test</scope>
         </dependency>
     </dependencies>
-</project>
+</project>
\ No newline at end of file
diff --git a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/java/org/apache/seatunnel/e2e/spark/v2/influxdb/InfluxDBSourceToAssertIT.java b/seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/src/test/java/org/apache/seatunnel/e2e/connector/influxdb/InfluxDBSourceToAssertIT.java
similarity index 66%
rename from seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/java/org/apache/seatunnel/e2e/spark/v2/influxdb/InfluxDBSourceToAssertIT.java
rename to seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/src/test/java/org/apache/seatunnel/e2e/connector/influxdb/InfluxDBSourceToAssertIT.java
index 6283f3e82..d39aa4f39 100644
--- a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/java/org/apache/seatunnel/e2e/spark/v2/influxdb/InfluxDBSourceToAssertIT.java
+++ b/seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/src/test/java/org/apache/seatunnel/e2e/connector/influxdb/InfluxDBSourceToAssertIT.java
@@ -15,72 +15,75 @@
  * limitations under the License.
  */
 
-package org.apache.seatunnel.e2e.spark.v2.influxdb;
+package org.apache.seatunnel.e2e.connector.influxdb;
+
+import static org.awaitility.Awaitility.given;
 
 import org.apache.seatunnel.connectors.seatunnel.influxdb.client.InfluxDBClient;
 import org.apache.seatunnel.connectors.seatunnel.influxdb.config.InfluxDBConfig;
-import org.apache.seatunnel.e2e.spark.SparkContainer;
+import org.apache.seatunnel.e2e.common.TestResource;
+import org.apache.seatunnel.e2e.common.TestSuiteBase;
+import org.apache.seatunnel.e2e.common.container.TestContainer;
 
-import com.google.common.collect.Lists;
 import lombok.extern.slf4j.Slf4j;
 import org.influxdb.InfluxDB;
 import org.influxdb.dto.BatchPoints;
 import org.influxdb.dto.Point;
-import org.junit.jupiter.api.AfterEach;
+import org.junit.jupiter.api.AfterAll;
 import org.junit.jupiter.api.Assertions;
-import org.junit.jupiter.api.BeforeEach;
-import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.BeforeAll;
+import org.junit.jupiter.api.TestTemplate;
 import org.testcontainers.containers.Container;
 import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.output.Slf4jLogConsumer;
 import org.testcontainers.lifecycle.Startables;
+import org.testcontainers.utility.DockerLoggerFactory;
 
 import java.io.IOException;
 import java.net.ConnectException;
-import java.sql.SQLException;
 import java.util.Date;
 import java.util.concurrent.TimeUnit;
 import java.util.stream.Stream;
 
 @Slf4j
-public class InfluxDBSourceToAssertIT extends SparkContainer {
+public class InfluxDBSourceToAssertIT extends TestSuiteBase implements TestResource {
 
     private static final String INFLUXDB_DOCKER_IMAGE = "influxdb:1.8";
     private static final String INFLUXDB_CONTAINER_HOST = "influxdb-host";
-    private static final String INFLUXDB_HOST = "localhost";
-
-    private static final int INFLUXDB_PORT = 8764;
     private static final int INFLUXDB_CONTAINER_PORT = 8086;
-    private static final String INFLUXDB_CONNECT_URL = String.format("http://%s:%s", INFLUXDB_HOST, INFLUXDB_PORT);
     private static final String INFLUXDB_DATABASE = "test";
     private static final String INFLUXDB_MEASUREMENT = "test";
 
     private GenericContainer<?> influxDBServer;
-
     private  InfluxDB influxDB;
 
-    @BeforeEach
-    public void startInfluxDBContainer() throws ClassNotFoundException, SQLException, ConnectException {
+    @BeforeAll
+    @Override
+    public void startUp() {
         influxDBServer = new GenericContainer<>(INFLUXDB_DOCKER_IMAGE)
-                .withNetwork(NETWORK)
-                .withNetworkAliases(INFLUXDB_CONTAINER_HOST)
-                .withLogConsumer(new Slf4jLogConsumer(log));
-        influxDBServer.setPortBindings(Lists.newArrayList(
-                String.format("%s:%s", INFLUXDB_PORT, INFLUXDB_CONTAINER_PORT)));
+            .withNetwork(NETWORK)
+            .withNetworkAliases(INFLUXDB_CONTAINER_HOST)
+            .withExposedPorts(INFLUXDB_CONTAINER_PORT)
+            .withLogConsumer(new Slf4jLogConsumer(DockerLoggerFactory.getLogger(INFLUXDB_DOCKER_IMAGE)));
         Startables.deepStart(Stream.of(influxDBServer)).join();
         log.info("influxdb container started");
-        initializeInfluxDBClient();
+        given().ignoreExceptions()
+            .await()
+            .atLeast(100, TimeUnit.MILLISECONDS)
+            .pollInterval(500, TimeUnit.MILLISECONDS)
+            .atMost(30, TimeUnit.SECONDS)
+            .untilAsserted(() -> initializeInfluxDBClient());
         batchInsertData();
     }
 
-    @Test
-    public void testInfluxDBSource() throws IOException, InterruptedException, SQLException {
-        Container.ExecResult execResult = executeSeaTunnelSparkJob("/influxdb/influxdb_source_to_assert.conf");
+    @TestTemplate
+    public void testInfluxDBSource(TestContainer container) throws IOException, InterruptedException {
+        Container.ExecResult execResult = container.executeJob("/influxdb_source_to_assert.conf");
         Assertions.assertEquals(0, execResult.getExitCode());
     }
 
-    private void initializeInfluxDBClient() throws SQLException, ClassNotFoundException, ConnectException {
-        InfluxDBConfig influxDBConfig = new InfluxDBConfig(INFLUXDB_CONNECT_URL);
+    private void initializeInfluxDBClient() throws ConnectException {
+        InfluxDBConfig influxDBConfig = new InfluxDBConfig(String.format("http://%s:%s", influxDBServer.getHost(), influxDBServer.getFirstMappedPort()));
         influxDB = InfluxDBClient.getInfluxDB(influxDBConfig);
     }
 
@@ -106,8 +109,12 @@ public class InfluxDBSourceToAssertIT extends SparkContainer {
         influxDB.write(batchPoints);
     }
 
-    @AfterEach
-    public void closeInfluxDBContainer() {
+    @AfterAll
+    @Override
+    public void tearDown() {
+        if (influxDB != null) {
+            influxDB.close();
+        }
         if (influxDBServer != null) {
             influxDBServer.stop();
         }
diff --git a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/resources/influxdb/influxdb_source_to_assert.conf b/seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/src/test/resources/influxdb_source_to_assert.conf
similarity index 91%
rename from seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/resources/influxdb/influxdb_source_to_assert.conf
rename to seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/src/test/resources/influxdb_source_to_assert.conf
index eb2a1e6c5..2a2f1192c 100644
--- a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/resources/influxdb/influxdb_source_to_assert.conf
+++ b/seatunnel-e2e/seatunnel-connector-v2-e2e/connector-influxdb-e2e/src/test/resources/influxdb_source_to_assert.conf
@@ -19,11 +19,15 @@
 ######
 
 env {
-  # You can set flink configuration here
   execution.parallelism = 1
   job.mode = "BATCH"
-  #execution.checkpoint.interval = 10000
-  #execution.checkpoint.data-uri = "hdfs://localhost:9000/checkpoint"
+
+  # You can set spark configuration here
+  spark.app.name = "SeaTunnel"
+  spark.executor.instances = 2
+  spark.executor.cores = 1
+  spark.executor.memory = "1g"
+  spark.master = local
 }
 
 source {
@@ -32,8 +36,8 @@ source {
         url = "http://influxdb-host:8086"
         sql = "select label, f1, f2, f3, f4, f5, f6, f7 from test"
         database = "test"
-        upper_bound = 100
-        lower_bound = 1
+        upper_bound = 99
+        lower_bound = 0
         partition_num = 4
         split_column = "f5"
         fields {
@@ -59,6 +63,16 @@ sink {
      Assert {
          rules =
           {
+            row_rules = [
+              {
+                rule_type = MAX_ROW
+                rule_value = 100
+              },
+              {
+                rule_type = MIN_ROW
+                rule_value = 100
+              }
+            ],
            field_rules =  [{
                  field_name = f1
                  field_type = string
@@ -132,7 +146,7 @@ sink {
                       },
                       {
                            rule_type = MIN
-                           rule_value = 1
+                           rule_value = 0
                        },
                        {
                             rule_type = MAX
diff --git a/seatunnel-e2e/seatunnel-connector-v2-e2e/pom.xml b/seatunnel-e2e/seatunnel-connector-v2-e2e/pom.xml
index 1fbf57b90..d5404c565 100644
--- a/seatunnel-e2e/seatunnel-connector-v2-e2e/pom.xml
+++ b/seatunnel-e2e/seatunnel-connector-v2-e2e/pom.xml
@@ -28,6 +28,7 @@
         <module>connector-jdbc-e2e</module>
         <module>connector-redis-e2e</module>
         <module>connector-clickhouse-e2e</module>
+        <module>connector-influxdb-e2e</module>
     </modules>
 
     <artifactId>seatunnel-connector-v2-e2e</artifactId>
diff --git a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/java/org/apache/seatunnel/e2e/flink/v2/influxdb/InfluxDBSourceToAssertIT.java b/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/java/org/apache/seatunnel/e2e/flink/v2/influxdb/InfluxDBSourceToAssertIT.java
deleted file mode 100644
index 336d1743d..000000000
--- a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/java/org/apache/seatunnel/e2e/flink/v2/influxdb/InfluxDBSourceToAssertIT.java
+++ /dev/null
@@ -1,115 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *    http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.seatunnel.e2e.flink.v2.influxdb;
-
-import org.apache.seatunnel.connectors.seatunnel.influxdb.client.InfluxDBClient;
-import org.apache.seatunnel.connectors.seatunnel.influxdb.config.InfluxDBConfig;
-import org.apache.seatunnel.e2e.flink.FlinkContainer;
-
-import com.google.common.collect.Lists;
-import lombok.extern.slf4j.Slf4j;
-import org.influxdb.InfluxDB;
-import org.influxdb.dto.BatchPoints;
-import org.influxdb.dto.Point;
-import org.junit.jupiter.api.AfterEach;
-import org.junit.jupiter.api.Assertions;
-import org.junit.jupiter.api.BeforeEach;
-import org.junit.jupiter.api.Test;
-import org.testcontainers.containers.Container;
-import org.testcontainers.containers.GenericContainer;
-import org.testcontainers.containers.output.Slf4jLogConsumer;
-import org.testcontainers.lifecycle.Startables;
-
-import java.io.IOException;
-import java.net.ConnectException;
-import java.sql.SQLException;
-import java.util.Date;
-import java.util.concurrent.TimeUnit;
-import java.util.stream.Stream;
-
-@Slf4j
-public class InfluxDBSourceToAssertIT extends FlinkContainer {
-
-    private static final String INFLUXDB_DOCKER_IMAGE = "influxdb:1.8";
-    private static final String INFLUXDB_CONTAINER_HOST = "influxdb-host";
-    private static final String INFLUXDB_HOST = "localhost";
-
-    private static final int INFLUXDB_PORT = 8764;
-    private static final int INFLUXDB_CONTAINER_PORT = 8086;
-    private static final String INFLUXDB_CONNECT_URL = String.format("http://%s:%s", INFLUXDB_HOST, INFLUXDB_PORT);
-    private static final String INFLUXDB_DATABASE = "test";
-    private static final String INFLUXDB_MEASUREMENT = "test";
-
-    private GenericContainer<?> influxDBServer;
-
-    private  InfluxDB influxDB;
-
-    @BeforeEach
-    public void startInfluxDBContainer() throws ClassNotFoundException, SQLException, ConnectException {
-        influxDBServer = new GenericContainer<>(INFLUXDB_DOCKER_IMAGE)
-                .withNetwork(NETWORK)
-                .withNetworkAliases(INFLUXDB_CONTAINER_HOST)
-                .withLogConsumer(new Slf4jLogConsumer(log));
-        influxDBServer.setPortBindings(Lists.newArrayList(
-                String.format("%s:%s", INFLUXDB_PORT, INFLUXDB_CONTAINER_PORT)));
-        Startables.deepStart(Stream.of(influxDBServer)).join();
-        log.info("influxdb container started");
-        initializeInfluxDBClient();
-        batchInsertData();
-    }
-
-    @Test
-    public void testInfluxDBSource() throws IOException, InterruptedException, SQLException {
-        Container.ExecResult execResult = executeSeaTunnelFlinkJob("/influxdb/influxdb_source_to_assert.conf");
-        Assertions.assertEquals(0, execResult.getExitCode());
-    }
-
-    private void initializeInfluxDBClient() throws SQLException, ClassNotFoundException, ConnectException {
-        InfluxDBConfig influxDBConfig = new InfluxDBConfig(INFLUXDB_CONNECT_URL);
-        influxDB = InfluxDBClient.getInfluxDB(influxDBConfig);
-    }
-
-    public void batchInsertData() {
-        influxDB.createDatabase(INFLUXDB_DATABASE);
-        BatchPoints batchPoints = BatchPoints
-                .database(INFLUXDB_DATABASE)
-                .build();
-        for (int i = 0; i < 100; i++) {
-            Point point = Point.measurement(INFLUXDB_MEASUREMENT)
-                    .time(new Date().getTime(), TimeUnit.NANOSECONDS)
-                    .tag("label", String.format("label_%s", i))
-                    .addField("f1", String.format("f1_%s", i))
-                    .addField("f2", Double.valueOf(i + 1))
-                    .addField("f3", Long.valueOf(i + 2))
-                    .addField("f4", Float.valueOf(i + 3))
-                    .addField("f5", Integer.valueOf(i))
-                    .addField("f6", (short) (i + 4))
-                    .addField("f7", i % 2 == 0 ? Boolean.TRUE : Boolean.FALSE)
-                    .build();
-            batchPoints.point(point);
-        }
-        influxDB.write(batchPoints);
-    }
-
-    @AfterEach
-    public void closeInfluxDBContainer() {
-        if (influxDBServer != null) {
-            influxDBServer.stop();
-        }
-    }
-}
diff --git a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/resources/log4j.properties b/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/resources/log4j.properties
deleted file mode 100644
index db5d9e512..000000000
--- a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/connector-influxdb-flink-e2e/src/test/resources/log4j.properties
+++ /dev/null
@@ -1,22 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#    http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-#
-# Set everything to be logged to the console
-log4j.rootCategory=INFO, console
-log4j.appender.console=org.apache.log4j.ConsoleAppender
-log4j.appender.console.target=System.err
-log4j.appender.console.layout=org.apache.log4j.PatternLayout
-log4j.appender.console.layout.ConversionPattern=%d{yy/MM/dd HH:mm:ss} %p %c{1}: %m%n
diff --git a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/pom.xml b/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/pom.xml
index 7f84dfc1e..5e68dad2c 100644
--- a/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/pom.xml
+++ b/seatunnel-e2e/seatunnel-flink-connector-v2-e2e/pom.xml
@@ -37,7 +37,6 @@
         <module>connector-mongodb-flink-e2e</module>
         <module>connector-iceberg-flink-e2e</module>
         <module>connector-neo4j-flink-e2e</module>
-        <module>connector-influxdb-flink-e2e</module>
         <module>connector-kafka-flink-e2e</module>
     </modules>
 
diff --git a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/pom.xml b/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/pom.xml
deleted file mode 100644
index 11fd1b931..000000000
--- a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/pom.xml
+++ /dev/null
@@ -1,50 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-       http://www.apache.org/licenses/LICENSE-2.0
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-    <parent>
-        <groupId>org.apache.seatunnel</groupId>
-        <artifactId>seatunnel-spark-connector-v2-e2e</artifactId>
-        <version>${revision}</version>
-    </parent>
-    <modelVersion>4.0.0</modelVersion>
-
-    <artifactId>connector-influxdb-spark-e2e</artifactId>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.seatunnel</groupId>
-            <artifactId>connector-spark-e2e-base</artifactId>
-            <version>${project.version}</version>
-            <classifier>tests</classifier>
-            <type>test-jar</type>
-            <scope>test</scope>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.seatunnel</groupId>
-            <artifactId>connector-influxdb</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.seatunnel</groupId>
-            <artifactId>connector-assert</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency>
-    </dependencies>
-</project>
diff --git a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/resources/influxdb/influxdb_source_to_assert.conf b/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/resources/influxdb/influxdb_source_to_assert.conf
deleted file mode 100644
index f8901980d..000000000
--- a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/resources/influxdb/influxdb_source_to_assert.conf
+++ /dev/null
@@ -1,182 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#    http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-#
-######
-###### This config file is a demonstration of streaming processing in seatunnel config
-######
-
-env {
-    # You can set spark configuration here
-    spark.app.name = "SeaTunnel"
-    spark.executor.instances = 2
-    spark.executor.cores = 1
-    spark.executor.memory = "1g"
-    spark.master = local
-    job.mode = "BATCH"
-}
-
-source {
-  # This is a example source plugin **only for test and demonstrate the feature source plugin**
-    InfluxDB {
-        url = "http://influxdb-host:8086"
-        sql = "select label, f1, f2, f3, f4, f5, f6, f7 from test"
-        database = "test"
-        upper_bound = 100
-        lower_bound = 1
-        partition_num = 4
-        split_column = "f5"
-        fields {
-            label = STRING
-            f1 = STRING
-            f2 = DOUBLE
-            f3 = BIGINT
-            f4 = FLOAT
-            f5 = INT
-            f6 = SMALLINT
-            f7 = BOOLEAN
-            }
-    }
-}
-
-transform {
-
-  # If you would like to get more information about how to configure seatunnel and see full list of transform plugins,
-  # please go to https://seatunnel.apache.org/docs/transform/sql
-}
-
-sink {
-     Assert {
-         rules =
-          {
-           field_rules =  [{
-                 field_name = f1
-                 field_type = string
-                 field_value = [
-                     {
-                         rule_type = NOT_NULL
-                     },
-                     {
-                         rule_type = MIN_LENGTH
-                         rule_value = 4
-                     },
-                     {
-                          rule_type = MAX_LENGTH
-                          rule_value = 5
-                     }
-                 ]
-             },{
-                 field_name = f2
-                 field_type = double
-                 field_value = [
-                     {
-                         rule_type = NOT_NULL
-                     },
-                     {
-                         rule_type = MIN
-                         rule_value = 1
-                     },
-                     {
-                          rule_type = MAX
-                          rule_value = 100
-                     }
-                 ]
-             },{
-                 field_name = f3
-                 field_type = long
-                 field_value = [
-                      {
-                           rule_type = NOT_NULL
-                      },
-                      {
-                           rule_type = MIN
-                           rule_value = 2
-                       },
-                       {
-                            rule_type = MAX
-                            rule_value = 101
-                       }
-                 ]
-             },{
-                 field_name = f4
-                 field_type = float
-                 field_value = [
-                      {
-                           rule_type = NOT_NULL
-                      },
-                      {
-                           rule_type = MIN
-                           rule_value = 3
-                       },
-                       {
-                            rule_type = MAX
-                            rule_value = 102
-                       }
-                 ]
-             },{
-                 field_name = f5
-                 field_type = int
-                 field_value = [
-                      {
-                           rule_type = NOT_NULL
-                      },
-                      {
-                           rule_type = MIN
-                           rule_value = 1
-                       },
-                       {
-                            rule_type = MAX
-                            rule_value = 99
-                       }
-                 ]
-             },{
-                 field_name = f6
-                 field_type = short
-                 field_value = [
-                      {
-                           rule_type = NOT_NULL
-                      },
-                      {
-                           rule_type = MIN
-                           rule_value = 4
-                       },
-                       {
-                            rule_type = MAX
-                            rule_value = 103
-                       }
-                 ]
-             },{
-                 field_name = f7
-                 field_type = boolean
-                 field_value = [
-                      {
-                           rule_type = NOT_NULL
-                      },
-                      {
-                           rule_type = MIN
-                           rule_value = 0
-                       },
-                       {
-                            rule_type = MAX
-                            rule_value = 1
-                       }
-                 ]
-             }
-             ]
-        }
-     }
-  # If you would like to get more information about how to configure seatunnel and see full list of sink plugins,
-  # please go to https://seatunnel.apache.org/docs/category/sink-v2
-}
\ No newline at end of file
diff --git a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/resources/log4j.properties b/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/resources/log4j.properties
deleted file mode 100644
index db5d9e512..000000000
--- a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/connector-influxdb-spark-e2e/src/test/resources/log4j.properties
+++ /dev/null
@@ -1,22 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#    http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-#
-# Set everything to be logged to the console
-log4j.rootCategory=INFO, console
-log4j.appender.console=org.apache.log4j.ConsoleAppender
-log4j.appender.console.target=System.err
-log4j.appender.console.layout=org.apache.log4j.PatternLayout
-log4j.appender.console.layout.ConversionPattern=%d{yy/MM/dd HH:mm:ss} %p %c{1}: %m%n
diff --git a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/pom.xml b/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/pom.xml
index 1dbb2853d..59848c27c 100644
--- a/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/pom.xml
+++ b/seatunnel-e2e/seatunnel-spark-connector-v2-e2e/pom.xml
@@ -36,7 +36,6 @@
         <module>connector-mongodb-spark-e2e</module>
         <module>connector-neo4j-spark-e2e</module>
         <module>connector-kafka-spark-e2e</module>
-        <module>connector-influxdb-spark-e2e</module>
         <module>connector-iceberg-spark-e2e</module>
     </modules>