You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@plc4x.apache.org by cd...@apache.org on 2018/09/17 15:47:04 UTC

[incubator-plc4x] branch master updated (e22e344 -> 86fb5db)

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

cdutz pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-plc4x.git.


    from e22e344  [maven-release-plugin] rollback the release of plc4x-parent-0.1.0
     new af14dd9  removed old files
     new 98976eb  Merge branch 'feature/api-redesign-chris-c' of https://github.com/skorikov/incubator-plc4x into skorikov-feature/api-redesign-chris-c
     new 86fb5db  Merge branch 'skorikov-feature/api-redesign-chris-c'

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 integrations/apache-kafka/README.md                | 34 +++----------
 integrations/apache-kafka/bin/debug.sh             | 29 -----------
 .../config/Plc4xSinkConnector.properties           | 23 ---------
 .../config/Plc4xSourceConnector.properties         | 21 --------
 .../config/connect-avro-docker.properties          | 44 ----------------
 integrations/apache-kafka/config/sink.properties   | 25 +++++++++
 integrations/apache-kafka/config/source.properties | 24 +++++++++
 integrations/apache-kafka/docker-compose.yml       | 45 -----------------
 integrations/apache-kafka/pom.xml                  | 55 ++------------------
 .../apache-kafka/src/main/assembly/package.xml     | 59 ----------------------
 .../org/apache/plc4x/kafka/Plc4xSourceTask.java    |  7 +--
 .../apache/plc4x/kafka/Plc4xSinkConnectorTest.java | 30 -----------
 .../org/apache/plc4x/kafka/Plc4xSinkTaskTest.java  | 30 -----------
 .../plc4x/kafka/Plc4xSourceConnectorTest.java      | 30 -----------
 .../apache/plc4x/kafka/Plc4xSourceTaskTest.java    | 30 -----------
 .../apache-kafka/src/test/resources/logback.xml    | 29 -----------
 16 files changed, 61 insertions(+), 454 deletions(-)
 delete mode 100644 integrations/apache-kafka/bin/debug.sh
 delete mode 100644 integrations/apache-kafka/config/Plc4xSinkConnector.properties
 delete mode 100644 integrations/apache-kafka/config/Plc4xSourceConnector.properties
 delete mode 100644 integrations/apache-kafka/config/connect-avro-docker.properties
 create mode 100644 integrations/apache-kafka/config/sink.properties
 create mode 100644 integrations/apache-kafka/config/source.properties
 delete mode 100644 integrations/apache-kafka/docker-compose.yml
 delete mode 100644 integrations/apache-kafka/src/main/assembly/package.xml
 delete mode 100644 integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkConnectorTest.java
 delete mode 100644 integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSinkTaskTest.java
 delete mode 100644 integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceConnectorTest.java
 delete mode 100644 integrations/apache-kafka/src/test/java/org/apache/plc4x/kafka/Plc4xSourceTaskTest.java
 delete mode 100644 integrations/apache-kafka/src/test/resources/logback.xml


[incubator-plc4x] 01/03: removed old files

Posted by cd...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

cdutz pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-plc4x.git

commit af14dd992e85d80e9a20cf040c11810d21faba87
Author: Andrey Skorikov <an...@codecentric.de>
AuthorDate: Wed Sep 12 16:09:11 2018 +0200

    removed old files
---
 integrations/apache-kafka/README.md                | 34 +++----------
 integrations/apache-kafka/bin/debug.sh             | 29 -----------
 .../config/Plc4xSinkConnector.properties           | 23 ---------
 .../config/Plc4xSourceConnector.properties         | 21 --------
 .../config/connect-avro-docker.properties          | 44 ----------------
 integrations/apache-kafka/config/sink.properties   | 25 +++++++++
 integrations/apache-kafka/config/source.properties | 24 +++++++++
 integrations/apache-kafka/docker-compose.yml       | 45 -----------------
 integrations/apache-kafka/pom.xml                  | 55 ++------------------
 .../apache-kafka/src/main/assembly/package.xml     | 59 ----------------------
 .../org/apache/plc4x/kafka/Plc4xSourceTask.java    |  7 +--
 .../apache/plc4x/kafka/Plc4xSinkConnectorTest.java | 30 -----------
 .../org/apache/plc4x/kafka/Plc4xSinkTaskTest.java  | 30 -----------
 .../plc4x/kafka/Plc4xSourceConnectorTest.java      | 30 -----------
 .../apache/plc4x/kafka/Plc4xSourceTaskTest.java    | 30 -----------
 .../apache-kafka/src/test/resources/logback.xml    | 29 -----------
 16 files changed, 61 insertions(+), 454 deletions(-)

diff --git a/integrations/apache-kafka/README.md b/integrations/apache-kafka/README.md
index 5b9e3be..6b646f2 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 7be498d..0000000
--- 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 29ff1a8..0000000
--- 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 3c54029..0000000
--- 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 5f8a265..0000000
--- 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 0000000..ae9ccba
--- /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 0000000..cbd00f5
--- /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 215c28a..0000000
--- 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 e09c85b..a4269ff 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 48dea31..0000000
--- 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 7d0ed86..7c048c5 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 @@ public class Plc4xSourceTask extends SourceTask {
     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 class Plc4xSourceTask extends SourceTask {
 
         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 2777ed5..0000000
--- 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 9006e85..0000000
--- 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 27d158d..0000000
--- 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 3b5942b..0000000
--- 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 c2bb522..0000000
--- 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


[incubator-plc4x] 03/03: Merge branch 'skorikov-feature/api-redesign-chris-c'

Posted by cd...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

cdutz pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-plc4x.git

commit 86fb5db7e24946dd25aad688c1c6fec3e392faea
Merge: e22e344 98976eb
Author: Christofer Dutz <ch...@c-ware.de>
AuthorDate: Mon Sep 17 17:46:06 2018 +0200

    Merge branch 'skorikov-feature/api-redesign-chris-c'

 integrations/apache-kafka/README.md                | 34 +++----------
 integrations/apache-kafka/bin/debug.sh             | 29 -----------
 .../config/Plc4xSinkConnector.properties           | 23 ---------
 .../config/Plc4xSourceConnector.properties         | 21 --------
 .../config/connect-avro-docker.properties          | 44 ----------------
 integrations/apache-kafka/config/sink.properties   | 25 +++++++++
 integrations/apache-kafka/config/source.properties | 24 +++++++++
 integrations/apache-kafka/docker-compose.yml       | 45 -----------------
 integrations/apache-kafka/pom.xml                  | 55 ++------------------
 .../apache-kafka/src/main/assembly/package.xml     | 59 ----------------------
 .../org/apache/plc4x/kafka/Plc4xSourceTask.java    |  7 +--
 .../apache/plc4x/kafka/Plc4xSinkConnectorTest.java | 30 -----------
 .../org/apache/plc4x/kafka/Plc4xSinkTaskTest.java  | 30 -----------
 .../plc4x/kafka/Plc4xSourceConnectorTest.java      | 30 -----------
 .../apache/plc4x/kafka/Plc4xSourceTaskTest.java    | 30 -----------
 .../apache-kafka/src/test/resources/logback.xml    | 29 -----------
 16 files changed, 61 insertions(+), 454 deletions(-)


[incubator-plc4x] 02/03: Merge branch 'feature/api-redesign-chris-c' of https://github.com/skorikov/incubator-plc4x into skorikov-feature/api-redesign-chris-c

Posted by cd...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

cdutz pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-plc4x.git

commit 98976ebd3375111e3373342b291872040f750a23
Merge: e22e344 af14dd9
Author: Christofer Dutz <ch...@c-ware.de>
AuthorDate: Mon Sep 17 17:45:00 2018 +0200

    Merge branch 'feature/api-redesign-chris-c' of https://github.com/skorikov/incubator-plc4x into skorikov-feature/api-redesign-chris-c

 integrations/apache-kafka/README.md                | 34 +++----------
 integrations/apache-kafka/bin/debug.sh             | 29 -----------
 .../config/Plc4xSinkConnector.properties           | 23 ---------
 .../config/Plc4xSourceConnector.properties         | 21 --------
 .../config/connect-avro-docker.properties          | 44 ----------------
 integrations/apache-kafka/config/sink.properties   | 25 +++++++++
 integrations/apache-kafka/config/source.properties | 24 +++++++++
 integrations/apache-kafka/docker-compose.yml       | 45 -----------------
 integrations/apache-kafka/pom.xml                  | 55 ++------------------
 .../apache-kafka/src/main/assembly/package.xml     | 59 ----------------------
 .../org/apache/plc4x/kafka/Plc4xSourceTask.java    |  7 +--
 .../apache/plc4x/kafka/Plc4xSinkConnectorTest.java | 30 -----------
 .../org/apache/plc4x/kafka/Plc4xSinkTaskTest.java  | 30 -----------
 .../plc4x/kafka/Plc4xSourceConnectorTest.java      | 30 -----------
 .../apache/plc4x/kafka/Plc4xSourceTaskTest.java    | 30 -----------
 .../apache-kafka/src/test/resources/logback.xml    | 29 -----------
 16 files changed, 61 insertions(+), 454 deletions(-)