You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@streampipes.apache.org by ze...@apache.org on 2023/01/03 10:02:11 UTC

[streampipes] branch dev updated: Sp 1026 (#1027) Fix unit test and activate them in actions

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

zehnder pushed a commit to branch dev
in repository https://gitbox.apache.org/repos/asf/streampipes.git


The following commit(s) were added to refs/heads/dev by this push:
     new 60ebf2116 Sp 1026 (#1027) Fix unit test and activate them in actions
60ebf2116 is described below

commit 60ebf2116f9ac2ccc2b07fd25103207757de9a0b
Author: Philipp Zehnder <te...@users.noreply.github.com>
AuthorDate: Tue Jan 3 11:02:06 2023 +0100

    Sp 1026 (#1027) Fix unit test and activate them in actions
    
    * [#1026] Fix unit test in extensions-management
    
    * [#1026] Fix junit tests in streampipes-pipeline-management
    
    * [#1026] Fix junit tests in streampipes-connect-management
    
    * [#1026] Activate JUnit tests in GiHub actions
    
    * [#1026] Remove flinkspector from tests
---
 .github/workflows/build.yml                        |   2 +-
 .github/workflows/cypress-test.yml                 |   2 +-
 .github/workflows/pr-validation.yml                |   4 +-
 pom.xml                                            |  18 -
 streampipes-connect-management/pom.xml             |  10 -
 .../management/health/AdapterHealthCheckTest.java  | 122 -----
 .../management/AdapterMasterManagementTest.java    |   5 +-
 .../management/DescriptionManagementTest.java      |  65 ---
 .../management/UnitMasterManagementTest.java       | 128 ------
 .../management/WorkerRestClientTest.java           | 141 ------
 streampipes-extensions-management/pom.xml          |   5 -
 .../connect/AdapterWorkerManagementTest.java       |  19 +-
 .../extensions/management/connect/Mock.java        |  26 --
 .../extensions/management/connect/Utils.java       |   4 +-
 .../connect/adapter/GroundingServiceTest.java      |  80 ----
 .../format/json/arraykey/JsonParserTest.java       |   7 +-
 .../json/arraynokey/JsonArrayParserTest.java       |   8 +-
 .../adapter/format/json/geojson/GeoJsonTest.java   | 362 +++++++--------
 .../format/json/object/JsonObjectParserTest.java   |   6 +-
 .../connect/adapter/format/json/xml/XmlTest.java   | 511 +++++++++------------
 .../schema/CreateNestedTransformationRuleTest.java |   1 +
 .../schema/DeleteTransformationRuleTest.java       |   3 +-
 .../schema/MoveTransformationRuleTest.java         |   1 +
 .../schema/RenameTransformationRuleTest.java       |   1 +
 .../schema/SchemaEventTransformerTest.java         |  16 +-
 .../value/TimestampTransformRuleTest.java          | 244 ----------
 .../transform/value/UnitTransformRuleTest.java     |  13 +-
 .../pom.xml                                        |  25 -
 .../processor/aggregation/AggregationTestData.java |  67 ---
 .../aggregation/TestTimeAggregationProgram.java    |  82 ----
 .../flink/processor/count/TestCountProgram.java    | 135 ------
 .../flink/processor/rate/TestRateProgram.java      | 129 ------
 .../pom.xml                                        |  14 -
 .../detection/processor/absence/TestAbsence.java   | 125 -----
 .../pattern/detection/processor/and/TestAnd.java   | 135 ------
 .../pom.xml                                        |  23 -
 .../pom.xml                                        |  15 -
 .../processor/converter/TestConverterProgram.java  |  95 ----
 .../flink/processor/hasher/TestFieldHasher.java    | 124 -----
 .../hasher/TestFieldHasherController.java          |  38 --
 .../processor/hasher/TestFieldHasherProgram.java   |  84 ----
 .../processor/hasher/TestFieldHasherUtils.java     |  44 --
 .../flink/processor/rename/TestRenameProgram.java  | 102 ----
 .../transformation/flink/utils/DummyCollector.java |  48 --
 .../smp/extractor/TestDockerImageExtractor.java    |  44 --
 .../streampipes/manager/ThrowableCaptor.java       |  42 --
 .../manager/assets/TestImagePathReplacer.java      |  31 +-
 .../manager/matching/TestPipelineModification.java |  66 ---
 .../matching/TestPipelineValidationHandler.java    |  64 ---
 .../streampipes/manager/matching/TestRdfId.java    |  49 --
 .../manager/matching/v2/ListPropertyMatchTest.java |   4 +-
 .../manager/matching/v2/TestDatatypeMatch.java     |   6 +-
 .../matching/v2/TestDomainPropertyMatch.java       |   9 +-
 .../matching/v2/TestElementVerification.java       |  41 --
 .../manager/matching/v2/TestFormatMatch.java       |   6 +-
 .../manager/matching/v2/TestGroundingMatch.java    |  21 +-
 .../matching/v2/TestMeasurementUnitMatch.java      |   5 +-
 .../matching/v2/TestPrimitivePropertyMatch.java    |   6 +-
 .../manager/matching/v2/TestProtocolMatch.java     |   6 +-
 .../manager/matching/v2/TestSchemaMatch.java       |   6 +-
 .../streampipes/manager/matching/v2/TestUtils.java |  59 ---
 .../manager/pipeline/TestPipelineManager.java      |   9 -
 .../pipeline/TestPipelinesContainingElements.java  |  89 ----
 .../manager/selector/TestPropertyRenaming.java     |   1 -
 .../streampipes/manager/selector/TestSelector.java |   9 +-
 65 files changed, 488 insertions(+), 3174 deletions(-)

diff --git a/.github/workflows/build.yml b/.github/workflows/build.yml
index 965e1262f..8954c4e7c 100644
--- a/.github/workflows/build.yml
+++ b/.github/workflows/build.yml
@@ -40,7 +40,7 @@ jobs:
           node-version: '16.x'
 
       - name: Build with Maven
-        run: mvn clean verify -Dmaven.test.skip=true
+        run: mvn clean verify
 
       - name: Set env variables for Docker builds
         run: |
diff --git a/.github/workflows/cypress-test.yml b/.github/workflows/cypress-test.yml
index 28c7a33eb..e870058b0 100644
--- a/.github/workflows/cypress-test.yml
+++ b/.github/workflows/cypress-test.yml
@@ -47,7 +47,7 @@ jobs:
           npm run build
 
       - name: Build with Maven
-        run: mvn clean package -Dmaven.test.skip=true
+        run: mvn clean package
 
       - name: Build and run streampipes
         run: docker-compose up --build -d
diff --git a/.github/workflows/pr-validation.yml b/.github/workflows/pr-validation.yml
index 85a757fa3..07ace7096 100644
--- a/.github/workflows/pr-validation.yml
+++ b/.github/workflows/pr-validation.yml
@@ -32,7 +32,7 @@ jobs:
           java-version: '17'
 
       - name: Validate java code
-        run: mvn clean verify -Dmaven.test.skip=true
+        run: mvn clean verify
 
   run-format-and-lint-ui:
     runs-on: ubuntu-latest
@@ -85,7 +85,7 @@ jobs:
           npm run build
 
       - name: Build with Maven
-        run: mvn clean package -Dmaven.test.skip=true
+        run: mvn clean package
 
       - name: Build and run streampipes
         run: docker-compose up --build -d
diff --git a/pom.xml b/pom.xml
index 1e7c5967c..7e1822550 100644
--- a/pom.xml
+++ b/pom.xml
@@ -53,7 +53,6 @@
         <elasticsearch.version>6.8.17</elasticsearch.version>
         <file-management.version>3.1.0</file-management.version>
         <flink.version>1.13.5</flink.version>
-        <flinkspector.version>0.9.4</flinkspector.version>
         <fogsy-qudt.version>1.0</fogsy-qudt.version>
         <fst.version>2.57</fst.version>
         <geojson-jackson.version>1.14</geojson-jackson.version>
@@ -993,23 +992,6 @@
                 <version>${rest-assured.version}</version>
                 <scope>test</scope>
             </dependency>
-            <dependency>
-                <groupId>io.flinkspector</groupId>
-                <artifactId>flinkspector-datastream_2.11</artifactId>
-                <version>${flinkspector.version}</version>
-                <scope>test</scope>
-            </dependency>
-            <dependency>
-                <groupId>org.apache.flink</groupId>
-                <artifactId>flink-test-utils_2.11</artifactId>
-                <version>${flink.version}</version>
-                <exclusions>
-                    <exclusion>
-                        <groupId>org.apache.logging.log4j</groupId>
-                        <artifactId>log4j-slf4j-impl</artifactId>
-                    </exclusion>
-                </exclusions>
-            </dependency>
             <dependency>
                 <groupId>org.apache.flink</groupId>
                 <artifactId>flink-runtime_2.11</artifactId>
diff --git a/streampipes-connect-management/pom.xml b/streampipes-connect-management/pom.xml
index 60c3ae026..84d8e076a 100644
--- a/streampipes-connect-management/pom.xml
+++ b/streampipes-connect-management/pom.xml
@@ -79,16 +79,6 @@
             <artifactId>mockito-core</artifactId>
             <scope>test</scope>
         </dependency>
-        <dependency>
-            <groupId>org.powermock</groupId>
-            <artifactId>powermock-module-junit4</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.powermock</groupId>
-            <artifactId>powermock-api-mockito2</artifactId>
-            <scope>test</scope>
-        </dependency>
     </dependencies>
 
     <build>
diff --git a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/health/AdapterHealthCheckTest.java b/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/health/AdapterHealthCheckTest.java
deleted file mode 100644
index 7e928bd71..000000000
--- a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/health/AdapterHealthCheckTest.java
+++ /dev/null
@@ -1,122 +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.streampipes.connect.management.health;
-
-import org.apache.streampipes.connect.management.management.AdapterMasterManagement;
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
-import org.apache.streampipes.model.connect.adapter.AdapterDescription;
-import org.apache.streampipes.model.connect.adapter.AdapterStreamDescription;
-import org.apache.streampipes.model.connect.adapter.SpecificAdapterStreamDescription;
-import org.apache.streampipes.sdk.builder.adapter.SpecificDataStreamAdapterBuilder;
-import org.apache.streampipes.storage.couchdb.impl.AdapterInstanceStorageImpl;
-
-import org.junit.Test;
-
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.mockito.ArgumentMatchers.any;
-import static org.mockito.Mockito.times;
-import static org.mockito.Mockito.verify;
-import static org.powermock.api.mockito.PowerMockito.mock;
-import static org.powermock.api.mockito.PowerMockito.when;
-
-public class AdapterHealthCheckTest {
-
-  private final String testElementId = "testElementId";
-
-  @Test
-  public void getAllRunningInstancesAdapterDescriptions() {
-    AdapterInstanceStorageImpl adapterStorage = mock(AdapterInstanceStorageImpl.class);
-    when(adapterStorage.getAllAdapters()).thenReturn(getAdapterDescriptionList());
-
-    AdapterHealthCheck adapterHealthCheck = new AdapterHealthCheck(adapterStorage, null);
-    Map<String, AdapterDescription> result = adapterHealthCheck.getAllRunningInstancesAdapterDescriptions();
-
-    assertNotNull(result);
-    assertEquals(1, result.keySet().size());
-    assertEquals(getAdapterDescriptionList().get(0), result.get(testElementId));
-  }
-
-  @Test
-  public void getAllWorkersWithAdapters() {
-    AdapterInstanceStorageImpl adapterStorage = mock(AdapterInstanceStorageImpl.class);
-    when(adapterStorage.getAllAdapters()).thenReturn(getAdapterDescriptionList());
-
-    AdapterHealthCheck adapterHealthCheck = new AdapterHealthCheck(null, null);
-    Map<String, List<AdapterDescription>> result =
-        adapterHealthCheck.getAllWorkersWithAdapters(getAdapterDescriptionMap());
-
-    assertNotNull(result);
-    assertEquals(1, result.keySet().size());
-    String selectedEndpointUrl = "http://test.de";
-    assertEquals(1, result.get(selectedEndpointUrl).size());
-    assertEquals(getAdapterDescriptionList().get(0), result.get(selectedEndpointUrl).get(0));
-  }
-
-  @Test
-  public void recoverRunningAdaptersTest() throws AdapterException {
-    AdapterMasterManagement adapterMasterManagementMock = mock(AdapterMasterManagement.class);
-    AdapterHealthCheck adapterHealthCheck = new AdapterHealthCheck(null, adapterMasterManagementMock);
-
-    adapterHealthCheck.recoverAdapters(getAdaptersToRecoverData(true));
-
-    verify(adapterMasterManagementMock, times(1)).startStreamAdapter(any());
-  }
-
-
-  @Test
-  public void recoverStoppedAdaptersTest() throws AdapterException {
-    AdapterMasterManagement adapterMasterManagementMock = mock(AdapterMasterManagement.class);
-    AdapterHealthCheck adapterHealthCheck = new AdapterHealthCheck(null, adapterMasterManagementMock);
-
-    adapterHealthCheck.recoverAdapters(getAdaptersToRecoverData(false));
-
-    verify(adapterMasterManagementMock, times(0)).startStreamAdapter(any());
-  }
-
-  private Map<String, AdapterDescription> getAdaptersToRecoverData(boolean isRunning) {
-    Map<String, AdapterDescription> adaptersToRecover = new HashMap<>();
-    AdapterStreamDescription ad = SpecificDataStreamAdapterBuilder.create("").build();
-    ad.setRunning(isRunning);
-    adaptersToRecover.put("", ad);
-    return adaptersToRecover;
-  }
-
-  private List<AdapterDescription> getAdapterDescriptionList() {
-
-    SpecificAdapterStreamDescription adapterStreamDescription = SpecificDataStreamAdapterBuilder
-        .create("testAppId", "Test Adapter", "")
-        .elementId(testElementId)
-        .build();
-    adapterStreamDescription.setSelectedEndpointUrl("http://test.de");
-
-    return List.of(adapterStreamDescription);
-  }
-
-  private Map<String, AdapterDescription> getAdapterDescriptionMap() {
-    Map<String, AdapterDescription> result = new HashMap<>();
-    result.put(testElementId, getAdapterDescriptionList().get(0));
-
-    return result;
-  }
-
-}
diff --git a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/AdapterMasterManagementTest.java b/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/AdapterMasterManagementTest.java
index 4b2a42678..0ad8170a6 100644
--- a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/AdapterMasterManagementTest.java
+++ b/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/AdapterMasterManagementTest.java
@@ -26,7 +26,6 @@ import org.apache.streampipes.storage.couchdb.impl.AdapterInstanceStorageImpl;
 
 import org.junit.Test;
 
-import java.util.Arrays;
 import java.util.List;
 
 import static org.junit.Assert.assertEquals;
@@ -49,7 +48,7 @@ public class AdapterMasterManagementTest {
 
   @Test(expected = AdapterException.class)
   public void getAdapterFail() throws AdapterException {
-    List<AdapterDescription> adapterDescriptions = Arrays.asList(new GenericAdapterStreamDescription());
+    List<AdapterDescription> adapterDescriptions = List.of(new GenericAdapterStreamDescription());
     AdapterInstanceStorageImpl adapterStorage = mock(AdapterInstanceStorageImpl.class);
     AdapterResourceManager resourceManager = mock(AdapterResourceManager.class);
     when(adapterStorage.getAllAdapters()).thenReturn(adapterDescriptions);
@@ -62,7 +61,7 @@ public class AdapterMasterManagementTest {
 
   @Test
   public void getAllAdaptersSuccess() throws AdapterException {
-    List<AdapterDescription> adapterDescriptions = Arrays.asList(new GenericAdapterStreamDescription());
+    List<AdapterDescription> adapterDescriptions = List.of(new GenericAdapterStreamDescription());
     AdapterInstanceStorageImpl adapterStorage = mock(AdapterInstanceStorageImpl.class);
     AdapterResourceManager resourceManager = mock(AdapterResourceManager.class);
     when(adapterStorage.getAllAdapters()).thenReturn(adapterDescriptions);
diff --git a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/DescriptionManagementTest.java b/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/DescriptionManagementTest.java
deleted file mode 100644
index 485ff04c9..000000000
--- a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/DescriptionManagementTest.java
+++ /dev/null
@@ -1,65 +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.streampipes.connect.management.management;
-
-import org.apache.streampipes.extensions.api.connect.IFormat;
-import org.apache.streampipes.extensions.management.connect.adapter.AdapterRegistry;
-import org.apache.streampipes.extensions.management.connect.adapter.format.json.arraykey.JsonFormat;
-import org.apache.streampipes.model.connect.grounding.FormatDescription;
-
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.Mockito;
-import org.powermock.api.mockito.PowerMockito;
-import org.powermock.core.classloader.annotations.PowerMockIgnore;
-import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
-
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-
-@RunWith(PowerMockRunner.class)
-@PrepareForTest({AdapterRegistry.class})
-@PowerMockIgnore({"com.sun.org.apache.xerces.*", "javax.xml.*", "org.xml.*", "javax.management.*"})
-public class DescriptionManagementTest {
-
-
-  @Test
-  public void getFormats() {
-    Map<String, IFormat> allFormats = new HashMap<>();
-    allFormats.put(JsonFormat.ID, new JsonFormat());
-
-    PowerMockito.mockStatic(AdapterRegistry.class);
-    Mockito.when(AdapterRegistry.getAllFormats())
-        .thenReturn(allFormats);
-
-    DescriptionManagement descriptionManagement = new DescriptionManagement();
-
-    List<FormatDescription> result = descriptionManagement.getFormats();
-
-    assertNotNull(result);
-    assertEquals(1, result.size());
-    assertEquals(JsonFormat.ID, result.get(0).getAppId());
-  }
-
-}
diff --git a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/UnitMasterManagementTest.java b/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/UnitMasterManagementTest.java
deleted file mode 100644
index 722c97e39..000000000
--- a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/UnitMasterManagementTest.java
+++ /dev/null
@@ -1,128 +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.streampipes.connect.management.management;
-
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
-import org.apache.streampipes.model.connect.unit.UnitDescription;
-import org.apache.streampipes.units.UnitProvider;
-
-import com.github.jqudt.Unit;
-import com.github.jqudt.onto.UnitFactory;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.powermock.core.classloader.annotations.PowerMockIgnore;
-import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
-import org.powermock.reflect.Whitebox;
-
-import java.net.URI;
-import java.util.ArrayList;
-import java.util.List;
-
-import static org.junit.Assert.assertEquals;
-import static org.mockito.ArgumentMatchers.any;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.powermock.api.mockito.PowerMockito.mock;
-import static org.powermock.api.mockito.PowerMockito.when;
-
-@RunWith(PowerMockRunner.class)
-@PrepareForTest({UnitProvider.class, UnitFactory.class})
-@PowerMockIgnore({"com.sun.org.apache.xerces.*", "javax.xml.*", "org.xml.*", "javax.management.*"})
-public class UnitMasterManagementTest {
-
-  @Test(expected = AdapterException.class)
-  public void urlIsNull() throws AdapterException {
-    UnitMasterManagement unitMasterManagement = new UnitMasterManagement();
-    unitMasterManagement.getFittingUnits(getUnitDescription("", null));
-  }
-
-  @Test(expected = AdapterException.class)
-  @Ignore
-  public void invalidURL() throws AdapterException {
-    UnitProvider unitProvider = mock(UnitProvider.INSTANCE.getClass());
-    when(unitProvider.getUnit(anyString())).thenThrow(new IllegalStateException());
-
-    UnitMasterManagement unitMasterManagement = new UnitMasterManagement();
-    unitMasterManagement.getFittingUnits(getUnitDescription("", "http://test"));
-  }
-
-  @Test
-  public void getFittingUnitsEmpty() throws Exception {
-    UnitProvider unitProvider = mock(UnitProvider.INSTANCE.getClass());
-    when(unitProvider.getUnit(anyString())).thenReturn(new Unit());
-    when(unitProvider.getUnitsByType(any())).thenReturn((new ArrayList<>()));
-    Whitebox.setInternalState(UnitProvider.class, "INSTANCE", unitProvider);
-
-    UnitMasterManagement unitMasterManagement = new UnitMasterManagement();
-    String jsonResult = unitMasterManagement.getFittingUnits(getUnitDescription("", ""));
-    assertEquals("[]", jsonResult);
-  }
-
-  @Test
-  public void getFittingUnitsUnitsEmpty() throws Exception {
-    UnitProvider unitProvider = mock(UnitProvider.INSTANCE.getClass());
-    when(unitProvider.getUnit(anyString())).thenReturn(new Unit());
-
-    List<Unit> unitList = new ArrayList<>(2);
-    unitList.add(new Unit());
-    unitList.add(new Unit());
-
-    when(unitProvider.getUnitsByType(any())).thenReturn((unitList));
-    Whitebox.setInternalState(UnitProvider.class, "INSTANCE", unitProvider);
-
-    UnitMasterManagement unitMasterManagement = new UnitMasterManagement();
-    String jsonResult = unitMasterManagement.getFittingUnits(getUnitDescription("", ""));
-    assertEquals("[]", jsonResult);
-  }
-
-  @Test
-  public void getFittingUnitsUnits() throws Exception {
-    UnitProvider unitProvider = mock(UnitProvider.INSTANCE.getClass());
-    when(unitProvider.getUnit(anyString())).thenReturn(new Unit());
-
-    List<Unit> unitList = new ArrayList<>(2);
-    Unit unit = new Unit();
-    unit.setLabel("A");
-    unit.setResource(new URI("http://A"));
-    unitList.add(unit);
-    unit = new Unit();
-    unit.setLabel("A");
-    unit.setResource(new URI("http://A"));
-    unitList.add(unit);
-    unitList.add(new Unit());
-
-    when(unitProvider.getUnitsByType(any())).thenReturn((unitList));
-    Whitebox.setInternalState(UnitProvider.class, "INSTANCE", unitProvider);
-
-    UnitMasterManagement unitMasterManagement = new UnitMasterManagement();
-    String jsonResult = unitMasterManagement.getFittingUnits(getUnitDescription("", ""));
-    assertEquals("[{\"resource\":\"http://A\",\"label\":\"A\"},{\"resource\":\"http://A\",\"label\":\"A\"}]",
-        jsonResult);
-  }
-
-
-  private UnitDescription getUnitDescription(String label, String ressource) {
-    UnitDescription unitDescription = new UnitDescription();
-    unitDescription.setLabel(label);
-    unitDescription.setResource(ressource);
-    return unitDescription;
-  }
-
-}
diff --git a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/WorkerRestClientTest.java b/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/WorkerRestClientTest.java
deleted file mode 100644
index b89ebfc0c..000000000
--- a/streampipes-connect-management/src/test/java/org/apache/streampipes/connect/management/management/WorkerRestClientTest.java
+++ /dev/null
@@ -1,141 +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.streampipes.connect.management.management;
-
-import org.apache.streampipes.connect.management.util.WorkerPaths;
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
-import org.apache.streampipes.model.connect.adapter.GenericAdapterSetDescription;
-import org.apache.streampipes.model.connect.adapter.GenericAdapterStreamDescription;
-
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.powermock.api.mockito.PowerMockito;
-import org.powermock.core.classloader.annotations.PowerMockIgnore;
-import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
-
-import static org.mockito.ArgumentMatchers.any;
-import static org.mockito.ArgumentMatchers.anyString;
-import static org.mockito.ArgumentMatchers.eq;
-import static org.mockito.Mockito.times;
-import static org.powermock.api.mockito.PowerMockito.doNothing;
-import static org.powermock.api.mockito.PowerMockito.doThrow;
-import static org.powermock.api.mockito.PowerMockito.verifyStatic;
-import static org.powermock.api.mockito.PowerMockito.when;
-
-@RunWith(PowerMockRunner.class)
-@PrepareForTest({WorkerRestClient.class, WorkerPaths.class})
-@PowerMockIgnore({"com.sun.org.apache.xerces.*", "javax.xml.*", "org.xml.*", "javax.management.*"})
-public class WorkerRestClientTest {
-
-  /**
-   * Notes: In this class I tested how powermock could be used to mok static methods
-   * One problem is to mock static methods that return void
-   */
-
-  @Before
-  public void before() {
-    PowerMockito.mockStatic(WorkerRestClient.class);
-    PowerMockito.mockStatic(WorkerPaths.class);
-  }
-
-  @Test
-  public void stopStreamAdapterSuccess() throws Exception {
-
-    String expectedUrl = "worker/stream/stop";
-    doNothing().when(WorkerRestClient.class, "stopAdapter", any(), anyString());
-    when(WorkerRestClient.class, "stopStreamAdapter", anyString(), any()).thenCallRealMethod();
-    when(WorkerPaths.class, "getStreamStopPath").thenReturn(expectedUrl);
-    GenericAdapterStreamDescription description = new GenericAdapterStreamDescription();
-    description.setElementId("id1");
-
-    WorkerRestClient.stopStreamAdapter("", description);
-
-    verifyStatic(WorkerRestClient.class, times(1));
-    WorkerRestClient.stopAdapter(any(), eq(expectedUrl));
-
-  }
-
-  @Test(expected = AdapterException.class)
-  public void stopStreamAdapterFail() throws Exception {
-    doThrow(new AdapterException()).when(WorkerRestClient.class, "stopAdapter", any(), anyString());
-    when(WorkerRestClient.class, "stopStreamAdapter", anyString(), any()).thenCallRealMethod();
-
-    GenericAdapterStreamDescription description = new GenericAdapterStreamDescription();
-    description.setElementId("id1");
-
-    WorkerRestClient.stopStreamAdapter("", description);
-
-  }
-
-  @Test
-  public void invokeSetAdapterSuccess() throws Exception {
-
-    String expectedUrl = "worker/set/invoke";
-    doNothing().when(WorkerRestClient.class, "startAdapter", anyString(), any());
-    when(WorkerRestClient.class, "invokeSetAdapter", anyString(), any()).thenCallRealMethod();
-    when(WorkerPaths.class, "getSetInvokePath").thenReturn(expectedUrl);
-
-    GenericAdapterSetDescription description = new GenericAdapterSetDescription();
-    description.setElementId("id1");
-    WorkerRestClient.invokeSetAdapter("", description);
-
-    verifyStatic(WorkerRestClient.class, times(1));
-    WorkerRestClient.startAdapter(eq("worker/set/invoke"), any());
-
-  }
-
-  @Test(expected = AdapterException.class)
-  public void invokeSetAdapterFail() throws Exception {
-    doThrow(new AdapterException()).when(WorkerRestClient.class, "startAdapter", anyString(), any());
-    when(WorkerRestClient.class, "invokeSetAdapter", anyString(), any()).thenCallRealMethod();
-
-    WorkerRestClient.invokeSetAdapter("", null);
-  }
-
-  @Test
-  public void stopSetAdapterSuccess() throws Exception {
-
-    String expectedUrl = "worker/set/stop";
-    doNothing().when(WorkerRestClient.class, "stopAdapter", any(), anyString());
-    when(WorkerRestClient.class, "stopSetAdapter", anyString(), any()).thenCallRealMethod();
-    when(WorkerPaths.class, "getSetStopPath").thenReturn(expectedUrl);
-
-    GenericAdapterSetDescription description = new GenericAdapterSetDescription();
-    description.setElementId("id1");
-    WorkerRestClient.stopSetAdapter("", description);
-
-    verifyStatic(WorkerRestClient.class, times(1));
-    WorkerRestClient.stopAdapter(any(), eq(expectedUrl));
-
-  }
-
-  @Test(expected = AdapterException.class)
-  public void stopSetAdapterFail() throws Exception {
-    doThrow(new AdapterException()).when(WorkerRestClient.class, "stopAdapter", any(), anyString());
-    when(WorkerRestClient.class, "stopSetAdapter", anyString(), any()).thenCallRealMethod();
-
-    GenericAdapterSetDescription description = new GenericAdapterSetDescription();
-    description.setElementId("id1");
-    WorkerRestClient.stopSetAdapter("", description);
-
-  }
-
-}
diff --git a/streampipes-extensions-management/pom.xml b/streampipes-extensions-management/pom.xml
index a913d865c..473cde354 100644
--- a/streampipes-extensions-management/pom.xml
+++ b/streampipes-extensions-management/pom.xml
@@ -150,11 +150,6 @@
             <artifactId>junit</artifactId>
             <scope>test</scope>
         </dependency>
-        <dependency>
-            <groupId>org.powermock</groupId>
-            <artifactId>powermock-module-junit4</artifactId>
-            <scope>test</scope>
-        </dependency>
         <dependency>
             <groupId>org.mockito</groupId>
             <artifactId>mockito-core</artifactId>
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/AdapterWorkerManagementTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/AdapterWorkerManagementTest.java
index 45f1f8d33..12be28682 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/AdapterWorkerManagementTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/AdapterWorkerManagementTest.java
@@ -27,16 +27,13 @@ import org.apache.streampipes.model.connect.adapter.SpecificAdapterSetDescriptio
 import org.apache.streampipes.model.connect.guess.GuessSchema;
 
 import org.junit.Test;
-import org.junit.runner.RunWith;
 import org.powermock.core.classloader.annotations.PowerMockIgnore;
 import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
 
 import java.util.ArrayList;
 
 import static org.junit.Assert.assertTrue;
 
-@RunWith(PowerMockRunner.class)
 @PrepareForTest({AdapterRegistry.class})
 @PowerMockIgnore({"com.sun.org.apache.xerces.*", "javax.xml.*", "org.xml.*", "javax.management.*"})
 public class AdapterWorkerManagementTest {
@@ -44,7 +41,7 @@ public class AdapterWorkerManagementTest {
   @Test
   public void stopStreamAdapterSuccess() throws AdapterException {
     TestAdapter testAdapter = getTestAdapterInstance();
-    RunningAdapterInstances.INSTANCE.addAdapter("http://t.de/", testAdapter, null);
+    RunningAdapterInstances.INSTANCE.addAdapter("https://t.de/", testAdapter, null);
     AdapterWorkerManagement adapterWorkerManagement = new AdapterWorkerManagement();
     adapterWorkerManagement.stopStreamAdapter(Utils.getMinimalStreamAdapter());
 
@@ -56,7 +53,7 @@ public class AdapterWorkerManagementTest {
   public void stopSetAdapterSuccess() throws AdapterException {
     TestAdapter testAdapter = getTestAdapterInstance();
 
-    RunningAdapterInstances.INSTANCE.addAdapter("http://t.de/", testAdapter, null);
+    RunningAdapterInstances.INSTANCE.addAdapter("https://t.de/", testAdapter, null);
     AdapterWorkerManagement adapterWorkerManagement = new AdapterWorkerManagement();
     adapterWorkerManagement.stopSetAdapter(Utils.getMinimalSetAdapter());
 
@@ -66,12 +63,10 @@ public class AdapterWorkerManagementTest {
   private TestAdapter getTestAdapterInstance() {
     SpecificAdapterSetDescription description = new SpecificAdapterSetDescription();
     description.setRules(new ArrayList<>());
-    TestAdapter testAdapter = new TestAdapter(description);
-
-    return testAdapter;
+    return new TestAdapter(description);
   }
 
-  private class TestAdapter extends SpecificDataSetAdapter {
+  private static class TestAdapter extends SpecificDataSetAdapter {
 
     public boolean calledStart = false;
     public boolean calledStop = false;
@@ -86,17 +81,17 @@ public class AdapterWorkerManagementTest {
     }
 
     @Override
-    public void startAdapter() throws AdapterException {
+    public void startAdapter() {
       calledStart = true;
     }
 
     @Override
-    public void stopAdapter() throws AdapterException {
+    public void stopAdapter() {
       calledStop = true;
     }
 
     @Override
-    public Adapter getInstance(SpecificAdapterSetDescription adapterDescription) {
+    public Adapter<SpecificAdapterSetDescription> getInstance(SpecificAdapterSetDescription adapterDescription) {
       return null;
     }
 
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Mock.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Mock.java
deleted file mode 100644
index 49bac3d6d..000000000
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Mock.java
+++ /dev/null
@@ -1,26 +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.streampipes.extensions.management.connect;
-
-public class Mock {
-  public static final int PORT = 8042;
-
-  public static final String HOST = "http://localhost:" + PORT;
-
-}
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Utils.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Utils.java
index be79a4458..76d093d96 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Utils.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/Utils.java
@@ -29,7 +29,7 @@ public class Utils {
 
   public static AdapterStreamDescription getMinimalStreamAdapter() {
     AdapterStreamDescription result = new GenericAdapterStreamDescription();
-    String id = "http://t.de/";
+    String id = "https://t.de/";
     result.setElementId(id);
     result.setRules(new ArrayList<>());
 
@@ -38,7 +38,7 @@ public class Utils {
 
   public static AdapterSetDescription getMinimalSetAdapter() {
     AdapterSetDescription result = new GenericAdapterSetDescription();
-    String id = "http://t.de/";
+    String id = "https://t.de/";
     result.setElementId(id);
 
     return result;
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/GroundingServiceTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/GroundingServiceTest.java
index a6cb4e164..ac5735670 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/GroundingServiceTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/GroundingServiceTest.java
@@ -18,46 +18,21 @@
 
 package org.apache.streampipes.extensions.management.connect.adapter;
 
-import org.apache.streampipes.config.backend.BackendConfig;
 import org.apache.streampipes.model.SpDataSet;
 import org.apache.streampipes.model.connect.adapter.AdapterDescription;
 import org.apache.streampipes.model.connect.adapter.GenericAdapterSetDescription;
 import org.apache.streampipes.model.connect.adapter.GenericAdapterStreamDescription;
-import org.apache.streampipes.model.connect.adapter.SpecificAdapterSetDescription;
 import org.apache.streampipes.model.grounding.EventGrounding;
 import org.apache.streampipes.model.grounding.KafkaTransportProtocol;
 import org.apache.streampipes.model.grounding.SimpleTopicDefinition;
 import org.apache.streampipes.model.grounding.TopicDefinition;
-import org.apache.streampipes.svcdiscovery.api.SpConfig;
 
-import org.junit.Before;
 import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.powermock.api.mockito.PowerMockito;
-import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
 
 import static org.junit.Assert.assertEquals;
 
-@RunWith(PowerMockRunner.class)
-@PrepareForTest({BackendConfig.class, SpConfig.class})
 public class GroundingServiceTest {
 
-  @Before
-  public void before() {
-    PowerMockito.mockStatic(SpConfig.class);
-  }
-
-//    @Test
-//    public void extractBrokerForGenericAdapterSetTest() {
-//        AdapterDescription adapterDescription = getGenericAdapterSetDescription();
-//
-//        String result = GroundingService.extractBroker(adapterDescription);
-//
-//        assertEquals("localhost:1111", result);
-//    }
-
-
   @Test
   public void extractTopicForGenericAdapterSetTest() {
     AdapterDescription adapterDescription = getGenericAdapterSetDescription();
@@ -67,35 +42,6 @@ public class GroundingServiceTest {
     assertEquals("test.topic", result);
   }
 
-//    @Test
-//    public void extractBrokerForSpecificAdapterSetTest() {
-//        AdapterDescription adapterDescription = getSpecificAdapterSetDescription();
-//
-//        String result = GroundingService.extractBroker(adapterDescription);
-//
-//        assertEquals("localhost:1111", result);
-//    }
-
-
-//    @Test
-//    public void extractTopicForSpecificAdapterSetTest() {
-//        AdapterDescription adapterDescription = getSpecificAdapterSetDescription();
-//
-//        String result = GroundingService.extractTopic(adapterDescription);
-//
-//        assertEquals("test.topic", result);
-//    }
-
-//    @Test
-//    public void extractBrokerForStreamTest() {
-//        AdapterDescription adapterDescription = getAdapterStreamDescription();
-//
-//        String result = GroundingService.extractBroker(adapterDescription);
-//
-//        assertEquals("localhost:1111", result);
-//    }
-
-
   @Test
   public void extractTopicForStreamTest() {
     AdapterDescription adapterDescription = getAdapterStreamDescription();
@@ -105,23 +51,6 @@ public class GroundingServiceTest {
     assertEquals("test.topic", result);
   }
 
-//    @Test
-//    public void createEventGroundingTest() {
-//
-//        when(SpConfig.getSpConfig(anyString())).thenReturn(new MockSpConfig(""));
-//
-//        BackendConfig backendConfig = mock(BackendConfig.INSTANCE.getClass());
-//        when(backendConfig.getMessagingSettings()).thenReturn(MessagingSettings.fromDefault());
-//        Whitebox.setInternalState(BackendConfig.class, "INSTANCE", backendConfig);
-//        EventGrounding eventGrounding = GroundingService.createEventGrounding();
-//
-////        assertEquals("localhost", eventGrounding.getTransportProtocol().getBrokerHostname());
-////        assertEquals(0, ((KafkaTransportProtocol)eventGrounding.getTransportProtocol()).getKafkaPort());
-//        assertTrue(eventGrounding.getTransportProtocol().getTopicDefinition().getActualTopicName()
-//        .startsWith("org.apache.streampipes.connect"));
-//
-//    }
-
   private AdapterDescription getAdapterStreamDescription() {
     AdapterDescription adapterDescription = new GenericAdapterStreamDescription();
 
@@ -139,15 +68,6 @@ public class GroundingServiceTest {
     return adapterDescription;
   }
 
-  private AdapterDescription getSpecificAdapterSetDescription() {
-    SpecificAdapterSetDescription adapterDescription = new SpecificAdapterSetDescription();
-    SpDataSet set = new SpDataSet();
-    adapterDescription.setDataSet(set);
-
-    set.setEventGrounding(getEventGrounding());
-    return adapterDescription;
-  }
-
   private EventGrounding getEventGrounding() {
     EventGrounding eventGrounding = new EventGrounding();
     KafkaTransportProtocol transportProtocol = new KafkaTransportProtocol();
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraykey/JsonParserTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraykey/JsonParserTest.java
index bde640303..77a6335fb 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraykey/JsonParserTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraykey/JsonParserTest.java
@@ -18,7 +18,6 @@
 
 package org.apache.streampipes.extensions.management.connect.adapter.format.json.arraykey;
 
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
 import org.apache.streampipes.extensions.management.connect.adapter.TestUtils;
 
 import com.google.gson.JsonObject;
@@ -34,7 +33,7 @@ import static org.junit.Assert.assertEquals;
 public class JsonParserTest {
 
   @Test
-  public void parseOneEvent() throws AdapterException {
+  public void parseOneEvent() {
 
     String jo = TestUtils.getJsonArrayWithThreeElements();
 
@@ -51,7 +50,7 @@ public class JsonParserTest {
 
 
   @Test
-  public void parseThreeEvents() throws AdapterException {
+  public void parseThreeEvents() {
 
     String jo = TestUtils.getJsonArrayWithThreeElements();
     JsonParser parser = new JsonParser(true, "key0");
@@ -71,7 +70,7 @@ public class JsonParserTest {
 
 
   @Test
-  public void parseMoreThenExist() throws AdapterException {
+  public void parseMoreThenExist() {
 
     JsonObject jo = new JsonObject();
     jo.add("key0", TestUtils.makeJsonArray(
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraynokey/JsonArrayParserTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraynokey/JsonArrayParserTest.java
index fd6ac1a5f..9ebc4745a 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraynokey/JsonArrayParserTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/arraynokey/JsonArrayParserTest.java
@@ -19,7 +19,7 @@
 package org.apache.streampipes.extensions.management.connect.adapter.format.json.arraynokey;
 
 
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
+
 import org.apache.streampipes.extensions.management.connect.adapter.TestUtils;
 
 import com.google.gson.JsonArray;
@@ -35,7 +35,7 @@ import static org.junit.Assert.assertEquals;
 public class JsonArrayParserTest {
 
   @Test
-  public void parseOneEvent() throws AdapterException {
+  public void parseOneEvent() {
 
     String jo = TestUtils.getJsonArrayWithThreeElements();
 
@@ -51,7 +51,7 @@ public class JsonArrayParserTest {
 
 
   @Test
-  public void parseThreeEvents() throws AdapterException {
+  public void parseThreeEvents() {
 
     String jo = TestUtils.getJsonArrayWithThreeElements();
     JsonArrayParser parser = new JsonArrayParser();
@@ -71,7 +71,7 @@ public class JsonArrayParserTest {
 
 
   @Test
-  public void parseMoreThenExist() throws AdapterException {
+  public void parseMoreThenExist() {
 
     JsonArray jsonArray = new JsonArray();
     jsonArray.add(TestUtils.makeJsonObject("one", 1));
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/geojson/GeoJsonTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/geojson/GeoJsonTest.java
index f7c1a4b75..2dc2279c8 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/geojson/GeoJsonTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/geojson/GeoJsonTest.java
@@ -18,7 +18,6 @@
 
 package org.apache.streampipes.extensions.management.connect.adapter.format.json.geojson;
 
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
 import org.apache.streampipes.extensions.management.connect.adapter.format.geojson.GeoJsonParser;
 import org.apache.streampipes.model.schema.EventSchema;
 
@@ -26,7 +25,6 @@ import org.apache.commons.io.IOUtils;
 import org.junit.Test;
 
 import java.io.InputStream;
-import java.io.UnsupportedEncodingException;
 import java.nio.charset.StandardCharsets;
 import java.util.Collections;
 import java.util.List;
@@ -38,10 +36,10 @@ import static org.junit.Assert.assertEquals;
 public class GeoJsonTest {
 
   @Test
-  public void getSchema1() throws UnsupportedEncodingException {
+  public void getSchema1() {
     GeoJsonParser parser = new GeoJsonParser();
 
-    byte[] event = getOneEventExampleMultiPolygon().getBytes("UTF-8");
+    byte[] event = getOneEventExampleMultiPolygon().getBytes(StandardCharsets.UTF_8);
 
     EventSchema eventSchema = parser.getEventSchema(Collections.singletonList(event));
 
@@ -50,10 +48,10 @@ public class GeoJsonTest {
   }
 
   @Test
-  public void getSchema2() throws UnsupportedEncodingException {
+  public void getSchema2() {
     GeoJsonParser parser = new GeoJsonParser();
 
-    byte[] event = getOneEventExample().getBytes("UTF-8");
+    byte[] event = getOneEventExample().getBytes(StandardCharsets.UTF_8);
 
     EventSchema eventSchema = parser.getEventSchema(Collections.singletonList(event));
 
@@ -63,7 +61,7 @@ public class GeoJsonTest {
 
 
   @Test
-  public void parseOneEvent() throws AdapterException {
+  public void parseOneEvent() {
 
     String jo = getFullExampleWithOneElement();
 
@@ -91,7 +89,7 @@ public class GeoJsonTest {
 
   @SuppressWarnings("checkstyle:OperatorWrap")
   @Test
-  public void parseThreeEvents() throws AdapterException {
+  public void parseThreeEvents() {
 
     String jo = getFullExampleWithThreeElements();
     GeoJsonParser parser = new GeoJsonParser();
@@ -142,185 +140,191 @@ public class GeoJsonTest {
   }
 
   private String getOneEventExampleMultiPolygon() {
-    return "{\n" +
-           "      \"type\": \"Feature\",\n" +
-           "      \"geometry\": {\n" +
-           "        \"type\": \"MultiPolygon\",\n" +
-           "        \"coordinates\": [\n" +
-           "          [\n" +
-           "            [\n" +
-           "              [\n" +
-           "                30,\n" +
-           "                20\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                45,\n" +
-           "                40\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                10,\n" +
-           "                40\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                30,\n" +
-           "                20\n" +
-           "              ]\n" +
-           "            ]\n" +
-           "          ],\n" +
-           "          [\n" +
-           "            [\n" +
-           "              [\n" +
-           "                15,\n" +
-           "                5\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                40,\n" +
-           "                10\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                10,\n" +
-           "                20\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                5,\n" +
-           "                10\n" +
-           "              ],\n" +
-           "              [\n" +
-           "                15,\n" +
-           "                5\n" +
-           "              ]\n" +
-           "            ]\n" +
-           "          ]\n" +
-           "        ]\n" +
-           "      },\n" +
-           "      \"properties\": {\n" +
-           "        \"measurementOrCalculationTime\": \"20180724160327\",\n" +
-           "        \"publicationTime\": \"20161026212501\",\n" +
-           "        \"lorryFlowRate\": \"4\",\n" +
-           "        \"lorryAverageVehicleSpeed\": \"84.0\",\n" +
-           "        \"anyVehicleAverageVehicleSpeed\": \"84.0\",\n" +
-           "        \"carAverageVehicleSpeed\": \"85.0\",\n" +
-           "        \"anyVehicleFlowRate\": \"21\",\n" +
-           "        \"anyVehiclePercentageLongVehicle\": \"19.0\",\n" +
-           "        \"carFlowRate\": \"17\",\n" +
-           "        \"id\": \"fs.MQ_A40-10E_HFB_NO_1\"\n" +
-           "      }\n" +
-           "    }";
+    return """
+        {
+              "type": "Feature",
+              "geometry": {
+                "type": "MultiPolygon",
+                "coordinates": [
+                  [
+                    [
+                      [
+                        30,
+                        20
+                      ],
+                      [
+                        45,
+                        40
+                      ],
+                      [
+                        10,
+                        40
+                      ],
+                      [
+                        30,
+                        20
+                      ]
+                    ]
+                  ],
+                  [
+                    [
+                      [
+                        15,
+                        5
+                      ],
+                      [
+                        40,
+                        10
+                      ],
+                      [
+                        10,
+                        20
+                      ],
+                      [
+                        5,
+                        10
+                      ],
+                      [
+                        15,
+                        5
+                      ]
+                    ]
+                  ]
+                ]
+              },
+              "properties": {
+                "measurementOrCalculationTime": "20180724160327",
+                "publicationTime": "20161026212501",
+                "lorryFlowRate": "4",
+                "lorryAverageVehicleSpeed": "84.0",
+                "anyVehicleAverageVehicleSpeed": "84.0",
+                "carAverageVehicleSpeed": "85.0",
+                "anyVehicleFlowRate": "21",
+                "anyVehiclePercentageLongVehicle": "19.0",
+                "carFlowRate": "17",
+                "id": "fs.MQ_A40-10E_HFB_NO_1"
+              }
+            }""";
   }
 
   private String getOneEventExample() {
-    return "{\n" +
-           "\t\t\t\"type\" : \"Feature\",\n" +
-           "\t\t\t\"geometry\" : {\n" +
-           "\t\t\t\t\"type\" : \"Point\",\n" +
-           "\t\t\t\t\"coordinates\" : [ 6.946535, 51.437344 ]\n" +
-           "\t\t\t},\n" +
-           "\t\t\t\"properties\" : {\n" +
-           "\t\t\t\t\"measurementOrCalculationTime\" : \"20180717121027\",\n" +
-           "\t\t\t\t\"publicationTime\" : \"20161026212501\",\n" +
-           "\t\t\t\t\"lorryFlowRate\" : \"5\",\n" +
-           "\t\t\t\t\"lorryAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"anyVehicleAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"carAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"anyVehicleFlowRate\" : \"15\",\n" +
-           "\t\t\t\t\"anyVehiclePercentageLongVehicle\" : \"33.0\",\n" +
-           "\t\t\t\t\"carFlowRate\" : \"10\",\n" +
-           "\t\t\t\t\"id\" : \"fs.MQ_A40-10E_HFB_NO_1\"\n" +
-           "\t\t\t}\n" +
-           "\t\t}";
+    return """
+        {
+        \t\t\t"type" : "Feature",
+        \t\t\t"geometry" : {
+        \t\t\t\t"type" : "Point",
+        \t\t\t\t"coordinates" : [ 6.946535, 51.437344 ]
+        \t\t\t},
+        \t\t\t"properties" : {
+        \t\t\t\t"measurementOrCalculationTime" : "20180717121027",
+        \t\t\t\t"publicationTime" : "20161026212501",
+        \t\t\t\t"lorryFlowRate" : "5",
+        \t\t\t\t"lorryAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"anyVehicleAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"carAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"anyVehicleFlowRate" : "15",
+        \t\t\t\t"anyVehiclePercentageLongVehicle" : "33.0",
+        \t\t\t\t"carFlowRate" : "10",
+        \t\t\t\t"id" : "fs.MQ_A40-10E_HFB_NO_1"
+        \t\t\t}
+        \t\t}""";
   }
 
   private String getFullExampleWithOneElement() {
-    return "{\n" +
-           "\t\"type\" : \"FeatureCollection\",\n" +
-           "\t\"name\" : \"geschwindigkeitsdaten_NRW\",\n" +
-           "\t\"features\" : [\n" +
-           "\t\t{\n" +
-           "\t\t\t\"type\" : \"Feature\",\n" +
-           "\t\t\t\"geometry\" : {\n" +
-           "\t\t\t\t\"type\" : \"Point\",\n" +
-           "\t\t\t\t\"coordinates\" : [ 6.946535, 51.437344 ]\n" +
-           "\t\t\t},\n" +
-           "\t\t\t\"properties\" : {\n" +
-           "\t\t\t\t\"measurementOrCalculationTime\" : \"20180717121027\",\n" +
-           "\t\t\t\t\"publicationTime\" : \"20161026212501\",\n" +
-           "\t\t\t\t\"lorryFlowRate\" : \"5\",\n" +
-           "\t\t\t\t\"lorryAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"anyVehicleAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"carAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"anyVehicleFlowRate\" : \"15\",\n" +
-           "\t\t\t\t\"anyVehiclePercentageLongVehicle\" : \"33.0\",\n" +
-           "\t\t\t\t\"carFlowRate\" : \"10\",\n" +
-           "\t\t\t\t\"id\" : \"fs.MQ_A40-10E_HFB_NO_1\"\n" +
-           "\t\t\t}\n" +
-           "\t\t}\n" +
-           "\t\n" +
-           "         ]\n" +
-           "}\n";
+    return """
+        {
+        \t"type" : "FeatureCollection",
+        \t"name" : "geschwindigkeitsdaten_NRW",
+        \t"features" : [
+        \t\t{
+        \t\t\t"type" : "Feature",
+        \t\t\t"geometry" : {
+        \t\t\t\t"type" : "Point",
+        \t\t\t\t"coordinates" : [ 6.946535, 51.437344 ]
+        \t\t\t},
+        \t\t\t"properties" : {
+        \t\t\t\t"measurementOrCalculationTime" : "20180717121027",
+        \t\t\t\t"publicationTime" : "20161026212501",
+        \t\t\t\t"lorryFlowRate" : "5",
+        \t\t\t\t"lorryAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"anyVehicleAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"carAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"anyVehicleFlowRate" : "15",
+        \t\t\t\t"anyVehiclePercentageLongVehicle" : "33.0",
+        \t\t\t\t"carFlowRate" : "10",
+        \t\t\t\t"id" : "fs.MQ_A40-10E_HFB_NO_1"
+        \t\t\t}
+        \t\t}
+        \t
+                 ]
+        }
+        """;
   }
 
   private String getFullExampleWithThreeElements() {
-    return "{\n" +
-           "\t\"type\" : \"FeatureCollection\",\n" +
-           "\t\"name\" : \"geschwindigkeitsdaten_NRW\",\n" +
-           "\t\"features\" : [\n" +
-           "\t\t{\n" +
-           "\t\t\t\"type\" : \"Feature\",\n" +
-           "\t\t\t\"geometry\" : {\n" +
-           "\t\t\t\t\"type\" : \"Point\",\n" +
-           "\t\t\t\t\"coordinates\" : [ 6.946535, 51.437344 ]\n" +
-           "\t\t\t},\n" +
-           "\t\t\t\"properties\" : {\n" +
-           "\t\t\t\t\"measurementOrCalculationTime\" : \"20180717121027\",\n" +
-           "\t\t\t\t\"publicationTime\" : \"20161026212501\",\n" +
-           "\t\t\t\t\"lorryFlowRate\" : \"5\",\n" +
-           "\t\t\t\t\"lorryAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"anyVehicleAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"carAverageVehicleSpeed\" : \"81.0\",\n" +
-           "\t\t\t\t\"anyVehicleFlowRate\" : \"15\",\n" +
-           "\t\t\t\t\"anyVehiclePercentageLongVehicle\" : \"33.0\",\n" +
-           "\t\t\t\t\"carFlowRate\" : \"10\",\n" +
-           "\t\t\t\t\"id\" : \"fs.MQ_A40-10E_HFB_NO_1\"\n" +
-           "\t\t\t}\n" +
-           "\t\t},\n" +
-           "\t\t{\n" +
-           "\t\t\t\"type\" : \"Feature\",\n" +
-           "\t\t\t\"geometry\" : {\n" +
-           "\t\t\t\t\"type\" : \"Point\",\n" +
-           "\t\t\t\t\"coordinates\" : [ 6.946535, 51.437344 ]\n" +
-           "\t\t\t},\n" +
-           "\t\t\t\"properties\" : {\n" +
-           "\t\t\t\t\"measurementOrCalculationTime\" : \"20180717121027\",\n" +
-           "\t\t\t\t\"publicationTime\" : \"20161026212501\",\n" +
-           "\t\t\t\t\"lorryFlowRate\" : \"0\",\n" +
-           "\t\t\t\t\"anyVehicleAverageVehicleSpeed\" : \"107.0\",\n" +
-           "\t\t\t\t\"carAverageVehicleSpeed\" : \"107.0\",\n" +
-           "\t\t\t\t\"anyVehicleFlowRate\" : \"6\",\n" +
-           "\t\t\t\t\"anyVehiclePercentageLongVehicle\" : \"0.0\",\n" +
-           "\t\t\t\t\"carFlowRate\" : \"6\",\n" +
-           "\t\t\t\t\"id\" : \"fs.MQ_A40-10E_HFB_NO_2\"\n" +
-           "\t\t\t}\n" +
-           "\t\t},\n" +
-           "\t\t{\n" +
-           "\t\t\t\"type\" : \"Feature\",\n" +
-           "\t\t\t\"geometry\" : {\n" +
-           "\t\t\t\t\"type\" : \"Point\",\n" +
-           "\t\t\t\t\"coordinates\" : [ 7.545113, 51.474907 ]\n" +
-           "\t\t\t},\n" +
-           "\t\t\t\"properties\" : {\n" +
-           "\t\t\t\t\"measurementOrCalculationTime\" : \"20180717121027\",\n" +
-           "\t\t\t\t\"publicationTime\" : \"20161026212501\",\n" +
-           "\t\t\t\t\"lorryFlowRate\" : \"1\",\n" +
-           "\t\t\t\t\"lorryAverageVehicleSpeed\" : \"71.0\",\n" +
-           "\t\t\t\t\"anyVehicleAverageVehicleSpeed\" : \"72.0\",\n" +
-           "\t\t\t\t\"carAverageVehicleSpeed\" : \"73.0\",\n" +
-           "\t\t\t\t\"anyVehicleFlowRate\" : \"9\",\n" +
-           "\t\t\t\t\"anyVehiclePercentageLongVehicle\" : \"11.0\",\n" +
-           "\t\t\t\t\"carFlowRate\" : \"8\",\n" +
-           "\t\t\t\t\"id\" : \"fs.MQ_Bergh.09_HFB_SW_1\"\n" +
-           "\t\t\t}\n" +
-           "\t\t}\n" +
-           "         ]\n" +
-           "}\n";
+    return """
+        {
+        \t"type" : "FeatureCollection",
+        \t"name" : "geschwindigkeitsdaten_NRW",
+        \t"features" : [
+        \t\t{
+        \t\t\t"type" : "Feature",
+        \t\t\t"geometry" : {
+        \t\t\t\t"type" : "Point",
+        \t\t\t\t"coordinates" : [ 6.946535, 51.437344 ]
+        \t\t\t},
+        \t\t\t"properties" : {
+        \t\t\t\t"measurementOrCalculationTime" : "20180717121027",
+        \t\t\t\t"publicationTime" : "20161026212501",
+        \t\t\t\t"lorryFlowRate" : "5",
+        \t\t\t\t"lorryAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"anyVehicleAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"carAverageVehicleSpeed" : "81.0",
+        \t\t\t\t"anyVehicleFlowRate" : "15",
+        \t\t\t\t"anyVehiclePercentageLongVehicle" : "33.0",
+        \t\t\t\t"carFlowRate" : "10",
+        \t\t\t\t"id" : "fs.MQ_A40-10E_HFB_NO_1"
+        \t\t\t}
+        \t\t},
+        \t\t{
+        \t\t\t"type" : "Feature",
+        \t\t\t"geometry" : {
+        \t\t\t\t"type" : "Point",
+        \t\t\t\t"coordinates" : [ 6.946535, 51.437344 ]
+        \t\t\t},
+        \t\t\t"properties" : {
+        \t\t\t\t"measurementOrCalculationTime" : "20180717121027",
+        \t\t\t\t"publicationTime" : "20161026212501",
+        \t\t\t\t"lorryFlowRate" : "0",
+        \t\t\t\t"anyVehicleAverageVehicleSpeed" : "107.0",
+        \t\t\t\t"carAverageVehicleSpeed" : "107.0",
+        \t\t\t\t"anyVehicleFlowRate" : "6",
+        \t\t\t\t"anyVehiclePercentageLongVehicle" : "0.0",
+        \t\t\t\t"carFlowRate" : "6",
+        \t\t\t\t"id" : "fs.MQ_A40-10E_HFB_NO_2"
+        \t\t\t}
+        \t\t},
+        \t\t{
+        \t\t\t"type" : "Feature",
+        \t\t\t"geometry" : {
+        \t\t\t\t"type" : "Point",
+        \t\t\t\t"coordinates" : [ 7.545113, 51.474907 ]
+        \t\t\t},
+        \t\t\t"properties" : {
+        \t\t\t\t"measurementOrCalculationTime" : "20180717121027",
+        \t\t\t\t"publicationTime" : "20161026212501",
+        \t\t\t\t"lorryFlowRate" : "1",
+        \t\t\t\t"lorryAverageVehicleSpeed" : "71.0",
+        \t\t\t\t"anyVehicleAverageVehicleSpeed" : "72.0",
+        \t\t\t\t"carAverageVehicleSpeed" : "73.0",
+        \t\t\t\t"anyVehicleFlowRate" : "9",
+        \t\t\t\t"anyVehiclePercentageLongVehicle" : "11.0",
+        \t\t\t\t"carFlowRate" : "8",
+        \t\t\t\t"id" : "fs.MQ_Bergh.09_HFB_SW_1"
+        \t\t\t}
+        \t\t}
+                 ]
+        }
+        """;
   }
 }
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/object/JsonObjectParserTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/object/JsonObjectParserTest.java
index fa9dbdbfc..df0b4faeb 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/object/JsonObjectParserTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/object/JsonObjectParserTest.java
@@ -18,8 +18,6 @@
 
 package org.apache.streampipes.extensions.management.connect.adapter.format.json.object;
 
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
-
 import com.google.gson.JsonObject;
 import org.apache.commons.io.IOUtils;
 import org.junit.Test;
@@ -34,7 +32,7 @@ import static org.junit.Assert.assertEquals;
 public class JsonObjectParserTest {
 
   @Test
-  public void parseOneEvent() throws AdapterException {
+  public void parseOneEvent() {
 
     JsonObject jo = makeJsonObject("one", 1);
 
@@ -49,7 +47,7 @@ public class JsonObjectParserTest {
   }
 
   @Test
-  public void parseMoreThenExist() throws AdapterException {
+  public void parseMoreThenExist() {
 
     JsonObject jo = makeJsonObject("one", 1);
 
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/xml/XmlTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/xml/XmlTest.java
index f70e92103..183eca170 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/xml/XmlTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/format/json/xml/XmlTest.java
@@ -18,7 +18,6 @@
 
 package org.apache.streampipes.extensions.management.connect.adapter.format.json.xml;
 
-import org.apache.streampipes.extensions.api.connect.exception.AdapterException;
 import org.apache.streampipes.extensions.management.connect.adapter.format.xml.XmlParser;
 import org.apache.streampipes.model.schema.EventSchema;
 
@@ -26,9 +25,7 @@ import org.apache.commons.io.IOUtils;
 import org.junit.Test;
 
 import java.io.InputStream;
-import java.io.UnsupportedEncodingException;
 import java.nio.charset.StandardCharsets;
-import java.util.ArrayList;
 import java.util.Collections;
 import java.util.List;
 
@@ -37,7 +34,7 @@ import static org.junit.Assert.assertEquals;
 public class XmlTest {
 
   @Test
-  public void parseEventCarPark() throws AdapterException {
+  public void parseEventCarPark() {
 
     String jo = getCarParkExample();
 
@@ -51,7 +48,7 @@ public class XmlTest {
   }
 
   @Test
-  public void parseEventParkingFaciltyStatus() throws AdapterException {
+  public void parseEventParkingFaciltyStatus() {
 
     String jo = getDatex2ParkingFacilityStatus();
 
@@ -71,10 +68,10 @@ public class XmlTest {
   }
 
   @Test
-  public void getSchemaCarExample() throws UnsupportedEncodingException {
+  public void getSchemaCarExample() {
     XmlParser parser = new XmlParser("parkhaus");
 
-    byte[] event = getEventSchemaTest().getBytes("UTF-8");
+    byte[] event = getEventSchemaTest().getBytes(StandardCharsets.UTF_8);
 
     EventSchema eventSchema = parser.getEventSchema(Collections.singletonList(event));
 
@@ -82,224 +79,216 @@ public class XmlTest {
 
   }
 
-    /*
-    @Test
-    public void getSchemaDatex2TrafficData1() throws UnsupportedEncodingException {
-        XmlParser parser = new XmlParser("elaboratedData");
-
-        List<byte[]> event = getEventSchemaTest2();
-
-        EventSchema eventSchema = parser.getEventSchema(event);
-
-        assertEquals(7, ((EventPropertyNested) ((EventPropertyNested) eventSchema.getEventProperties().get(0))
-                .getEventProperties().get(0)).getEventProperties().size());
-
-    }
-    */
-
-    /*
-
-    @Test
-    public void getSchemaDatex2TrafficData2() throws UnsupportedEncodingException {
-        XmlParser parser = new XmlParser("elaboratedData");
-
-        List<byte[]> event = getEventSchemaTest3();
-
-        EventSchema eventSchema = parser.getEventSchema(event);
-
-        assertEquals(5, ((EventPropertyNested) ((EventPropertyNested) eventSchema.getEventProperties().get(0))
-                .getEventProperties().get(0)).getEventProperties().size());
-
-    }
-    */
-
   private InputStream getInputStream(String s) {
     return IOUtils.toInputStream(s, "UTF-8");
   }
 
+  @SuppressWarnings("checkstyle:LineLength")
   private String getCarParkExample() {
-    return "<?xml version=\"1.0\" encoding=\"iso-8859-1\"?>\n"
-           + "<parkhaeuser xmlns:msdata=\"urn:schemas-microsoft-com:xml-msdata\" "
-           + "xmlns:xsi=\"http://www.w3.org/2001/XMLSchema-instance\">\n"
-           + "    <parkhaus>\n" + "        <lfdnr>1</lfdnr>\n" + "        <bezeichnung>bahnhof.txt</bezeichnung>\n"
-           + "        <gesamt>114</gesamt>\n" + "        <frei>000</frei>\n" + "        <status>1</status>\n"
-           + "        <zeitstempel>25.07.2018 10:45</zeitstempel>\n" + "        <tendenz>3</tendenz>\n"
-           + "    </parkhaus>\n" + "    <parkhaus>\n" + "        <lfdnr>2</lfdnr>\n"
-           + "        <bezeichnung>beethoven.txt</bezeichnung>\n" + "        <gesamt>416</gesamt>\n"
-           + "        <frei>150</frei>\n" + "        <status>0</status>\n"
-           + "        <zeitstempel>25.07.2018 10:45</zeitstempel>\n" + "        <tendenz>3</tendenz>\n"
-           + "    </parkhaus>\n" + "    <parkhaus>\n" + "        <lfdnr>3</lfdnr>\n"
-           + "        <bezeichnung>friedensplatz.txt</bezeichnung>\n" + "        <gesamt>810</gesamt>\n"
-           + "        <frei>295</frei>\n" + "        <status>0</status>\n"
-           + "        <zeitstempel>25.07.2018 10:45</zeitstempel>\n" + "        <tendenz>1</tendenz>\n"
-           + "    </parkhaus>\n" + "    <parkhaus>\n" + "        <lfdnr>4</lfdnr>\n"
-           + "        <bezeichnung>markt.txt</bezeichnung>\n" + "        <gesamt>305</gesamt>\n"
-           + "        <frei>043</frei>\n" + "        <status>0</status>\n"
-           + "        <zeitstempel>25.07.2018 10:45</zeitstempel>\n" + "        <tendenz>3</tendenz>\n"
-           + "    </parkhaus>\n" + "    <parkhaus>\n" + "        <lfdnr>5</lfdnr>\n"
-           + "        <bezeichnung>muensterplatz.txt</bezeichnung>\n" + "        <gesamt>312</gesamt>\n"
-           + "        <frei>069</frei>\n" + "        <status>0</status>\n"
-           + "        <zeitstempel>25.07.2018 10:45</zeitstempel>\n" + "        <tendenz>1</tendenz>\n"
-           + "    </parkhaus>\n" + "    <parkhaus>\n" + "        <lfdnr>6</lfdnr>\n"
-           + "        <bezeichnung>stadthaus.txt</bezeichnung>\n" + "        <gesamt>320</gesamt>\n"
-           + "        <frei>000</frei>\n" + "        <status>1</status>\n"
-           + "        <zeitstempel>25.07.2018 10:45</zeitstempel>\n" + "        <tendenz>3</tendenz>\n"
-           + "    </parkhaus>\n" + "</parkhaeuser>";
+    return """
+        <?xml version="1.0" encoding="iso-8859-1"?>
+        <parkhaeuser xmlns:msdata="urn:schemas-microsoft-com:xml-msdata" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+            <parkhaus>
+                <lfdnr>1</lfdnr>
+                <bezeichnung>bahnhof.txt</bezeichnung>
+                <gesamt>114</gesamt>
+                <frei>000</frei>
+                <status>1</status>
+                <zeitstempel>25.07.2018 10:45</zeitstempel>
+                <tendenz>3</tendenz>
+            </parkhaus>
+            <parkhaus>
+                <lfdnr>2</lfdnr>
+                <bezeichnung>beethoven.txt</bezeichnung>
+                <gesamt>416</gesamt>
+                <frei>150</frei>
+                <status>0</status>
+                <zeitstempel>25.07.2018 10:45</zeitstempel>
+                <tendenz>3</tendenz>
+            </parkhaus>
+            <parkhaus>
+                <lfdnr>3</lfdnr>
+                <bezeichnung>friedensplatz.txt</bezeichnung>
+                <gesamt>810</gesamt>
+                <frei>295</frei>
+                <status>0</status>
+                <zeitstempel>25.07.2018 10:45</zeitstempel>
+                <tendenz>1</tendenz>
+            </parkhaus>
+            <parkhaus>
+                <lfdnr>4</lfdnr>
+                <bezeichnung>markt.txt</bezeichnung>
+                <gesamt>305</gesamt>
+                <frei>043</frei>
+                <status>0</status>
+                <zeitstempel>25.07.2018 10:45</zeitstempel>
+                <tendenz>3</tendenz>
+            </parkhaus>
+            <parkhaus>
+                <lfdnr>5</lfdnr>
+                <bezeichnung>muensterplatz.txt</bezeichnung>
+                <gesamt>312</gesamt>
+                <frei>069</frei>
+                <status>0</status>
+                <zeitstempel>25.07.2018 10:45</zeitstempel>
+                <tendenz>1</tendenz>
+            </parkhaus>
+            <parkhaus>
+                <lfdnr>6</lfdnr>
+                <bezeichnung>stadthaus.txt</bezeichnung>
+                <gesamt>320</gesamt>
+                <frei>000</frei>
+                <status>1</status>
+                <zeitstempel>25.07.2018 10:45</zeitstempel>
+                <tendenz>3</tendenz>
+            </parkhaus>
+        </parkhaeuser>""";
   }
 
+  @SuppressWarnings({"checkstyle:LineLength"})
   private String getDatex2ParkingFacilityStatus() {
-    return "<?xml version=\"1.0\" encoding=\"UTF-8\" standalone=\"yes\"?>\n"
-           + "<d2LogicalModel modelBaseVersion=\"2\" extensionName=\"MDM\" "
-           + "extensionVersion=\"00-01-03\" xmlns:xsi=\"http://www.w3.org/2001/XMLSchema-instance\" "
-           + "xsi:schemaLocation=\"http://datex2.eu/schema/2/2_0 "
-           + "http://bast.s3.amazonaws.com/schema/1385369839450/MDM-Profile_ParkingFacilityStatus.xsd\" "
-           + "xmlns=\"http://datex2.eu/schema/2/2_0\">\n"
-           + "    <exchange>\n" + "        <supplierIdentification>\n" + "            <country>de</country>\n"
-           + "            <nationalIdentifier>DE-MDM-Kassel</nationalIdentifier>\n"
-           + "        </supplierIdentification>\n"
-           + "    </exchange>\n"
-           + "    <payloadPublication xsi:type=\"GenericPublication\" lang=\"de\" "
-           + "xmlns:xsi=\"http://www.w3.org/2001/XMLSchema-instance\">\n"
-           + "        <publicationTime>2018-07-25T13:17:16.776+02:00</publicationTime>\n"
-           + "        <publicationCreator>\n" + "            <country>de</country>\n"
-           + "            <nationalIdentifier>DE-MDM-Kassel</nationalIdentifier>\n" + "        </publicationCreator>\n"
-           + "        <genericPublicationName>ParkingFacilityTableStatusPublication</genericPublicationName>\n"
-           + "        <genericPublicationExtension>\n" + "            <parkingFacilityTableStatusPublication>\n"
-           + "                <headerInformation>\n"
-           + "                    <confidentiality>noRestriction</confidentiality>\n"
-           + "                    <informationStatus>real</informationStatus>\n"
-           + "                </headerInformation>\n"
-           + "                <parkingAreaStatus>\n"
-           + "                    <parkingAreaOccupancy>0.6244076</parkingAreaOccupancy>\n"
-           + "                    <parkingAreaReference targetClass=\"ParkingArea\" id=\"1001[Stadtmitte]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingAreaStatusTime>2018-07-25T13:17:00.087+02:00</parkingAreaStatusTime>\n"
-           + "                    <parkingAreaTotalNumberOfVacantParkingSpaces>1268"
-           + "</parkingAreaTotalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityLongTermOverride>3376</totalParkingCapacityLongTermOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>3376</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingAreaStatus>\n" + "                <parkingAreaStatus>\n"
-           + "                    <parkingAreaOccupancy>0.37333333</parkingAreaOccupancy>\n"
-           + "                    <parkingAreaReference targetClass=\"ParkingArea\" "
-           + "id=\"1002[Bhf. Wilhelmsh&#xf6;he]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingAreaStatusTime>2018-07-25T13:17:00.087+02:00</parkingAreaStatusTime>\n"
-           + "                    <parkingAreaTotalNumberOfVacantParkingSpaces>94"
-           + "</parkingAreaTotalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityLongTermOverride>150</totalParkingCapacityLongTermOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>150</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingAreaStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.5590909</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"7[City Point]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>123</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>97</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>220</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>220</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>1.0</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"6[Theaterplatz]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>statusUnknown</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>228</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>0</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>228</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>228</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.6989796</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"1[Friedrichsplatz]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>685</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>295</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>980</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>980</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.3416149</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" "
-           + "id=\"4[Wilhelmsstra&#xdf;e]\" version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>110</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>212</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>322</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>322</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.31129032</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" "
-           + "id=\"2[Kurf&#xfc;rsten Galerie]\" version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>193</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>427</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>620</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>620</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>1.0</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"5[Rathaus]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>closed</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>298</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>0</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>298</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>298</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.48085105</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"10[Galeria Kaufhof]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>113</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>122</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>235</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>235</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.19469027</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" "
-           + "id=\"9[Martinskirche]\" version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>22</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>91</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>113</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>113</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.93333334</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"3[Garde-du-Corps]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>336</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>24</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>360</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>360</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "                <parkingFacilityStatus>\n"
-           + "                    <parkingFacilityOccupancy>0.37333333</parkingFacilityOccupancy>\n"
-           + "                    <parkingFacilityReference targetClass=\"ParkingFacility\" id=\"8[Atrium]\" "
-           + "version=\"1.0\"/>\n"
-           + "                    <parkingFacilityStatus>open</parkingFacilityStatus>\n"
-           + "                    <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00"
-           + "</parkingFacilityStatusTime>\n"
-           + "                    <totalNumberOfOccupiedParkingSpaces>56</totalNumberOfOccupiedParkingSpaces>\n"
-           + "                    <totalNumberOfVacantParkingSpaces>94</totalNumberOfVacantParkingSpaces>\n"
-           + "                    <totalParkingCapacityOverride>150</totalParkingCapacityOverride>\n"
-           + "                    <totalParkingCapacityShortTermOverride>150</totalParkingCapacityShortTermOverride>\n"
-           + "                </parkingFacilityStatus>\n" + "            </parkingFacilityTableStatusPublication>\n"
-           + "        </genericPublicationExtension>\n" + "    </payloadPublication>\n" + "</d2LogicalModel>";
+    return """
+        <?xml version="1.0" encoding="UTF-8" standalone="yes"?>
+        <d2LogicalModel modelBaseVersion="2" extensionName="MDM" extensionVersion="00-01-03" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://datex2.eu/schema/2/2_0 http://bast.s3.amazonaws.com/schema/1385369839450/MDM-Profile_ParkingFacilityStatus.xsd" xmlns="http://datex2.eu/schema/2/2_0">
+            <exchange>
+                <supplierIdentification>
+                    <country>de</country>
+                    <nationalIdentifier>DE-MDM-Kassel</nationalIdentifier>
+                </supplierIdentification>
+            </exchange>
+            <payloadPublication xsi:type="GenericPublication" lang="de" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+                <publicationTime>2018-07-25T13:17:16.776+02:00</publicationTime>
+                <publicationCreator>
+                    <country>de</country>
+                    <nationalIdentifier>DE-MDM-Kassel</nationalIdentifier>
+                </publicationCreator>
+                <genericPublicationName>ParkingFacilityTableStatusPublication</genericPublicationName>
+                <genericPublicationExtension>
+                    <parkingFacilityTableStatusPublication>
+                        <headerInformation>
+                            <confidentiality>noRestriction</confidentiality>
+                            <informationStatus>real</informationStatus>
+                        </headerInformation>
+                        <parkingAreaStatus>
+                            <parkingAreaOccupancy>0.6244076</parkingAreaOccupancy>
+                            <parkingAreaReference targetClass="ParkingArea" id="1001[Stadtmitte]" version="1.0"/>
+                            <parkingAreaStatusTime>2018-07-25T13:17:00.087+02:00</parkingAreaStatusTime>
+                            <parkingAreaTotalNumberOfVacantParkingSpaces>1268</parkingAreaTotalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityLongTermOverride>3376</totalParkingCapacityLongTermOverride>
+                            <totalParkingCapacityShortTermOverride>3376</totalParkingCapacityShortTermOverride>
+                        </parkingAreaStatus>
+                        <parkingAreaStatus>
+                            <parkingAreaOccupancy>0.37333333</parkingAreaOccupancy>
+                            <parkingAreaReference targetClass="ParkingArea" id="1002[Bhf. Wilhelmsh&#xf6;he]" version="1.0"/>
+                            <parkingAreaStatusTime>2018-07-25T13:17:00.087+02:00</parkingAreaStatusTime>
+                            <parkingAreaTotalNumberOfVacantParkingSpaces>94</parkingAreaTotalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityLongTermOverride>150</totalParkingCapacityLongTermOverride>
+                            <totalParkingCapacityShortTermOverride>150</totalParkingCapacityShortTermOverride>
+                        </parkingAreaStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.5590909</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="7[City Point]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>123</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>97</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>220</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>220</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>1.0</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="6[Theaterplatz]" version="1.0"/>
+                            <parkingFacilityStatus>statusUnknown</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>228</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>0</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>228</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>228</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.6989796</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="1[Friedrichsplatz]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>685</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>295</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>980</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>980</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.3416149</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="4[Wilhelmsstra&#xdf;e]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>110</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>212</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>322</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>322</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.31129032</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="2[Kurf&#xfc;rsten Galerie]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>193</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>427</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>620</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>620</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>1.0</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="5[Rathaus]" version="1.0"/>
+                            <parkingFacilityStatus>closed</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>298</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>0</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>298</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>298</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.48085105</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="10[Galeria Kaufhof]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>113</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>122</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>235</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>235</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.19469027</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="9[Martinskirche]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>22</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>91</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>113</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>113</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.93333334</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="3[Garde-du-Corps]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>336</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>24</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>360</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>360</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                        <parkingFacilityStatus>
+                            <parkingFacilityOccupancy>0.37333333</parkingFacilityOccupancy>
+                            <parkingFacilityReference targetClass="ParkingFacility" id="8[Atrium]" version="1.0"/>
+                            <parkingFacilityStatus>open</parkingFacilityStatus>
+                            <parkingFacilityStatusTime>2018-07-25T13:17:00.087+02:00</parkingFacilityStatusTime>
+                            <totalNumberOfOccupiedParkingSpaces>56</totalNumberOfOccupiedParkingSpaces>
+                            <totalNumberOfVacantParkingSpaces>94</totalNumberOfVacantParkingSpaces>
+                            <totalParkingCapacityOverride>150</totalParkingCapacityOverride>
+                            <totalParkingCapacityShortTermOverride>150</totalParkingCapacityShortTermOverride>
+                        </parkingFacilityStatus>
+                    </parkingFacilityTableStatusPublication>
+                </genericPublicationExtension>
+            </payloadPublication>
+        </d2LogicalModel>""";
   }
 
   private String getEventSchemaTest() {
@@ -310,92 +299,4 @@ public class XmlTest {
            + "\"parkingFacilityStatusTime\":\"2018-07-25T13:17:00.087+02:00\",\"parkingFacilityOccupancy\":0.5590909}";
   }
 
-  private List<byte[]> getEventSchemaTest2() throws UnsupportedEncodingException {
-    List<byte[]> list = new ArrayList();
-
-    String dataone =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":12},\"pertinentLocation\":{\"xsi:type\":"
-        + "\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\",\"id\":"
-        + "\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":"
-        + "\"car\"}}}}";
-    String datatwo =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":1},\"pertinentLocation\":{\"xsi:type\":"
-        + "\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\",\"id\":"
-        + "\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":"
-        + "\"lorry\"}}}}";
-    String datathree =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"percentageLongVehicles\":{\"percentage\":7},\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{"
-        + "\"vehicleFlowRate"
-        + "\":13},\"pertinentLocation\":{\"xsi:type\":\"LocationByReference\",\"predefinedLocationReference\":{"
-        + "\"targetClass\":\"PredefinedLocation\",\"id\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},"
-        + "\"forVehiclesWithCharacteristicsOf\":{\"vehicleType\":\"anyVehicle\"}}}}";
-    String datafour =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"averageVehicleSpeed\":{\"speed\":44},\"xsi:type\":\"TrafficSpeed\",\"pertinentLocation\":{\"xsi:type"
-        + "\":\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\",\"id"
-        + "\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":\"car\"}}}}\"\n";
-    String datafive =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"averageVehicleSpeed\":{\"speed\":29},\"xsi:type\":\"TrafficSpeed\",\"pertinentLocation\":{\"xsi:type\":"
-        + "\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\",\"id\":"
-        + "\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{\"vehicleType"
-        + "\":\"lorry\"}}}}";
-
-    list.add(dataone.getBytes("UTF-8"));
-    list.add(datatwo.getBytes("UTF-8"));
-    list.add(datathree.getBytes("UTF-8"));
-    list.add(datafour.getBytes("UTF-8"));
-    list.add(datafive.getBytes("UTF-8"));
-
-    return list;
-  }
-
-  private List<byte[]> getEventSchemaTest3() throws UnsupportedEncodingException {
-    List<byte[]> list = new ArrayList();
-
-    String dataone =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":12},\"pertinentLocation\":{\"xsi:type"
-        + "\":\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\",\"id"
-        + "\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":\"car\"}}}}";
-    String datatwo =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00"
-        + "\",\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":12},\"pertinentLocation\":{"
-        + "\"xsi:type\":\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation"
-        + "\",\"id\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":\"car\"}}}}";
-    String datathree =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":12},\"pertinentLocation\":{\"xsi:type"
-        + "\":\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\","
-        + "\"id\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":\"car\"}}}}";
-    String datafour =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":12},\"pertinentLocation\":{\"xsi:type"
-        + "\":\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation\",\"id"
-        + "\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":\"car\"}}}}";
-    String datafive =
-        "{\"elaboratedData\":{\"basicData\":{\"measurementOrCalculationTime\":\"2018-07-25T16:21:27.365+02:00\","
-        + "\"xsi:type\":\"TrafficFlow\",\"vehicleFlow\":{\"vehicleFlowRate\":12},\"pertinentLocation\":{"
-        + "\"xsi:type\":\"LocationByReference\",\"predefinedLocationReference\":{\"targetClass\":\"PredefinedLocation"
-        + "\",\"id\":\"fs.MQ_555.050_AB_SW_R_1\",\"version\":201610261425}},\"forVehiclesWithCharacteristicsOf\":{"
-        + "\"vehicleType\":\"car\"}}}}";
-
-    list.add(dataone.getBytes(StandardCharsets.UTF_8));
-    list.add(datatwo.getBytes(StandardCharsets.UTF_8));
-    list.add(datathree.getBytes(StandardCharsets.UTF_8));
-    list.add(datafour.getBytes(StandardCharsets.UTF_8));
-    list.add(datafive.getBytes(StandardCharsets.UTF_8));
-
-    return list;
-  }
 }
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/CreateNestedTransformationRuleTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/CreateNestedTransformationRuleTest.java
index 5d7abe525..447324390 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/CreateNestedTransformationRuleTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/CreateNestedTransformationRuleTest.java
@@ -29,6 +29,7 @@ import java.util.Map;
 
 import static org.junit.Assert.assertEquals;
 
+@SuppressWarnings("unchecked")
 public class CreateNestedTransformationRuleTest {
 
   @Test
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/DeleteTransformationRuleTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/DeleteTransformationRuleTest.java
index 6205263cf..0fbbbf9ec 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/DeleteTransformationRuleTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/DeleteTransformationRuleTest.java
@@ -24,6 +24,7 @@ import org.junit.Test;
 
 import java.util.Arrays;
 import java.util.HashMap;
+import java.util.List;
 import java.util.Map;
 
 import static org.junit.Assert.assertEquals;
@@ -35,7 +36,7 @@ public class DeleteTransformationRuleTest {
     Map<String, Object> event = new HashMap<>();
     event.put("key", "value");
 
-    DeleteTransformationRule deleteRule = new DeleteTransformationRule(Arrays.asList("key"));
+    DeleteTransformationRule deleteRule = new DeleteTransformationRule(List.of("key"));
 
     Map<String, Object> result = deleteRule.transform(event);
 
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/MoveTransformationRuleTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/MoveTransformationRuleTest.java
index 063827c2b..41076ee6b 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/MoveTransformationRuleTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/MoveTransformationRuleTest.java
@@ -30,6 +30,7 @@ import java.util.Map;
 
 import static org.junit.Assert.assertEquals;
 
+@SuppressWarnings("unchecked")
 public class MoveTransformationRuleTest {
 
   @Test
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/RenameTransformationRuleTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/RenameTransformationRuleTest.java
index 583e9abbf..38f6f94e5 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/RenameTransformationRuleTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/RenameTransformationRuleTest.java
@@ -47,6 +47,7 @@ public class RenameTransformationRuleTest {
   }
 
   @Test
+  @SuppressWarnings("unchecked")
   public void renameNested() {
     Map<String, Object> nestedEvent = new HashMap<>();
     nestedEvent.put("old_key", "test");
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/SchemaEventTransformerTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/SchemaEventTransformerTest.java
index 5bd619e03..c02f45716 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/SchemaEventTransformerTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/schema/SchemaEventTransformerTest.java
@@ -28,7 +28,6 @@ import org.apache.streampipes.extensions.management.connect.adapter.preprocessin
 import org.junit.Test;
 
 import java.util.ArrayList;
-import java.util.Arrays;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
@@ -39,17 +38,18 @@ import static org.junit.Assert.assertTrue;
 public class SchemaEventTransformerTest {
 
   @Test
+  @SuppressWarnings("unchecked")
   public void transform() {
     Map<String, Object> event = getFirstEvent();
 
     List<TransformationRule> rules = new ArrayList<>();
-    rules.add(new RenameTransformationRule(Arrays.asList("a"), "a1"));
-    rules.add(new RenameTransformationRule(Arrays.asList("b"), "b1"));
-    rules.add(new RenameTransformationRule(Arrays.asList("c"), "c1"));
-    rules.add(new RenameTransformationRule(Arrays.asList("c1", "d"), "d1"));
-    rules.add(new CreateNestedTransformationRule(Arrays.asList("c1", "f")));
-    rules.add(new MoveTransformationRule(Arrays.asList("b1"), Arrays.asList("c1", "f")));
-    rules.add(new DeleteTransformationRule(Arrays.asList("e")));
+    rules.add(new RenameTransformationRule(List.of("a"), "a1"));
+    rules.add(new RenameTransformationRule(List.of("b"), "b1"));
+    rules.add(new RenameTransformationRule(List.of("c"), "c1"));
+    rules.add(new RenameTransformationRule(List.of("c1", "d"), "d1"));
+    rules.add(new CreateNestedTransformationRule(List.of("c1", "f")));
+    rules.add(new MoveTransformationRule(List.of("b1"), List.of("c1", "f")));
+    rules.add(new DeleteTransformationRule(List.of("e")));
 
     SchemaEventTransformer eventTransformer = new SchemaEventTransformer(rules);
 
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/TimestampTransformRuleTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/TimestampTransformRuleTest.java
deleted file mode 100644
index cc4c5c264..000000000
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/TimestampTransformRuleTest.java
+++ /dev/null
@@ -1,244 +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.streampipes.extensions.management.connect.adapter.transform.value;
-
-public class TimestampTransformRuleTest {
-
-//    @Test
-//    public void transformListFormatString() {
-//        EventSchema eventSchema = new EventSchema();
-//        EventPropertyList eventPropertyList = new EventPropertyList();
-//        eventPropertyList.setRuntimeName("list");
-//        EventProperty eventPropertyValue = new EventPropertyPrimitive();
-//        eventPropertyValue.setLabel("value");
-//        eventPropertyValue.setRuntimeName("value");
-//        eventPropertyList.setEventProperty(eventPropertyValue);
-//        eventSchema.setEventProperties(Collections.singletonList(eventPropertyList));
-//
-//        Map<String, Object> event = new HashMap<>();
-//        Map<String, Object> subEvent = new HashMap<>();
-//        subEvent.put("value", "2019-03-11T20:50:38.138Z");
-//        event.put("list",subEvent);
-//
-//        List<String> keys = new ArrayList<>();
-//        keys.add("list");
-//        keys.add("value");
-//
-//        TimestampTranformationRule timestampTranformationRule = new TimestampTranformationRule(keys,
-//                TimestampTranformationRuleMode.FORMAT_STRING, "yyyy-MM-dd'T'HH:mm:ss.SSS'Z'", 1000);
-//
-//        Map result = timestampTranformationRule.transform(event);
-//
-//        assertEquals(1, result.keySet().size());
-//        assertEquals( 1552333838138L, ((Map) result.get(eventPropertyList.getRuntimeName())).
-//        get(eventPropertyValue.getRuntimeName()));
-//    }
-
-//    @Test
-//    public void transformListTimeUnit() {
-//        EventSchema eventSchema = new EventSchema();
-//        EventPropertyList eventPropertyList = new EventPropertyList();
-//        eventPropertyList.setRuntimeName("list");
-//        EventProperty eventPropertyValue = new EventPropertyPrimitive();
-//        eventPropertyValue.setLabel("value");
-//        eventPropertyValue.setRuntimeName("value");
-//        eventPropertyList.setEventProperty(eventPropertyValue);
-//        eventSchema.setEventProperties(Collections.singletonList(eventPropertyList));
-//
-//        Map<String, Object> event = new HashMap<>();
-//        Map<String, Object> subEvent = new HashMap<>();
-//        subEvent.put("value", 1552380411);
-//        event.put("list",subEvent);
-//
-//        List<String> keys = new ArrayList<>();
-//        keys.add("list");
-//        keys.add("value");
-//
-//        TimestampTranformationRule timestampTranformationRule = new TimestampTranformationRule(keys,
-//                TimestampTranformationRuleMode.TIME_UNIT, "yyyy-MM-dd'T'HH:mm:ss.SSS'Z'", 1000);
-//
-//        Map result = timestampTranformationRule.transform(event);
-//
-//        assertEquals(1, result.keySet().size());
-//        assertEquals( 1552380411000L, ((Map) result.get(eventPropertyList.getRuntimeName())).
-//        get(eventPropertyValue.getRuntimeName()));
-//
-//    }
-//
-//
-//    @Test
-//    public void transformNestedFormatString() {
-//        EventSchema eventSchema = new EventSchema();
-//        EventPropertyNested eventPropertyMainKey = new EventPropertyNested();
-//        eventPropertyMainKey.setLabel("mainKey");
-//        eventPropertyMainKey.setRuntimeName("mainKey");
-//        EventProperty eventPropertyValue = new EventPropertyPrimitive();
-//        eventPropertyValue.setLabel("value");
-//        eventPropertyValue.setRuntimeName("value");
-//        eventPropertyMainKey.setEventProperties(Collections.singletonList(eventPropertyValue));
-//        eventSchema.setEventProperties(Collections.singletonList(eventPropertyMainKey));
-//
-//        Map<String, Object> event = new HashMap<>();
-//        Map<String, Object> subEvent = new HashMap<>();
-//        subEvent.put("value", "2009-12-31");
-//        event.put("mainKey",subEvent);
-//
-//        List<String> keys = new ArrayList<>();
-//        keys.add("mainKey");
-//        keys.add("value");
-//
-//
-//        TimestampTranformationRule timestampTranformationRule = new TimestampTranformationRule(keys,
-//                TimestampTranformationRuleMode.FORMAT_STRING, "yyyy-MM-dd", 1000);
-//
-//        Map result = timestampTranformationRule.transform(event);
-//
-//        assertEquals(1, result.keySet().size());
-//        assertEquals(1262214000000L, ((Map) result.get(eventPropertyMainKey.getRuntimeName())).
-//        get(eventPropertyValue.getRuntimeName()));
-//
-//    }
-//
-//    @Test
-//    public void transformNestedTimeUnit() {
-//        EventSchema eventSchema = new EventSchema();
-//        EventPropertyNested eventPropertyMainKey = new EventPropertyNested();
-//        eventPropertyMainKey.setLabel("mainKey");
-//        eventPropertyMainKey.setRuntimeName("mainKey");
-//        EventProperty eventPropertyValue = new EventPropertyPrimitive();
-//        eventPropertyValue.setLabel("value");
-//        eventPropertyValue.setRuntimeName("value");
-//        eventPropertyMainKey.setEventProperties(Collections.singletonList(eventPropertyValue));
-//        eventSchema.setEventProperties(Collections.singletonList(eventPropertyMainKey));
-//
-//        Map<String, Object> event = new HashMap<>();
-//        Map<String, Object> subEvent = new HashMap<>();
-//        subEvent.put("value", 1262214000);
-//        event.put("mainKey",subEvent);
-//
-//        List<String> keys = new ArrayList<>();
-//        keys.add("mainKey");
-//        keys.add("value");
-//
-//
-//        TimestampTranformationRule timestampTranformationRule = new TimestampTranformationRule(keys,
-//                TimestampTranformationRuleMode.TIME_UNIT, "yyyy-MM-dd", 1000);
-//
-//        Map result = timestampTranformationRule.transform(event);
-//
-//        assertEquals(1, result.keySet().size());
-//        assertEquals(1262214000000L, ((Map) result.get(eventPropertyMainKey.getRuntimeName())).
-//        get(eventPropertyValue.getRuntimeName()));
-//
-//    }
-//
-//
-//    @Test
-//    public void transformMultiEventFormatString() {
-//        EventSchema eventSchema = new EventSchema();
-//        EventProperty eventPropertyValue1 = new EventPropertyPrimitive();
-//        eventPropertyValue1.setLabel("value1");
-//        eventPropertyValue1.setRuntimeName("value1");
-//        EventProperty eventPropertyValue2 = new EventPropertyPrimitive();
-//        eventPropertyValue2.setLabel("value2");
-//        eventPropertyValue2.setRuntimeName("value2");
-//        eventSchema.addEventProperty(eventPropertyValue1);
-//        eventSchema.addEventProperty(eventPropertyValue2);
-//
-//        List<String> keys = new ArrayList<>();
-//        keys.add("value2");
-//
-//
-//        TimestampTranformationRule timestampTranformationRule = new TimestampTranformationRule(keys,
-//                TimestampTranformationRuleMode.FORMAT_STRING, "yyyy-MM-dd HH:mm:ss", 1000);
-//
-//        Map<String, Object> event = new HashMap<>();
-//        event.put("value1", 0.0);
-//        event.put("value2", "2019-03-15 10:00:00");
-//
-//        Map result = timestampTranformationRule.transform(event);
-//        assertEquals(2, result.keySet().size());
-//        assertEquals(1552640400000L, result.get(eventPropertyValue2.getLabel()));
-//
-//
-//        event = new HashMap<>();
-//        event.put("value1", 20.0);
-//        event.put("value2", "2019-03-15 15:23:00");
-//
-//        result = timestampTranformationRule.transform(event);
-//        assertEquals(2, result.keySet().size());
-//        assertEquals(1552659780000L, result.get(eventPropertyValue2.getRuntimeName()));
-//
-//
-//        event = new HashMap<>();
-//        event.put("value1", 0.0);
-//        event.put("value2", "2027-012-15 21:53:50");
-//
-//        result = timestampTranformationRule.transform(event);
-//        assertEquals(2, result.keySet().size());
-//        assertEquals(1828904030000L, result.get(eventPropertyValue2.getRuntimeName()));
-//    }
-//
-//    @Test
-//    public void transformMultiEventTimeUnit() {
-//        EventSchema eventSchema = new EventSchema();
-//        EventProperty eventPropertyValue1 = new EventPropertyPrimitive();
-//        eventPropertyValue1.setLabel("value1");
-//        eventPropertyValue1.setRuntimeName("value1");
-//        EventProperty eventPropertyValue2 = new EventPropertyPrimitive();
-//        eventPropertyValue2.setLabel("value2");
-//        eventPropertyValue2.setRuntimeName("value2");
-//        eventSchema.addEventProperty(eventPropertyValue1);
-//        eventSchema.addEventProperty(eventPropertyValue2);
-//
-//        List<String> keys = new ArrayList<>();
-//        keys.add("value2");
-//
-//
-//        TimestampTranformationRule timestampTranformationRule = new TimestampTranformationRule(keys,
-//                TimestampTranformationRuleMode.TIME_UNIT, "yyyy-MM-dd HH:mm:ss", 1000);
-//
-//        Map<String, Object> event = new HashMap<>();
-//        event.put("value1", 0.0);
-//        event.put("value2", 1552640400);
-//
-//        Map result = timestampTranformationRule.transform(event);
-//        assertEquals(2, result.keySet().size());
-//        assertEquals(1552640400000L, result.get(eventPropertyValue2.getLabel()));
-//
-//
-//        event = new HashMap<>();
-//        event.put("value1", 20.0);
-//        event.put("value2", 1552659780);
-//
-//        result = timestampTranformationRule.transform(event);
-//        assertEquals(2, result.keySet().size());
-//        assertEquals(1552659780000L, result.get(eventPropertyValue2.getRuntimeName()));
-//
-//
-//        event = new HashMap<>();
-//        event.put("value1", 0.0);
-//        event.put("value2", 1828904030);
-//
-//        result = timestampTranformationRule.transform(event);
-//        assertEquals(2, result.keySet().size());
-//        assertEquals(1828904030000L, result.get(eventPropertyValue2.getRuntimeName()));
-//    }
-
-}
diff --git a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/UnitTransformRuleTest.java b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/UnitTransformRuleTest.java
index 9102efb33..53893b67a 100644
--- a/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/UnitTransformRuleTest.java
+++ b/streampipes-extensions-management/src/test/java/org/apache/streampipes/extensions/management/connect/adapter/transform/value/UnitTransformRuleTest.java
@@ -35,6 +35,7 @@ import java.util.Map;
 
 import static org.junit.Assert.assertEquals;
 
+@SuppressWarnings("unchecked")
 public class UnitTransformRuleTest {
 
   @Test
@@ -60,11 +61,12 @@ public class UnitTransformRuleTest {
     UnitTransformationRule unitTransformationRule = new UnitTransformationRule(keys,
         "http://qudt.org/vocab/unit#DegreeCelsius", "http://qudt.org/vocab/unit#Kelvin");
 
-    Map result = unitTransformationRule.transform(event);
+    var result = unitTransformationRule.transform(event);
 
     assertEquals(1, result.keySet().size());
     assertEquals(273.15,
-        ((Map) result.get(eventPropertyList.getRuntimeName())).get(eventPropertyValue.getRuntimeName()));
+        ((Map<String, Object>) result.get(eventPropertyList.getRuntimeName()))
+            .get(eventPropertyValue.getRuntimeName()));
   }
 
 
@@ -92,11 +94,12 @@ public class UnitTransformRuleTest {
     UnitTransformationRule unitTransformationRule = new UnitTransformationRule(keys,
         "http://qudt.org/vocab/unit#DegreeCelsius", "http://qudt.org/vocab/unit#Kelvin");
 
-    Map result = unitTransformationRule.transform(event);
+    var result = unitTransformationRule.transform(event);
 
     assertEquals(1, result.keySet().size());
     assertEquals(283.15,
-        ((Map) result.get(eventPropertyMainKey.getRuntimeName())).get(eventPropertyValue.getRuntimeName()));
+        ((Map<String, Object>) result.get(eventPropertyMainKey.getRuntimeName()))
+            .get(eventPropertyValue.getRuntimeName()));
   }
 
 
@@ -121,7 +124,7 @@ public class UnitTransformRuleTest {
     event.put("value1", 0.0);
     event.put("value2", 10.0);
 
-    Map result = unitTransformationRule.transform(event);
+    var result = unitTransformationRule.transform(event);
     assertEquals(2, result.keySet().size());
     assertEquals(283.15, result.get(eventPropertyValue2.getLabel()));
 
diff --git a/streampipes-extensions/streampipes-processors-aggregation-flink/pom.xml b/streampipes-extensions/streampipes-processors-aggregation-flink/pom.xml
index c6bc7aa90..ff25119f8 100644
--- a/streampipes-extensions/streampipes-processors-aggregation-flink/pom.xml
+++ b/streampipes-extensions/streampipes-processors-aggregation-flink/pom.xml
@@ -84,31 +84,6 @@
 
 
         <!-- Test dependencies -->
-        <dependency>
-            <groupId>io.flinkspector</groupId>
-            <artifactId>flinkspector-datastream_2.11</artifactId>
-            <scope>test</scope>
-            <exclusions>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-runtime_2.11</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-streaming-java_2.11</artifactId>
-                </exclusion>
-            </exclusions>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.flink</groupId>
-            <artifactId>flink-test-utils_2.11</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.flink</groupId>
-            <artifactId>flink-runtime_2.11</artifactId>
-            <type>test-jar</type>
-        </dependency>
         <dependency>
             <groupId>org.apache.streampipes</groupId>
             <artifactId>streampipes-test-utils</artifactId>
diff --git a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/aggregation/AggregationTestData.java b/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/aggregation/AggregationTestData.java
deleted file mode 100644
index e29b16481..000000000
--- a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/aggregation/AggregationTestData.java
+++ /dev/null
@@ -1,67 +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.streampipes.processors.aggregation.flink.processor.aggregation;
-
-import org.apache.streampipes.model.runtime.Event;
-
-import java.util.ArrayList;
-import java.util.List;
-
-public class AggregationTestData {
-
-  private List<Event> expectedOutput;
-  private List<Event> input;
-
-  public AggregationTestData() {
-    buildOutput();
-    buildInput();
-  }
-
-  private void buildOutput() {
-    this.expectedOutput = new ArrayList<>();
-    this.expectedOutput.add(buildOutputMap(1.0f, 1.0f));
-    this.expectedOutput.add(buildOutputMap(2.0f, 1.5f));
-  }
-
-  private void buildInput() {
-    this.input = new ArrayList<>();
-    input.add(buildEvent(1.0f));
-    input.add(buildEvent(2.0f));
-  }
-
-  private Event buildOutputMap(Float value, Float aggregatedValue) {
-    Event event = buildEvent(value);
-    event.addField("aggregatedValue", aggregatedValue);
-    return event;
-  }
-
-  private Event buildEvent(Float value) {
-    Event event = new Event();
-    event.addField("sensorId", "a");
-    event.addField("value", value);
-    return event;
-  }
-
-  public List<Event> getExpectedOutput() {
-    return expectedOutput;
-  }
-
-  public List<Event> getInput() {
-    return input;
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/aggregation/TestTimeAggregationProgram.java b/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/aggregation/TestTimeAggregationProgram.java
deleted file mode 100644
index b8bfd6c7f..000000000
--- a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/aggregation/TestTimeAggregationProgram.java
+++ /dev/null
@@ -1,82 +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.streampipes.processors.aggregation.flink.processor.aggregation;
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.aggregation.flink.AggregationFlinkInit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.core.collection.ExpectedRecords;
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-
-import java.util.Arrays;
-
-@Ignore
-//@RunWith(Parameterized.class)
-public class TestTimeAggregationProgram extends DataStreamTestBase {
-
-//  @Parameterized.Parameters
-//  public static Iterable<Object[]> algorithm() {
-//    return Arrays.asList(new Object[][]{
-//            {"a", 1},
-//            {new Sha1HashAlgorithm(), HashAlgorithmType.SHA1},
-//            {new Sha2HashAlgorithm(), HashAlgorithmType.SHA2}
-//    });
-//  }
-
-
-  @Test
-  public void testAggregationProgram() {
-    AggregationParameters params = makeParams();
-    ConfigExtractor configExtractor = ConfigExtractor.from(AggregationFlinkInit.SERVICE_GROUP);
-    AggregationProgram program = new AggregationProgram(params, configExtractor, null);
-    AggregationTestData testData = new AggregationTestData();
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(makeInputData
-        (testData)));
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expectAll(testData.getExpectedOutput());
-
-    assertStream(stream, expected);
-  }
-
-  private AggregationParameters makeParams() {
-    return new AggregationParameters(
-        InvocationGraphGenerator.makeEmptyInvocation(new AggregationController().declareModel()),
-        AggregationType.AVG,
-        1,
-        Arrays.asList("sensorId"),
-        Arrays.asList("value"),
-        10,
-        Arrays.asList("value"),
-        true);
-  }
-
-  private EventTimeInput<Event> makeInputData(AggregationTestData testData) {
-    return EventTimeInputBuilder.startWith(testData.getInput().get(0))
-        .emit(testData.getInput().get(1), after(1, seconds));
-  }
-
-}
diff --git a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/count/TestCountProgram.java b/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/count/TestCountProgram.java
deleted file mode 100644
index 0692a4099..000000000
--- a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/count/TestCountProgram.java
+++ /dev/null
@@ -1,135 +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.streampipes.processors.aggregation.flink.processor.count;
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.aggregation.flink.AggregationFlinkInit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.core.collection.ExpectedRecords;
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.List;
-
-@Ignore
-public class TestCountProgram extends DataStreamTestBase {
-
-  @Test
-  public void testCountProgram() {
-
-    EventTimeInput input = makeInputData(makeTestData(), makeTestData().size());
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expectAll(getOutput());
-
-    runProgram(input, expected);
-  }
-
-  @Test
-  public void testOutOfWindow() {
-
-    EventTimeInput input = makeInputData(makeTestData(), 2);
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expectAll(getOutOfWindowOutput());
-
-    runProgram(input, expected);
-  }
-
-  private void runProgram(EventTimeInput<Event> input, ExpectedRecords<Event>
-      expected) {
-    CountParameters params =
-        new CountParameters(InvocationGraphGenerator.makeEmptyInvocation(new CountController().declareModel()), 10,
-            "SECONDS", "field");
-    ConfigExtractor configExtractor = ConfigExtractor.from(AggregationFlinkInit.SERVICE_GROUP);
-    CountProgram program = new CountProgram(params, configExtractor, null);
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(input));
-
-    assertStream(stream, expected);
-  }
-
-  private Collection<Event> getOutput() {
-    List<Event> outRecords = new ArrayList<>();
-    outRecords.add(makeOutMap("v1", 1));
-    outRecords.add(makeOutMap("v2", 1));
-    outRecords.add(makeOutMap("v1", 2));
-    outRecords.add(makeOutMap("v3", 1));
-    outRecords.add(makeOutMap("v2", 2));
-
-    return outRecords;
-  }
-
-  private Collection<Event> getOutOfWindowOutput() {
-    List<Event> outRecords = new ArrayList<>();
-    outRecords.add(makeOutMap("v1", 1));
-    outRecords.add(makeOutMap("v2", 1));
-    outRecords.add(makeOutMap("v1", 1));
-    outRecords.add(makeOutMap("v3", 1));
-    outRecords.add(makeOutMap("v2", 1));
-
-    return outRecords;
-  }
-
-  private Event makeOutMap(String key, Integer count) {
-    Event outEvent = new Event();
-    outEvent.addField("value", key);
-    outEvent.addField("count", count);
-    return outEvent;
-  }
-
-  private EventTimeInput<Event> makeInputData(List<Event> testData, Integer
-      splitIndex) {
-    EventTimeInputBuilder<Event> builder = EventTimeInputBuilder.startWith(testData.get(0));
-
-    for (int i = 1; i < splitIndex; i++) {
-      builder.emit(testData.get(i), after(1, seconds));
-    }
-
-    for (int j = splitIndex; j < testData.size(); j++) {
-      builder.emit(testData.get(j), after(10, seconds));
-    }
-
-    return builder;
-  }
-
-  private List<Event> makeTestData() {
-    List<Event> inEvent = new ArrayList<>();
-    inEvent.add(makeMap("v1"));
-    inEvent.add(makeMap("v2"));
-    inEvent.add(makeMap("v1"));
-    inEvent.add(makeMap("v3"));
-    inEvent.add(makeMap("v2"));
-
-    return inEvent;
-  }
-
-  private Event makeMap(String s) {
-    Event testEvent = new Event();
-    testEvent.addField("field", s);
-    return testEvent;
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/rate/TestRateProgram.java b/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/rate/TestRateProgram.java
deleted file mode 100644
index a0c3d77ef..000000000
--- a/streampipes-extensions/streampipes-processors-aggregation-flink/src/test/java/org/apache/streampipes/processors/aggregation/flink/processor/rate/TestRateProgram.java
+++ /dev/null
@@ -1,129 +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.streampipes.processors.aggregation.flink.processor.rate;
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.aggregation.flink.AggregationFlinkInit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.core.collection.ExpectedRecords;
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.Parameterized;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.List;
-import java.util.concurrent.TimeUnit;
-
-@Ignore
-@RunWith(Parameterized.class)
-public class TestRateProgram extends DataStreamTestBase {
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> data() {
-    return Arrays.asList(new Object[][]{
-        {1, 1000, TimeUnit.MILLISECONDS, 1.0f, 1},
-        {10, 1000, TimeUnit.MILLISECONDS, 1.0f, 1},
-        {100, 1000, TimeUnit.MILLISECONDS, 1.0f, 1},
-        {10, 100, TimeUnit.MILLISECONDS, 1.0f, 10},
-        {2, 500, TimeUnit.MILLISECONDS, 2.0f, 1},
-        {4, 250, TimeUnit.MILLISECONDS, 4.0f, 1},
-        {8, 250, TimeUnit.MILLISECONDS, 4.0f, 2},
-    });
-  }
-
-  @Parameterized.Parameter
-  public Integer numEvents;
-
-  @Parameterized.Parameter(1)
-  public Integer waitTime;
-
-  @Parameterized.Parameter(2)
-  public TimeUnit timeUnit;
-
-  @Parameterized.Parameter(3)
-  public Float expectedFrequency;
-
-  @Parameterized.Parameter(4)
-  public Integer timeWindowSize;
-
-  @Test
-  public void testRateProgram() {
-    EventRateParameter params =
-        new EventRateParameter(InvocationGraphGenerator.makeEmptyInvocation(new EventRateController().declareModel()),
-            timeWindowSize);
-    ConfigExtractor configExtractor = ConfigExtractor.from(AggregationFlinkInit.SERVICE_GROUP);
-
-    EventRateProgram program = new EventRateProgram(params, configExtractor, null);
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(makeInputData
-        (numEvents, waitTime, timeUnit)));
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expectAll(getOutput(timeWindowSize, expectedFrequency,
-            numEvents));
-
-    assertStream(stream, expected);
-  }
-
-  private Collection<Event> getOutput(Integer timeWindowSize, Float eventsPerSecond, Integer
-      numEvents) {
-    List<Event> allEvents = new ArrayList<>();
-    Event outMap = new Event();
-    outMap.addField("rate", eventsPerSecond);
-
-    for (int i = 0; i < numEvents % timeWindowSize; i++) {
-      allEvents.add(outMap);
-    }
-
-    return allEvents;
-  }
-
-  private EventTimeInput<Event> makeInputData(Integer count, Integer time, TimeUnit timeUnit) {
-    List<Event> testData = makeTestData(count);
-    EventTimeInputBuilder<Event> builder = EventTimeInputBuilder.startWith(testData.get(0));
-
-    for (int i = 1; i < testData.size(); i++) {
-      builder.emit(testData.get(i), after(time, timeUnit));
-    }
-
-    return builder;
-  }
-
-  private List<Event> makeTestData(Integer count) {
-    List<Event> allEvents = new ArrayList<>();
-    Event event = new Event();
-    event.addField("test", 1);
-
-    for (int i = 0; i < count; i++) {
-      allEvents.add(event);
-    }
-
-    return allEvents;
-  }
-
-
-}
diff --git a/streampipes-extensions/streampipes-processors-pattern-detection-flink/pom.xml b/streampipes-extensions/streampipes-processors-pattern-detection-flink/pom.xml
index feb672448..753313463 100644
--- a/streampipes-extensions/streampipes-processors-pattern-detection-flink/pom.xml
+++ b/streampipes-extensions/streampipes-processors-pattern-detection-flink/pom.xml
@@ -96,20 +96,6 @@
             <artifactId>junit</artifactId>
             <scope>test</scope>
         </dependency>
-        <dependency>
-            <groupId>io.flinkspector</groupId>
-            <artifactId>flinkspector-datastream_2.11</artifactId>
-            <exclusions>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-runtime_2.11</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-streaming-java_2.11</artifactId>
-                </exclusion>
-            </exclusions>
-        </dependency>
         <dependency>
             <groupId>org.apache.streampipes</groupId>
             <artifactId>streampipes-test-utils</artifactId>
diff --git a/streampipes-extensions/streampipes-processors-pattern-detection-flink/src/test/java/org/apache/streampipes/processors/pattern/detection/processor/absence/TestAbsence.java b/streampipes-extensions/streampipes-processors-pattern-detection-flink/src/test/java/org/apache/streampipes/processors/pattern/detection/processor/absence/TestAbsence.java
deleted file mode 100644
index 1a13836cd..000000000
--- a/streampipes-extensions/streampipes-processors-pattern-detection-flink/src/test/java/org/apache/streampipes/processors/pattern/detection/processor/absence/TestAbsence.java
+++ /dev/null
@@ -1,125 +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.streampipes.processors.pattern.detection.processor.absence;
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.pattern.detection.flink.PatternDetectionFlinkInit;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.absence.AbsenceController;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.absence.AbsenceParameters;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.absence.AbsenceProgram;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.and.TimeUnit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.Parameterized;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.List;
-
-import static org.hamcrest.core.IsEqual.equalTo;
-
-@Ignore
-@RunWith(Parameterized.class)
-public class TestAbsence extends DataStreamTestBase {
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> data() {
-    return Arrays.asList(new Object[][]{
-        {10, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), true, 12},
-        {10, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), false, 5},
-        {5, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), true, 6},
-    });
-  }
-
-  @Parameterized.Parameter
-  public Integer timeWindow;
-
-  @Parameterized.Parameter(1)
-  public TimeUnit timeUnit;
-
-  @Parameterized.Parameter(2)
-  public List<String> leftMapping;
-
-  @Parameterized.Parameter(3)
-  public List<String> rightMapping;
-
-  @Parameterized.Parameter(4)
-  public Boolean shouldMatch;
-
-  @Parameterized.Parameter(5)
-  public Integer waitForMs;
-
-
-  @Test
-  public void testAbsenceProgram() {
-    AbsenceParameters params =
-        new AbsenceParameters(InvocationGraphGenerator.makeEmptyInvocation(new AbsenceController().declareModel()),
-            Arrays.asList("id", "timestamp", "value"), timeWindow, timeUnit);
-
-    ConfigExtractor configExtractor = ConfigExtractor.from(PatternDetectionFlinkInit.SERVICE_GROUP);
-    AbsenceProgram program = new AbsenceProgram(params, configExtractor, null);
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(makeInputData(1, makeMap(), 0)),
-        createTestStream(makeInputData(waitForMs, makeMap(), 1)));
-
-    assertStream(stream, equalTo(getOutput(shouldMatch)));
-  }
-
-  private Collection<Event> getOutput(Boolean shouldMatch) {
-    List<Event> allEvents = new ArrayList<>();
-
-    if (shouldMatch) {
-      allEvents.add(makeMap().get(0));
-    }
-
-    return allEvents;
-  }
-
-  private EventTimeInput<Event> makeInputData(Integer delayEvent, List<Event> inputMap, Integer i) {
-    List<Event> testData = inputMap;
-    EventTimeInputBuilder<Event> builder = EventTimeInputBuilder.startWith(testData.get(i), after(delayEvent, seconds));
-
-    return builder;
-  }
-
-  private List<Event> makeMap() {
-    List<Event> allEvents = new ArrayList<>();
-    Event event1 = new Event();
-    event1.addField("id", "a");
-    event1.addField("timestamp", 0);
-
-    allEvents.add(event1);
-
-    Event event2 = new Event();
-    event2.addField("id", "a");
-    event2.addField("timestamp", waitForMs);
-
-    allEvents.add(event2);
-
-    return allEvents;
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-pattern-detection-flink/src/test/java/org/apache/streampipes/processors/pattern/detection/processor/and/TestAnd.java b/streampipes-extensions/streampipes-processors-pattern-detection-flink/src/test/java/org/apache/streampipes/processors/pattern/detection/processor/and/TestAnd.java
deleted file mode 100644
index 0546c3f57..000000000
--- a/streampipes-extensions/streampipes-processors-pattern-detection-flink/src/test/java/org/apache/streampipes/processors/pattern/detection/processor/and/TestAnd.java
+++ /dev/null
@@ -1,135 +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.streampipes.processors.pattern.detection.processor.and;
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.graph.DataProcessorDescription;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.pattern.detection.flink.PatternDetectionFlinkInit;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.and.AndController;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.and.AndParameters;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.and.AndProgram;
-import org.apache.streampipes.processors.pattern.detection.flink.processor.and.TimeUnit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-import org.apache.streampipes.test.generator.grounding.EventGroundingGenerator;
-
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.Parameterized;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.List;
-
-import static org.hamcrest.core.IsEqual.equalTo;
-
-@Ignore
-@RunWith(Parameterized.class)
-public class TestAnd extends DataStreamTestBase {
-
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> data() {
-    return Arrays.asList(new Object[][]{
-        {2, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), true, 1, 1},
-        {1, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), true, 1, 1},
-        {10, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), false, 1, 12},
-        {10, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), true, 3, 4},
-        {1, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), false, 1, 2},
-        {3600, TimeUnit.Seconds, Arrays.asList("id"), Arrays.asList("id"), true, 10, 3500},
-
-    });
-  }
-
-  @Parameterized.Parameter
-  public Integer timeWindow;
-
-  @Parameterized.Parameter(1)
-  public TimeUnit timeUnit;
-
-  @Parameterized.Parameter(2)
-  public List<String> leftMapping;
-
-  @Parameterized.Parameter(3)
-  public List<String> rightMapping;
-
-  @Parameterized.Parameter(4)
-  public Boolean shouldMatch;
-
-  @Parameterized.Parameter(5)
-  public Integer delayFirstEvent;
-
-  @Parameterized.Parameter(6)
-  public Integer delaySecondEvent;
-
-  @Test
-  public void testAndProgram() {
-    DataProcessorDescription description = new AndController().declareModel();
-    description.setSupportedGrounding(EventGroundingGenerator.makeDummyGrounding());
-    AndParameters params =
-        new AndParameters(InvocationGraphGenerator.makeEmptyInvocation(description), timeUnit,
-            timeWindow, leftMapping, rightMapping);
-
-    ConfigExtractor configExtractor = ConfigExtractor.from(PatternDetectionFlinkInit.SERVICE_GROUP);
-    AndProgram program = new AndProgram(params, configExtractor, null);
-
-    DataStream<Event> stream =
-        program.getApplicationLogic(createTestStream(makeInputData(delayFirstEvent, makeMap("field1"))),
-            createTestStream(makeInputData(delaySecondEvent, makeMap("field2"))));
-
-    assertStream(stream, equalTo(getOutput(shouldMatch)));
-  }
-
-  private Collection<Event> getOutput(Boolean shouldMatch) {
-    List<Event> allEvents = new ArrayList<>();
-
-    if (shouldMatch) {
-      Event outMap = new Event();
-      outMap.addField("id", "a");
-      outMap.addField("field1", 1);
-      outMap.addField("field2", 1);
-      allEvents.add(outMap);
-    }
-
-    return allEvents;
-  }
-
-  private EventTimeInput<Event> makeInputData(Integer delayEvent, List<Event> inputMap) {
-    List<Event> testData = inputMap;
-    EventTimeInputBuilder<Event> builder = EventTimeInputBuilder.startWith(testData.get(0), after(delayEvent, seconds));
-
-    return builder;
-  }
-
-  private List<Event> makeMap(String fieldName) {
-    List<Event> allEvents = new ArrayList<>();
-    Event event = new Event();
-    event.addField("id", "a");
-    event.addField(fieldName, 1);
-
-    allEvents.add(event);
-
-    return allEvents;
-  }
-
-}
diff --git a/streampipes-extensions/streampipes-processors-text-mining-flink/pom.xml b/streampipes-extensions/streampipes-processors-text-mining-flink/pom.xml
index 18d031adc..45ddbff55 100644
--- a/streampipes-extensions/streampipes-processors-text-mining-flink/pom.xml
+++ b/streampipes-extensions/streampipes-processors-text-mining-flink/pom.xml
@@ -63,29 +63,6 @@
         </dependency>
 
         <!-- Test dependencies -->
-        <dependency>
-            <groupId>io.flinkspector</groupId>
-            <artifactId>flinkspector-datastream_2.11</artifactId>
-            <scope>test</scope>
-            <exclusions>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-runtime_2.11</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-streaming-java_2.11</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.scala-lang</groupId>
-                    <artifactId>scala-reflect</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.scala-lang</groupId>
-                    <artifactId>scala-compiler</artifactId>
-                </exclusion>
-            </exclusions>
-        </dependency>
         <dependency>
             <groupId>org.apache.streampipes</groupId>
             <artifactId>streampipes-test-utils</artifactId>
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/pom.xml b/streampipes-extensions/streampipes-processors-transformation-flink/pom.xml
index a94fcbec2..2469a686e 100644
--- a/streampipes-extensions/streampipes-processors-transformation-flink/pom.xml
+++ b/streampipes-extensions/streampipes-processors-transformation-flink/pom.xml
@@ -64,21 +64,6 @@
         </dependency>
 
         <!-- Test dependencies -->
-        <dependency>
-            <groupId>io.flinkspector</groupId>
-            <artifactId>flinkspector-datastream_2.11</artifactId>
-            <scope>test</scope>
-            <exclusions>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-runtime_2.11</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.apache.flink</groupId>
-                    <artifactId>flink-streaming-java_2.11</artifactId>
-                </exclusion>
-            </exclusions>
-        </dependency>
         <dependency>
             <groupId>org.apache.streampipes</groupId>
             <artifactId>streampipes-test-utils</artifactId>
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/converter/TestConverterProgram.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/converter/TestConverterProgram.java
deleted file mode 100644
index e8dd0b4a0..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/converter/TestConverterProgram.java
+++ /dev/null
@@ -1,95 +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.streampipes.processors.transformation.flink.processor.converter;
-
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.transformation.flink.TransformationFlinkInit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.core.collection.ExpectedRecords;
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.Parameterized;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.List;
-
-@RunWith(Parameterized.class)
-@Ignore
-public class TestConverterProgram extends DataStreamTestBase {
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> data() {
-    return Arrays.asList(new Object[][]{
-        {"1", 1, "http://www.w3.org/2001/XMLSchema#integer"},
-        {"1.0", 1.0f, "http://www.w3.org/2001/XMLSchema#float"},
-
-    });
-  }
-
-  @Parameterized.Parameter
-  public String inputValue;
-
-  @Parameterized.Parameter(1)
-  public Object expectedValue;
-
-  @Parameterized.Parameter(2)
-  public String targetDatatype;
-
-  @Test
-  public void testConverterProgram() {
-    FieldConverterParameters params = new FieldConverterParameters(
-        InvocationGraphGenerator.makeEmptyInvocation(new FieldConverterController().declareModel()), "field",
-        targetDatatype);
-
-    ConfigExtractor configExtractor = ConfigExtractor.from(TransformationFlinkInit.SERVICE_GROUP);
-    FieldConverterProgram program = new FieldConverterProgram(params, configExtractor, null);
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(makeInputData(inputValue)));
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expect(makeTestData(expectedValue).get(0));
-
-    assertStream(stream, expected);
-  }
-
-  private EventTimeInput<Event> makeInputData(String inputValue) {
-    List<Event> testData = makeTestData(inputValue);
-    EventTimeInputBuilder<Event> builder = EventTimeInputBuilder.startWith(testData.get(0));
-
-    return builder;
-  }
-
-  private List<Event> makeTestData(Object inputValue) {
-    List<Event> allEvents = new ArrayList<>();
-    Event event = new Event();
-    event.addField("field", inputValue);
-
-    allEvents.add(event);
-
-    return allEvents;
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasher.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasher.java
deleted file mode 100644
index e5723d16a..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasher.java
+++ /dev/null
@@ -1,124 +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.streampipes.processors.transformation.flink.processor.hasher;
-
-
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.Md5HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.Sha1HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.Sha2HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.utils.DummyCollector;
-
-import io.flinkspector.datastream.DataStreamTestBase;
-import org.junit.Before;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.Parameterized;
-
-import java.util.Arrays;
-import java.util.List;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.fail;
-
-@Ignore
-@RunWith(Parameterized.class)
-public class TestFieldHasher extends DataStreamTestBase {
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> algorithm() {
-    return Arrays.asList(new Object[][]{
-        {"field1", "field2", "1"},
-        {"field1", "field2", "1"},
-        {"field1", "field2", 3},
-    });
-  }
-
-  @Parameterized.Parameter
-  public String fieldToHash;
-
-  @Parameterized.Parameter(1)
-  public String fieldNotToHash;
-
-  @Parameterized.Parameter(2)
-  public Object valueToHash;
-
-  private Event inputMap;
-  private Event expectedMap;
-
-  @Before
-  public void generateMaps() {
-    inputMap = new Event();
-    inputMap.addField(fieldToHash, valueToHash);
-    inputMap.addField(fieldNotToHash, valueToHash);
-
-    expectedMap = new Event();
-    expectedMap.addField(fieldToHash, valueToHash);
-    expectedMap.addField(fieldNotToHash, valueToHash);
-  }
-
-  @Test
-  public void testFieldHasherMd5() {
-    HashAlgorithm algorithm = new Md5HashAlgorithm();
-    FieldHasher fieldHasher = new FieldHasher(fieldToHash, algorithm);
-    expectedMap.addField(fieldToHash, algorithm.toHashValue(valueToHash));
-
-    testFieldHasher(fieldHasher);
-
-  }
-
-  @Test
-  public void testFieldHasherSha1() {
-    HashAlgorithm algorithm = new Sha1HashAlgorithm();
-    FieldHasher fieldHasher = new FieldHasher(fieldToHash, algorithm);
-    expectedMap.addField(fieldToHash, algorithm.toHashValue(valueToHash));
-
-    testFieldHasher(fieldHasher);
-
-  }
-
-  @Test
-  public void testFieldHasherSha2() {
-    HashAlgorithm algorithm = new Sha2HashAlgorithm();
-    FieldHasher fieldHasher = new FieldHasher(fieldToHash, algorithm);
-    expectedMap.addField(fieldToHash, algorithm.toHashValue(valueToHash));
-
-    testFieldHasher(fieldHasher);
-
-  }
-
-  private void testFieldHasher(FieldHasher fieldHasher) {
-    DummyCollector collector = new DummyCollector();
-    try {
-      fieldHasher.flatMap(inputMap, collector);
-
-      List<Event> output = collector.getOutput();
-
-      if (output.size() != 1) {
-        fail();
-      } else {
-        assertEquals(expectedMap.getRaw(), output.get(0).getRaw());
-      }
-    } catch (Exception e) {
-      fail();
-    }
-  }
-
-}
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherController.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherController.java
deleted file mode 100644
index 6aace3dd4..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherController.java
+++ /dev/null
@@ -1,38 +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.streampipes.processors.transformation.flink.processor.hasher;
-
-import org.apache.streampipes.model.graph.DataProcessorDescription;
-
-import org.junit.Test;
-
-public class TestFieldHasherController {
-
-  @Test
-  public void testDescription() {
-    DataProcessorDescription description = new FieldHasherController().declareModel();
-
-  }
-
-  @Test
-  public void testInvocation() {
-
-  }
-
-
-}
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherProgram.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherProgram.java
deleted file mode 100644
index 2a19bdc3b..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherProgram.java
+++ /dev/null
@@ -1,84 +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.streampipes.processors.transformation.flink.processor.hasher;
-
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.transformation.flink.TransformationFlinkInit;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.HashAlgorithmType;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.Md5HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.Sha1HashAlgorithm;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.Sha2HashAlgorithm;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.core.collection.ExpectedRecords;
-import io.flinkspector.datastream.DataStreamTestBase;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.Parameterized;
-
-import java.util.Arrays;
-
-import static org.apache.streampipes.processors.transformation.flink.processor.hasher.TestFieldHasherUtils.makeTestData;
-
-@RunWith(Parameterized.class)
-@Ignore
-public class TestFieldHasherProgram extends DataStreamTestBase {
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> algorithm() {
-    return Arrays.asList(new Object[][]{
-        {new Md5HashAlgorithm(), HashAlgorithmType.MD5},
-        {new Sha1HashAlgorithm(), HashAlgorithmType.SHA1},
-        {new Sha2HashAlgorithm(), HashAlgorithmType.SHA2}
-    });
-  }
-
-  @Parameterized.Parameter()
-  public HashAlgorithm hashAlgorithm;
-
-  @Parameterized.Parameter(1)
-  public HashAlgorithmType hashAlgorithmType;
-
-  @Test
-  public void testFieldHasherProgram() {
-
-    FieldHasherParameters params = makeParams();
-    ConfigExtractor configExtractor = ConfigExtractor.from(TransformationFlinkInit.SERVICE_GROUP);
-    FieldHasherProgram program = new FieldHasherProgram(params, configExtractor, null);
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(makeTestData(true, hashAlgorithm)));
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expectAll(makeTestData(false, hashAlgorithm));
-
-    assertStream(stream, expected);
-  }
-
-  private FieldHasherParameters makeParams() {
-    return new FieldHasherParameters(
-        InvocationGraphGenerator.makeEmptyInvocation(new FieldHasherController().declareModel()), "field",
-        hashAlgorithmType);
-  }
-
-
-}
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherUtils.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherUtils.java
deleted file mode 100644
index 637bbde75..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/hasher/TestFieldHasherUtils.java
+++ /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.
- *
- */
-package org.apache.streampipes.processors.transformation.flink.processor.hasher;
-
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.transformation.flink.processor.hasher.algorithm.HashAlgorithm;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.List;
-
-public class TestFieldHasherUtils {
-
-  public static List<String> testData = Arrays.asList("test1", "test2", "test3", "test4");
-
-  public static List<Event> makeTestData(boolean originalValue, HashAlgorithm hashAlgorithm) {
-    List<Event> data = new ArrayList<>();
-    for (int i = 0; i < 3; i++) {
-      Event event = new Event();
-      event.addField("timestamp", i);
-      event.addField("field", originalValue ? testData.get(i) : hashAlgorithm.toHashValue
-          (testData
-              .get(i)));
-      data.add(event);
-    }
-    return data;
-  }
-
-}
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/rename/TestRenameProgram.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/rename/TestRenameProgram.java
deleted file mode 100644
index b35321b40..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/processor/rename/TestRenameProgram.java
+++ /dev/null
@@ -1,102 +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.streampipes.processors.transformation.flink.processor.rename;
-
-
-import org.apache.streampipes.extensions.management.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.transformation.flink.TransformationFlinkInit;
-import org.apache.streampipes.test.generator.InvocationGraphGenerator;
-
-import io.flinkspector.core.collection.ExpectedRecords;
-import io.flinkspector.datastream.DataStreamTestBase;
-import io.flinkspector.datastream.input.EventTimeInput;
-import io.flinkspector.datastream.input.EventTimeInputBuilder;
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runners.Parameterized;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.List;
-
-@Ignore
-public class TestRenameProgram extends DataStreamTestBase {
-
-  @Parameterized.Parameters
-  public static Iterable<Object[]> data() {
-    return Arrays.asList(new Object[][]{
-        {"fieldA", "fieldC"},
-        {"fieldB", "fieldD"},
-
-    });
-  }
-
-  @Parameterized.Parameter
-  public String oldPropertyName;
-
-  @Parameterized.Parameter(1)
-  public String newPropertyName;
-
-  @Test
-  public void testConverterProgram() {
-    FieldRenamerParameters params = new FieldRenamerParameters(
-        InvocationGraphGenerator.makeEmptyInvocation(new FieldRenamerController().declareModel()), oldPropertyName,
-        newPropertyName);
-
-    ConfigExtractor configExtractor = ConfigExtractor.from(TransformationFlinkInit.SERVICE_GROUP);
-    FieldRenamerProgram program = new FieldRenamerProgram(params, configExtractor, null);
-
-    DataStream<Event> stream = program.getApplicationLogic(createTestStream(makeInputData()));
-
-    ExpectedRecords<Event> expected =
-        new ExpectedRecords<Event>().expectAll(getOutput(oldPropertyName, newPropertyName));
-
-    assertStream(stream, expected);
-  }
-
-  private Collection<Event> getOutput(String oldPropertyName, String newPropertyName) {
-    List<Event> allEvents = new ArrayList<>();
-    Event outMap = makeTestData().get(0);
-    Object value = outMap.getFieldBySelector(oldPropertyName);
-    outMap.removeFieldBySelector(oldPropertyName);
-    outMap.addField(newPropertyName, value);
-    allEvents.add(outMap);
-
-    return allEvents;
-  }
-
-  private EventTimeInput<Event> makeInputData() {
-    List<Event> testData = makeTestData();
-
-    return EventTimeInputBuilder.startWith(testData.get(0));
-  }
-
-  private List<Event> makeTestData() {
-    List<Event> allEvents = new ArrayList<>();
-    Event event = new Event();
-    event.addField("fieldA", "a");
-    event.addField("fieldB", "b");
-
-    allEvents.add(event);
-
-    return allEvents;
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/utils/DummyCollector.java b/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/utils/DummyCollector.java
deleted file mode 100644
index 45e411187..000000000
--- a/streampipes-extensions/streampipes-processors-transformation-flink/src/test/java/org/apache/streampipes/processors/transformation/flink/utils/DummyCollector.java
+++ /dev/null
@@ -1,48 +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.streampipes.processors.transformation.flink.utils;
-
-import org.apache.streampipes.model.runtime.Event;
-
-import org.apache.flink.util.Collector;
-
-import java.util.ArrayList;
-import java.util.List;
-
-public class DummyCollector implements Collector<Event> {
-
-  List<Event> output;
-
-  public DummyCollector() {
-    this.output = new ArrayList<>();
-  }
-
-  @Override
-  public void collect(Event stringObjectMap) {
-    this.output.add(stringObjectMap);
-  }
-
-  @Override
-  public void close() {
-
-  }
-
-  public List<Event> getOutput() {
-    return output;
-  }
-}
diff --git a/streampipes-maven-plugin/src/test/java/org/apache/streampipes/smp/extractor/TestDockerImageExtractor.java b/streampipes-maven-plugin/src/test/java/org/apache/streampipes/smp/extractor/TestDockerImageExtractor.java
deleted file mode 100644
index c5370be58..000000000
--- a/streampipes-maven-plugin/src/test/java/org/apache/streampipes/smp/extractor/TestDockerImageExtractor.java
+++ /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.
- *
- */
-
-package org.apache.streampipes.smp.extractor;
-
-import org.apache.commons.io.IOUtils;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.yaml.snakeyaml.Yaml;
-
-import java.io.IOException;
-
-import static org.junit.Assert.assertEquals;
-
-public class TestDockerImageExtractor {
-
-  @Test
-  @Ignore
-  public void testDockerImageExtrator() throws IOException {
-    ClassLoader classLoader = this.getClass().getClassLoader();
-    String yamlContent = IOUtils.toString(classLoader.getResourceAsStream("docker-compose.yml"));
-    Yaml yaml = new Yaml();
-    String imageName = new DockerImageExtractor(null).extractNameFromYaml(yaml.load(yamlContent));
-    System.out.println(imageName);
-
-    assertEquals("processors-text-mining-flink", imageName);
-
-  }
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/ThrowableCaptor.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/ThrowableCaptor.java
deleted file mode 100644
index f089030f5..000000000
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/ThrowableCaptor.java
+++ /dev/null
@@ -1,42 +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.streampipes.manager;
-
-/**
- * Helper class to assert exceptions
- * See http://www.codeaffine.com/2014/07/28/clean-junit-throwable-tests-with-java-8-lambdas/
- */
-public class ThrowableCaptor {
-
-  public interface Actor {
-    void act() throws Throwable;
-  }
-
-  public static Throwable captureThrowable(Actor actor) {
-    Throwable result = null;
-    try {
-      actor.act();
-    } catch (Throwable throwable) {
-      result = throwable;
-    }
-    return result;
-  }
-
-
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/assets/TestImagePathReplacer.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/assets/TestImagePathReplacer.java
index 9de021e01..aafb2be34 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/assets/TestImagePathReplacer.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/assets/TestImagePathReplacer.java
@@ -24,27 +24,28 @@ import static org.junit.Assert.assertEquals;
 
 public class TestImagePathReplacer {
 
-  private String testContent = "## Numerical Filter\n"
-      + "\n"
-      + "<img src=\"logo.png\"/>\n"
-      + "\n"
-      + "## Description\n"
-      + "\n"
-      + "Lorem ipsu";
+  private static final String testContentReplaced = """
+      ## Numerical Filter
 
-  private String testContentReplaced = "## Numerical Filter\n"
-      + "\n"
-      + "<img src=\"/streampipes-backend/api/v2/pe/app/assets/logo.png\"/>\n"
-      + "\n"
-      + "## Description\n"
-      + "\n"
-      + "Lorem ipsu";
+      <img src="/streampipes-backend/api/v2/pe/app/assets/logo.png"/>
 
-  private String appId = "app";
+      ## Description
+
+      Lorem ipsu""";
+
+  private static final String appId = "app";
 
 
   @Test
   public void testRegexReplacement() {
+    String testContent = """
+        ## Numerical Filter
+
+        <img src="logo.png"/>
+
+        ## Description
+
+        Lorem ipsu""";
     String newContent = new ImagePathReplacer(testContent, appId).replaceContent();
     assertEquals(testContentReplaced, newContent);
 
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestPipelineModification.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestPipelineModification.java
deleted file mode 100644
index 2dd8dcde5..000000000
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestPipelineModification.java
+++ /dev/null
@@ -1,66 +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.streampipes.manager.matching;
-
-public class TestPipelineModification {
-
-//    @Test
-//    public void testPipelineModificationMessagePresent() {
-//
-//        DataProcessorInvocation invocation = TestUtils.makeSepa(new AggregationController(), "B", "A");
-//        SpDataStream stream = TestUtils.makeStream(new RandomDataProducer(), new RandomNumberStreamJson(), "A");
-//
-//        Pipeline pipeline =TestUtils.makePipeline(Arrays.asList(stream), Arrays.asList(invocation));
-//
-//        PipelineModificationMessage message = null;
-//        try {
-//            message = new PipelineVerificationHandler(pipeline)
-//                    .validateConnection()
-//                    .computeMappingProperties()
-//                    .getPipelineModificationMessage();
-//        } catch (Exception e) {
-//            fail(e.toString());
-//        }
-//
-//        assertNotNull(message);
-//    }
-
-//    @Test
-//    public void testPipelineMappingProperties() {
-//
-//        DataProcessorInvocation invocation = TestUtils.makeSepa(new AggregationController(), "B", "A");
-//        SpDataStream stream = TestUtils.makeStream(new RandomDataProducer(), new RandomNumberStreamJson(), "A");
-//
-//        Pipeline pipeline =TestUtils.makePipeline(Arrays.asList(stream), Arrays.asList(invocation));
-//
-//        PipelineModificationMessage message = null;
-//        try {
-//            message = new PipelineVerificationHandler(pipeline)
-//                    .validateConnection()
-//                    .computeMappingProperties()
-//                    .getPipelineModificationMessage();
-//        } catch (Exception e) {
-//            fail("Exception");
-//        }
-//
-//        assertNotNull(message);
-//        assertTrue(message.getPipelineModifications().size() > 0);
-//    }
-
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestPipelineValidationHandler.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestPipelineValidationHandler.java
deleted file mode 100644
index fdd6357d3..000000000
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestPipelineValidationHandler.java
+++ /dev/null
@@ -1,64 +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.streampipes.manager.matching;
-
-//import static org.assertj.core.api.Assertions.assertThat;
-
-public class TestPipelineValidationHandler {
-
-//  @Test
-//  public void testPositivePipelineValidation() {
-//
-//    Pipeline pipeline = TestUtils.makePipeline(new RandomDataProducer(),
-//        new RandomNumberStreamJson(),
-//        new AggregationController());
-//
-//    PipelineVerificationHandler handler;
-//    try {
-//      handler = new PipelineVerificationHandler(pipeline);
-//      handler.validateConnection();
-//    } catch (Exception e2) {
-//      fail(e2.getMessage());
-//    }
-//
-//    assertTrue(true);
-//  }
-//
-//  @Test
-//  public void testNegativePipelineValidation() {
-//
-//    Pipeline pipeline = TestUtils.makePipeline(new RandomDataProducer(),
-//        new RandomNumberStreamJson(),
-//        new GeofencingController());
-//
-//    PipelineVerificationHandler handler = null;
-//
-//
-//    try {
-//      handler = new PipelineVerificationHandler(pipeline);
-//    } catch (Exception e) {
-//      assertTrue(false);
-//    }
-//
-//    Throwable actual = ThrowableCaptor.captureThrowable(handler::validateConnection);
-//
-//    //assertThat(actual).isInstanceOf(InvalidConnectionException.class);
-//
-//  }
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestRdfId.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestRdfId.java
deleted file mode 100644
index d53114883..000000000
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/TestRdfId.java
+++ /dev/null
@@ -1,49 +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.streampipes.manager.matching;
-
-public class TestRdfId {
-
-//    @Test
-//    public void testGraphIdAfterClone() {
-//
-//        DataProcessorInvocation invocation = TestUtils.makeSepa(new ProjectController(), "A", "B");
-//        SpDataStream stream = TestUtils.makeStream(new RandomDataProducer(), new RandomNumberStreamJson(), "B");
-//
-//        SpDataStream clonedStream = new SpDataStream(stream);
-//
-//        assertEquals(stream.getElementId(), clonedStream.getElementId());
-//
-//        CustomOutputStrategy strategy = (CustomOutputStrategy) invocation.getOutputStrategies().get(0);
-//        strategy.setEventProperties(clonedStream.getEventSchema().getEventProperties());
-//
-//        assertEquals(clonedStream.getEventSchema().getEventProperties().get(0).getElementId(),
-//        strategy.getEventProperties().get(0).getElementId());
-//
-//        DataProcessorInvocation invocation2 = new DataProcessorInvocation(invocation);
-//
-//        CustomOutputStrategy strategy2 = (CustomOutputStrategy) invocation2.getOutputStrategies().get(0);
-//
-//        assertEquals(clonedStream.getEventSchema().getEventProperties().get(0).getElementId(),
-//        strategy2.getEventProperties().get(0).getElementId());
-//
-//
-//
-//    }
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/ListPropertyMatchTest.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/ListPropertyMatchTest.java
index 29b5b6305..019616adf 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/ListPropertyMatchTest.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/ListPropertyMatchTest.java
@@ -33,7 +33,7 @@ public class ListPropertyMatchTest {
 
 
   @Test
-  public void matchSameDomainProperty() throws Exception {
+  public void matchSameDomainProperty() {
     List<URI> domainProperties = new ArrayList<>();
     domainProperties.add(URI.create("http://test.org/property"));
 
@@ -50,7 +50,7 @@ public class ListPropertyMatchTest {
   }
 
   @Test
-  public void matchListWithNoFurtherRequirements() throws Exception {
+  public void matchListWithNoFurtherRequirements() {
 
     EventPropertyList offer = new EventPropertyList();
     EventPropertyList requirement = new EventPropertyList();
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDatatypeMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDatatypeMatch.java
index 36c82fcdf..f9957e38a 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDatatypeMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDatatypeMatch.java
@@ -22,13 +22,15 @@ import org.apache.streampipes.model.client.matching.MatchingResultMessage;
 import org.apache.streampipes.vocabulary.SO;
 import org.apache.streampipes.vocabulary.XSD;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.util.ArrayList;
 import java.util.List;
 
-public class TestDatatypeMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestDatatypeMatch {
 
   @Test
   public void testPositiveDatatypeMatch() {
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDomainPropertyMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDomainPropertyMatch.java
index 4f55a8aee..bd77a8a7f 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDomainPropertyMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestDomainPropertyMatch.java
@@ -21,15 +21,16 @@ package org.apache.streampipes.manager.matching.v2;
 import org.apache.streampipes.model.client.matching.MatchingResultMessage;
 import org.apache.streampipes.vocabulary.Geo;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.net.URI;
 import java.util.ArrayList;
-import java.util.Arrays;
 import java.util.List;
 
-public class TestDomainPropertyMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestDomainPropertyMatch {
 
   @Test
   public void testPositiveDomainPropertyMatch() {
@@ -56,6 +57,6 @@ public class TestDomainPropertyMatch extends TestCase {
   }
 
   private List<URI> buildDomainProperties(String name) {
-    return Arrays.asList(URI.create(name));
+    return List.of(URI.create(name));
   }
 }
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestElementVerification.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestElementVerification.java
deleted file mode 100644
index cd10eda9e..000000000
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestElementVerification.java
+++ /dev/null
@@ -1,41 +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.streampipes.manager.matching.v2;
-
-import junit.framework.TestCase;
-import org.junit.Test;
-
-public class TestElementVerification extends TestCase {
-
-  @Test
-  public void testPositive() {
-
-//    RandomDataProducer producer = new RandomDataProducer();
-//    SpDataStream offer = producer.getEventStreams().get(0).declareModel(producer.declareModel());
-//
-//    DataProcessorDescription requirement = (new AggregationController().declareModel());
-//
-//    ElementVerification verifier = new ElementVerification();
-//    boolean match = verifier.verify(offer, new DataProcessorInvocation(requirement));
-//
-//    verifier.getErrorLog().forEach(e -> System.out.println(e.getTitle()));
-    assertTrue(true);
-
-  }
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestFormatMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestFormatMatch.java
index b340ff7ea..25820bc70 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestFormatMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestFormatMatch.java
@@ -21,13 +21,15 @@ package org.apache.streampipes.manager.matching.v2;
 import org.apache.streampipes.model.client.matching.MatchingResultMessage;
 import org.apache.streampipes.model.grounding.TransportFormat;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.util.ArrayList;
 import java.util.List;
 
-public class TestFormatMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestFormatMatch {
 
   @Test
   public void testPositiveFormatMatch() {
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestGroundingMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestGroundingMatch.java
index e8928b393..c48569cc3 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestGroundingMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestGroundingMatch.java
@@ -23,13 +23,15 @@ import org.apache.streampipes.model.grounding.EventGrounding;
 import org.apache.streampipes.model.grounding.TransportFormat;
 import org.apache.streampipes.model.grounding.TransportProtocol;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.util.ArrayList;
 import java.util.List;
 
-public class TestGroundingMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestGroundingMatch {
 
   @Test
   public void testPositiveGroundingMatch() {
@@ -103,19 +105,4 @@ public class TestGroundingMatch extends TestCase {
     assertFalse(matches);
   }
 
-  @Test
-  public void testPositiveGroundingMatchWithRealEpa() {
-
-//    RandomDataProducer producer = new RandomDataProducer();
-//    SpDataStream offer = producer.getEventStreams().get(0).declareModel(producer.declareModel());
-//
-//    DataProcessorDescription requirement = (new AggregationController().declareModel());
-//
-//    List<MatchingResultMessage> errorLog = new ArrayList<>();
-//    boolean match = new GroundingMatch().match(offer.getEventGrounding(),
-//        requirement.getSupportedGrounding(), errorLog);
-
-    assertTrue(true);
-
-  }
 }
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestMeasurementUnitMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestMeasurementUnitMatch.java
index 473dcffdd..81e6f5a59 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestMeasurementUnitMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestMeasurementUnitMatch.java
@@ -20,14 +20,15 @@ package org.apache.streampipes.manager.matching.v2;
 
 import org.apache.streampipes.model.client.matching.MatchingResultMessage;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.net.URI;
 import java.util.ArrayList;
 import java.util.List;
 
-public class TestMeasurementUnitMatch extends TestCase {
+import static org.junit.Assert.assertTrue;
+
+public class TestMeasurementUnitMatch {
 
   @Test
   public void testPositiveMeasurementUnitMatch() {
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestPrimitivePropertyMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestPrimitivePropertyMatch.java
index af5718996..240940fda 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestPrimitivePropertyMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestPrimitivePropertyMatch.java
@@ -25,13 +25,15 @@ import org.apache.streampipes.sdk.helpers.EpRequirements;
 import org.apache.streampipes.sdk.helpers.Labels;
 import org.apache.streampipes.vocabulary.Geo;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.util.ArrayList;
 import java.util.List;
 
-public class TestPrimitivePropertyMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestPrimitivePropertyMatch {
 
   @Test
   public void testPositivePrimitivePropertyMatch() {
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestProtocolMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestProtocolMatch.java
index 6553928ed..98d315183 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestProtocolMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestProtocolMatch.java
@@ -21,13 +21,15 @@ package org.apache.streampipes.manager.matching.v2;
 import org.apache.streampipes.model.client.matching.MatchingResultMessage;
 import org.apache.streampipes.model.grounding.TransportProtocol;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.util.ArrayList;
 import java.util.List;
 
-public class TestProtocolMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestProtocolMatch {
 
   @Test
   public void testPositiveProtocolMatch() {
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestSchemaMatch.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestSchemaMatch.java
index 8b102223c..e2696f6c7 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestSchemaMatch.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestSchemaMatch.java
@@ -27,14 +27,16 @@ import org.apache.streampipes.sdk.helpers.EpRequirements;
 import org.apache.streampipes.sdk.helpers.Labels;
 import org.apache.streampipes.vocabulary.Geo;
 
-import junit.framework.TestCase;
 import org.junit.Test;
 
 import java.util.ArrayList;
 import java.util.Arrays;
 import java.util.List;
 
-public class TestSchemaMatch extends TestCase {
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+public class TestSchemaMatch {
 
   @Test
   public void testPositiveSchemaMatch() {
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestUtils.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestUtils.java
index 5d362903a..d1e31832e 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestUtils.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/matching/v2/TestUtils.java
@@ -18,24 +18,12 @@
 
 package org.apache.streampipes.manager.matching.v2;
 
-import org.apache.streampipes.extensions.api.declarer.EventStreamDeclarer;
-import org.apache.streampipes.extensions.api.declarer.SemanticEventProcessingAgentDeclarer;
-import org.apache.streampipes.extensions.api.declarer.SemanticEventProducerDeclarer;
-import org.apache.streampipes.model.SpDataStream;
-import org.apache.streampipes.model.graph.DataProcessorDescription;
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.model.graph.DataSourceDescription;
 import org.apache.streampipes.model.grounding.JmsTransportProtocol;
 import org.apache.streampipes.model.grounding.KafkaTransportProtocol;
 import org.apache.streampipes.model.grounding.TransportFormat;
 import org.apache.streampipes.model.grounding.TransportProtocol;
-import org.apache.streampipes.model.pipeline.Pipeline;
 import org.apache.streampipes.vocabulary.MessageFormat;
 
-import java.util.Arrays;
-import java.util.List;
-import java.util.stream.Collectors;
-
 public class TestUtils {
 
   public static TransportProtocol kafkaProtocol() {
@@ -54,51 +42,4 @@ public class TestUtils {
     return new TransportFormat(MessageFormat.THRIFT);
   }
 
-  public static Pipeline makePipeline(SemanticEventProducerDeclarer producer, EventStreamDeclarer stream,
-                                      SemanticEventProcessingAgentDeclarer agent) {
-    DataSourceDescription dataSourceDescription = new DataSourceDescription(producer.declareModel());
-    dataSourceDescription.setElementId("http://www.schema.org/test1");
-    SpDataStream offer = stream.declareModel();
-    offer.setElementId("http://www.schema.org/test2");
-    DataProcessorDescription requirement = (agent.declareModel());
-    requirement.setElementId("http://www.schema.org/test3");
-    Pipeline pipeline = new Pipeline();
-    SpDataStream offeredClientModel = offer;
-    offeredClientModel.setDom("A");
-
-    DataProcessorInvocation requiredClientModel = new DataProcessorInvocation(requirement);
-    requiredClientModel.setDom("B");
-    requiredClientModel.setConnectedTo(Arrays.asList("A"));
-
-    pipeline.setStreams(Arrays.asList(offeredClientModel));
-    pipeline.setSepas(Arrays.asList(requiredClientModel));
-
-
-    return pipeline;
-  }
-
-  public static Pipeline makePipeline(List<SpDataStream> streams, List<DataProcessorInvocation> epas) {
-    Pipeline pipeline = new Pipeline();
-
-    pipeline.setStreams(streams.stream().map(s -> new SpDataStream(s)).collect(Collectors.toList()));
-    pipeline.setSepas(epas.stream().map(s -> new DataProcessorInvocation(s)).collect(Collectors.toList()));
-
-    return pipeline;
-  }
-
-  public static DataProcessorInvocation makeSepa(SemanticEventProcessingAgentDeclarer declarer, String domId,
-                                                 String... connectedTo) {
-    DataProcessorInvocation invocation = new DataProcessorInvocation(declarer.declareModel());
-    invocation.setDom(domId);
-    invocation.setConnectedTo(Arrays.asList(connectedTo));
-    return invocation;
-  }
-
-  public static SpDataStream makeStream(SemanticEventProducerDeclarer declarer, EventStreamDeclarer streamDec,
-                                        String domId) {
-    SpDataStream stream = new SpDataStream(streamDec.declareModel());
-    stream.setDom(domId);
-    return stream;
-  }
-
 }
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelineManager.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelineManager.java
index 7938de77a..3d0feae91 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelineManager.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelineManager.java
@@ -20,10 +20,8 @@ package org.apache.streampipes.manager.pipeline;
 import org.apache.streampipes.manager.operations.Operations;
 import org.apache.streampipes.model.pipeline.Pipeline;
 import org.apache.streampipes.model.pipeline.PipelineOperationStatus;
-import org.apache.streampipes.resource.management.UserResourceManager;
 import org.apache.streampipes.test.generator.pipeline.DummyPipelineGenerator;
 
-import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.powermock.api.mockito.PowerMockito;
@@ -37,17 +35,10 @@ import static junit.framework.TestCase.assertNotNull;
 
 @RunWith(PowerMockRunner.class)
 @PrepareForTest({
-    UserResourceManager.class,
     PipelineManager.class,
     Operations.class})
 public class TestPipelineManager {
 
-  @Before
-  public void before() {
-    PowerMockito.mockStatic(
-        UserResourceManager.class);
-  }
-
   @Test
   public void testStartPipeline() {
     // Prepare
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelinesContainingElements.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelinesContainingElements.java
deleted file mode 100644
index bc35b3b74..000000000
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/pipeline/TestPipelinesContainingElements.java
+++ /dev/null
@@ -1,89 +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.streampipes.manager.pipeline;
-
-import org.apache.streampipes.model.pipeline.Pipeline;
-import org.apache.streampipes.test.generator.pipeline.DummyPipelineGenerator;
-
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.powermock.api.mockito.PowerMockito;
-import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
-
-import java.util.Collections;
-import java.util.List;
-
-import static junit.framework.TestCase.assertEquals;
-import static junit.framework.TestCase.assertNotNull;
-
-@RunWith(PowerMockRunner.class)
-@PrepareForTest({
-    PipelineManager.class})
-public class TestPipelinesContainingElements {
-  public static final String TARGET_ELEMENT_ID = "TARGET_ELEMENT_ID";
-
-  private Pipeline pipeline;
-
-  @Before
-  public void before() {
-    pipeline = DummyPipelineGenerator.makePipelineWithProcessorAndSink();
-    PowerMockito.stub(PowerMockito.method(PipelineManager.class, "getAllPipelines"))
-        .toReturn(Collections.singletonList(pipeline));
-  }
-
-  @Test
-  public void getPipelineContainingNoElement() {
-    List<Pipeline> resultingPipelines = PipelineManager.getPipelinesContainingElements("");
-    assertNotNull(resultingPipelines);
-    assertEquals(resultingPipelines.size(), 0);
-  }
-
-  @Test
-  public void getPipelineContainingStream() {
-    pipeline.getStreams().forEach((spDataStream) -> spDataStream.setElementId(TARGET_ELEMENT_ID));
-
-    validateOneResultingPipeline();
-  }
-
-
-  @Test
-  public void getPipelineContainingProcessor() {
-
-    pipeline.getSepas().forEach((processor) -> processor.setElementId(TARGET_ELEMENT_ID));
-
-    validateOneResultingPipeline();
-  }
-
-  @Test
-  public void getPipelineContainingSink() {
-
-    pipeline.getActions().forEach((sink) -> sink.setElementId(TARGET_ELEMENT_ID));
-
-    validateOneResultingPipeline();
-  }
-
-  private void validateOneResultingPipeline() {
-    List<Pipeline> resultingPipelines = PipelineManager.getPipelinesContainingElements(TARGET_ELEMENT_ID);
-    assertNotNull(resultingPipelines);
-    assertEquals(resultingPipelines.size(), 1);
-    assertEquals(resultingPipelines.get(0).getName(), DummyPipelineGenerator.PIPELINE_NAME);
-  }
-
-}
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestPropertyRenaming.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestPropertyRenaming.java
index 89bdec2df..7956caea6 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestPropertyRenaming.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestPropertyRenaming.java
@@ -31,7 +31,6 @@ import static org.junit.Assert.assertEquals;
 
 public class TestPropertyRenaming {
 
-
   @Test
   public void testRenaming() {
     EventSchema schema1 = TestSelectorUtils.makeSimpleSchema();
diff --git a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestSelector.java b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestSelector.java
index e7226a563..ceccf5237 100644
--- a/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestSelector.java
+++ b/streampipes-pipeline-management/src/test/java/org/apache/streampipes/manager/selector/TestSelector.java
@@ -23,7 +23,6 @@ import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
 
-import java.util.Arrays;
 import java.util.List;
 
 import static org.apache.streampipes.manager.selector.TestSelectorUtils.makeSchema;
@@ -34,10 +33,10 @@ public class TestSelector {
 
   @Parameterized.Parameters
   public static Iterable<Object[]> data() {
-    return Arrays.asList(new Object[][]{
-        {Arrays.asList("s0::testDimension"), 1},
-        {Arrays.asList("s0::location", "s0::location::latitude"), 1},
-        {Arrays.asList("s0::testDimension", "s0::testMeasurement"), 2}
+    return List.of(new Object[][]{
+        {List.of("s0::testDimension"), 1},
+        {List.of("s0::location", "s0::location::latitude"), 1},
+        {List.of("s0::testDimension", "s0::testMeasurement"), 2}
 
     });
   }