You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@plc4x.apache.org by GitBox <gi...@apache.org> on 2018/09/17 07:07:38 UTC

[GitHub] asfgit closed pull request #20: Removed old files

asfgit closed pull request #20: Removed old files
URL: https://github.com/apache/incubator-plc4x/pull/20
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git a/integrations/apache-kafka/README.md b/integrations/apache-kafka/README.md
index 5b9e3be0d..6b646f295 100644
--- a/integrations/apache-kafka/README.md
+++ b/integrations/apache-kafka/README.md
@@ -16,37 +16,15 @@
   limitations under the License.
 
 -->
-Welcome to your new Kafka Connect connector!
 
-# Running in development
+# Kafka Connect PLC4X Connector
 
+The PLC4X Connector streams data from and to any device accessible through the PLC4X interface.
 
-The [docker-compose.yml](docker-compose.yml) that is included in this repository is based on the Confluent Platform Docker
-images. Take a look at the [quickstart](http://docs.confluent.io/3.0.1/cp-docker-images/docs/quickstart.html#getting-started-with-docker-client)
-for the Docker images. 
+## Source Connector
 
-The hostname `confluent` must be resolvable by your host. You will need to determine the ip address of your docker-machine using `docker-machine ip confluent` 
-and add this to your `/etc/hosts` file. For example if `docker-machine ip confluent` returns `192.168.99.100` add this:
+See `config/source.properties` for example configuration.
 
-```
-192.168.99.100  confluent
-```
+## Sink Connector
 
-
-```
-docker-compose up -d
-```
-
-
-Start the connector with debugging enabled.
- 
-```
-./bin/debug.sh
-```
-
-Start the connector with debugging enabled. This will wait for a debugger to attach.
-
-```
-export SUSPEND='y'
-./bin/debug.sh
-```
\ No newline at end of file
+See `config/sink.properties` for example configuration.
\ No newline at end of file
diff --git a/integrations/apache-kafka/bin/debug.sh b/integrations/apache-kafka/bin/debug.sh
deleted file mode 100644
index 7be498d5f..000000000
--- a/integrations/apache-kafka/bin/debug.sh
+++ /dev/null
@@ -1,29 +0,0 @@
-#!/usr/bin/env bash
-# ----------------------------------------------------------------------------
-# 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.
-# ----------------------------------------------------------------------------
-
-: ${SUSPEND:='n'}
-
-set -e
-
-mvn clean package
-export KAFKA_JMX_OPTS="-Xdebug -agentlib:jdwp=transport=dt_socket,server=y,suspend=${SUSPEND},address=5005"
-export CLASSPATH="$(find target/kafka-connect-target/usr/share/java -type f -name '*.jar' | tr '\n' ':')"
-
-connect-standalone config/connect-avro-docker.properties config/Plc4xSinkConnector.properties config/Plc4xSourceConnector.properties
diff --git a/integrations/apache-kafka/config/Plc4xSinkConnector.properties b/integrations/apache-kafka/config/Plc4xSinkConnector.properties
deleted file mode 100644
index 29ff1a82c..000000000
--- a/integrations/apache-kafka/config/Plc4xSinkConnector.properties
+++ /dev/null
@@ -1,23 +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.
-# ----------------------------------------------------------------------------
-
-name=Plc4xSinkConnector
-topics=plc4x-topic
-tasks.max=1
-connector.class=org.apache.plc4x.kafka.Plc4xSinkConnector
diff --git a/integrations/apache-kafka/config/Plc4xSourceConnector.properties b/integrations/apache-kafka/config/Plc4xSourceConnector.properties
deleted file mode 100644
index 3c5402987..000000000
--- a/integrations/apache-kafka/config/Plc4xSourceConnector.properties
+++ /dev/null
@@ -1,21 +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.
-# ----------------------------------------------------------------------------
-name=Plc4xSourceConnector
-tasks.max=1
-connector.class=org.apache.plc4x.kafka.Plc4xSourceConnector
\ No newline at end of file
diff --git a/integrations/apache-kafka/config/connect-avro-docker.properties b/integrations/apache-kafka/config/connect-avro-docker.properties
deleted file mode 100644
index 5f8a265a2..000000000
--- a/integrations/apache-kafka/config/connect-avro-docker.properties
+++ /dev/null
@@ -1,44 +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.
-# ----------------------------------------------------------------------------
-
-# Sample configuration for a standalone Kafka Connect worker that uses Avro serialization and
-# integrates the the SchemaConfig Registry. This sample configuration assumes a local installation of
-# Confluent Platform with all services running on their default ports.
-# Bootstrap Kafka servers. If multiple servers are specified, they should be comma-separated.
-bootstrap.servers=confluent:9092
-# The converters specify the format of data in Kafka and how to translate it into Connect data.
-# Every Connect user will need to configure these based on the format they want their data in
-# when loaded from or stored into Kafka
-key.converter=io.confluent.connect.avro.AvroConverter
-key.converter.schema.registry.url=http://confluent:8081
-value.converter=io.confluent.connect.avro.AvroConverter
-value.converter.schema.registry.url=http://confluent:8081
-# The internal converter used for offsets and config data is configurable and must be specified,
-# but most users will always want to use the built-in default. Offset and config data is never
-# visible outside of Connect in this format.
-internal.key.converter=org.apache.kafka.connect.json.JsonConverter
-internal.value.converter=org.apache.kafka.connect.json.JsonConverter
-internal.key.converter.schemas.enable=false
-internal.value.converter.schemas.enable=false
-# Local storage file for offset data
-offset.storage.file.filename=/tmp/connect.offsets
-# Confuent Control Center Integration -- uncomment these lines to enable Kafka client interceptors
-# that will report audit data that can be displayed and analyzed in Confluent Control Center
-# producer.interceptor.classes=io.confluent.monitoring.clients.interceptor.MonitoringProducerInterceptor
-# consumer.interceptor.classes=io.confluent.monitoring.clients.interceptor.MonitoringConsumerInterceptor
diff --git a/integrations/apache-kafka/config/sink.properties b/integrations/apache-kafka/config/sink.properties
new file mode 100644
index 000000000..ae9ccba6c
--- /dev/null
+++ b/integrations/apache-kafka/config/sink.properties
@@ -0,0 +1,25 @@
+<!--
+
+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.
+
+-->
+name=plc-sink-test
+connector.class=org.apache.plc4x.kafka.Plc4xSinkConnector
+topics=test
+url=test:unused
+transforms=key
+transforms.key.type=org.apache.kafka.connect.transforms.ExtractField$Key
+transforms.key.field=query
\ No newline at end of file
diff --git a/integrations/apache-kafka/config/source.properties b/integrations/apache-kafka/config/source.properties
new file mode 100644
index 000000000..cbd00f576
--- /dev/null
+++ b/integrations/apache-kafka/config/source.properties
@@ -0,0 +1,24 @@
+<!--
+
+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.
+
+-->
+name=plc-source-test
+connector.class=org.apache.plc4x.kafka.Plc4xSourceConnector
+topic=test
+url=test:unused
+queries=RANDOM/foo:INTEGER,RANDOM/bar:STRING
+rate=2000
\ No newline at end of file
diff --git a/integrations/apache-kafka/docker-compose.yml b/integrations/apache-kafka/docker-compose.yml
deleted file mode 100644
index 215c28aff..000000000
--- a/integrations/apache-kafka/docker-compose.yml
+++ /dev/null
@@ -1,45 +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.
-# ----------------------------------------------------------------------------
-version: "2"
-services:
-  zookeeper:
-    image: confluentinc/cp-zookeeper:3.2.2-1
-    environment:
-      ZOOKEEPER_CLIENT_PORT: 2181
-      zk_id: "1"
-  kafka:
-    hostname: kafka
-    image: confluentinc/cp-kafka:3.2.2-1
-    links:
-    - zookeeper
-    ports:
-    - "9092:9092"
-    environment:
-      KAFKA_ZOOKEEPER_CONNECT: "zookeeper:2181"
-      KAFKA_ADVERTISED_LISTENERS: "PLAINTEXT://:9092"
-  schema-registry:
-    image: confluentinc/cp-schema-registry:3.2.2-1
-    links:
-    - kafka
-    - zookeeper
-    ports:
-    - "8081:8081"
-    environment:
-      SCHEMA_REGISTRY_KAFKASTORE_CONNECTION_URL: "zookeeper:2181"
-      SCHEMA_REGISTRY_HOST_NAME: schema-registry
\ No newline at end of file
diff --git a/integrations/apache-kafka/pom.xml b/integrations/apache-kafka/pom.xml
index e09c85be2..a4269fffb 100644
--- a/integrations/apache-kafka/pom.xml
+++ b/integrations/apache-kafka/pom.xml
@@ -28,8 +28,8 @@
   </parent>
 
   <artifactId>apache-kafka</artifactId>
-  <name>Integrations: Apache Kafka</name>
-  <description>Integration module for integrating PLC4X into Apache Kafka (Kafka-Connect-Plugin).</description>
+  <name>Integrations: Apache Kafka.</name>
+  <description>Integration module for integrating PLC4X into Apache Kafka (Kafka-Connect-Plugin)</description>
 
   <properties>
     <kafka.version>2.0.0</kafka.version>
@@ -39,65 +39,18 @@
     <dependency>
       <groupId>org.apache.plc4x</groupId>
       <artifactId>plc4j-api</artifactId>
-      <version>0.0.1-SNAPSHOT</version>
+      <version>${project.version}</version>
     </dependency>
     <dependency>
       <groupId>org.apache.plc4x</groupId>
       <artifactId>plc4j-core</artifactId>
-      <version>0.0.1-SNAPSHOT</version>
+      <version>${project.version}</version>
     </dependency>
-
     <dependency>
       <groupId>org.apache.kafka</groupId>
       <artifactId>connect-api</artifactId>
       <version>${kafka.version}</version>
       <scope>provided</scope>
     </dependency>
-    <dependency>
-      <groupId>org.apache.kafka</groupId>
-      <artifactId>kafka-clients</artifactId>
-      <version>${kafka.version}</version>
-      <scope>provided</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>org.mockito</groupId>
-      <artifactId>mockito-core</artifactId>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>ch.qos.logback</groupId>
-      <artifactId>logback-classic</artifactId>
-      <scope>test</scope>
-    </dependency>
   </dependencies>
-
-  <build>
-    <plugins>
-      <plugin>
-        <artifactId>maven-assembly-plugin</artifactId>
-        <version>2.5.3</version>
-        <configuration>
-          <descriptors>
-            <descriptor>src/main/assembly/package.xml</descriptor>
-          </descriptors>
-        </configuration>
-        <executions>
-          <execution>
-            <id>make-assembly</id>
-            <phase>package</phase>
-            <goals>
-              <goal>single</goal>
-            </goals>
-          </execution>
-        </executions>
-      </plugin>
-    </plugins>
-  </build>
-
 </project>
\ No newline at end of file
diff --git a/integrations/apache-kafka/src/main/assembly/package.xml b/integrations/apache-kafka/src/main/assembly/package.xml
deleted file mode 100644
index 48dea3168..000000000
--- a/integrations/apache-kafka/src/main/assembly/package.xml
+++ /dev/null
@@ -1,59 +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.
-
--->
-<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
-          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-          xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2
-          http://maven.apache.org/xsd/assembly-1.1.2.xsd">
-  <!-- Assembles a packaged version targeting OS installation. -->
-  <id>package</id>
-  <formats>
-    <format>dir</format>
-  </formats>
-  <includeBaseDirectory>false</includeBaseDirectory>
-  <fileSets>
-    <fileSet>
-      <directory>${project.basedir}</directory>
-      <outputDirectory>share/doc/${project.name}/</outputDirectory>
-      <includes>
-        <include>README*</include>
-        <include>LICENSE*</include>
-        <include>NOTICE*</include>
-        <include>licenses/</include>
-      </includes>
-    </fileSet>
-    <fileSet>
-      <directory>${project.basedir}/config</directory>
-      <outputDirectory>etc/${project.name}</outputDirectory>
-      <includes>
-        <include>*</include>
-      </includes>
-    </fileSet>
-  </fileSets>
-  <dependencySets>
-    <dependencySet>
-      <outputDirectory>share/java/${project.name}</outputDirectory>
-      <useProjectArtifact>true</useProjectArtifact>
-      <useTransitiveFiltering>true</useTransitiveFiltering>
-      <excludes>
-        <exclude>org.apache.kafka:connect-api</exclude>
-      </excludes>
-    </dependencySet>
-  </dependencySets>
-</assembly>
diff --git a/integrations/apache-kafka/src/main/java/org/apache/plc4x/kafka/Plc4xSourceTask.java b/integrations/apache-kafka/src/main/java/org/apache/plc4x/kafka/Plc4xSourceTask.java
index 7d0ed8621..7c048c5e0 100644
--- a/integrations/apache-kafka/src/main/java/org/apache/plc4x/kafka/Plc4xSourceTask.java
+++ b/integrations/apache-kafka/src/main/java/org/apache/plc4x/kafka/Plc4xSourceTask.java
@@ -64,11 +64,8 @@ Licensed to the Apache Software Foundation (ASF) under one
     private PlcReader plcReader;
     private PlcReadRequest plcRequest;
 
-
-
     // TODO: should we use shared (static) thread pool for this?
     private ScheduledExecutorService scheduler;
-    private ScheduledFuture<?> timer;
     private boolean fetch = true;
 
     @Override
@@ -97,14 +94,14 @@ public void start(Map<String, String> props) {
 
         int rate = Integer.valueOf(props.get(Plc4xSourceConnector.RATE_CONFIG));
         scheduler = Executors.newScheduledThreadPool(1);
-        timer = scheduler.scheduleAtFixedRate(Plc4xSourceTask.this::scheduleFetch, rate, rate, TimeUnit.MILLISECONDS);
+        scheduler.scheduleAtFixedRate(Plc4xSourceTask.this::scheduleFetch, rate, rate, TimeUnit.MILLISECONDS);
     }
 
     @Override
     public void stop() {
-        timer.cancel(true);
         scheduler.shutdown();
         closeConnection();
+        notify(); // wake up thread waiting in awaitFetch
     }
 
     @Override
diff --git a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkConnectorTest.java b/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkConnectorTest.java
deleted file mode 100644
index 2777ed5ae..000000000
--- a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkConnectorTest.java
+++ /dev/null
@@ -1,30 +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.plc4x.kafka;
-
-import org.junit.Test;
-
-public class Plc4xSinkConnectorTest {
-
-    @Test
-    public void test() {
-        // Congrats on a passing test!
-    }
-
-}
\ No newline at end of file
diff --git a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkTaskTest.java b/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkTaskTest.java
deleted file mode 100644
index 9006e856b..000000000
--- a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkTaskTest.java
+++ /dev/null
@@ -1,30 +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.plc4x.kafka;
-
-import org.junit.Test;
-
-public class Plc4xSinkTaskTest {
-
-    @Test
-    public void test() {
-        // Congrats on a passing test!
-    }
-
-}
diff --git a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceConnectorTest.java b/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceConnectorTest.java
deleted file mode 100644
index 27d158d6f..000000000
--- a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceConnectorTest.java
+++ /dev/null
@@ -1,30 +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.plc4x.kafka;
-
-import org.junit.Test;
-
-public class Plc4xSourceConnectorTest {
-
-    @Test
-    public void test() {
-        // Congrats on a passing test!
-    }
-
-}
diff --git a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceTaskTest.java b/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceTaskTest.java
deleted file mode 100644
index 3b5942b3b..000000000
--- a/integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceTaskTest.java
+++ /dev/null
@@ -1,30 +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.plc4x.kafka;
-
-import org.junit.Test;
-
-public class Plc4xSourceTaskTest {
-
-    @Test
-    public void test() {
-        // Congrats on a passing test!
-    }
-
-}
\ No newline at end of file
diff --git a/integrations/apache-kafka/src/test/resources/logback.xml b/integrations/apache-kafka/src/test/resources/logback.xml
deleted file mode 100644
index c2bb52233..000000000
--- a/integrations/apache-kafka/src/test/resources/logback.xml
+++ /dev/null
@@ -1,29 +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.
-
--->
-<configuration>
-  <appender name="STDOUT" class="ch.qos.logback.core.ConsoleAppender">
-    <encoder class="ch.qos.logback.classic.encoder.PatternLayoutEncoder">
-      <pattern>%d{HH:mm:ss.SSS} [%thread] %-5level %logger - %msg%n</pattern>
-    </encoder>
-  </appender>
-  <root level="debug">
-    <appender-ref ref="STDOUT"/>
-  </root>
-</configuration>
\ No newline at end of file


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services