You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@streampipes.apache.org by ri...@apache.org on 2020/03/30 20:55:35 UTC

[incubator-streampipes-extensions] branch revert-7-dev created (now 5f1fcc5)

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

riemer pushed a change to branch revert-7-dev
in repository https://gitbox.apache.org/repos/asf/incubator-streampipes-extensions.git.


      at 5f1fcc5  Revert "WIP: New Processor: StringCounter + StringTimer"

This branch includes the following new commits:

     new 5f1fcc5  Revert "WIP: New Processor: StringCounter + StringTimer"

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



[incubator-streampipes-extensions] 01/01: Revert "WIP: New Processor: StringCounter + StringTimer"

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

riemer pushed a commit to branch revert-7-dev
in repository https://gitbox.apache.org/repos/asf/incubator-streampipes-extensions.git

commit 5f1fcc50d27e6617d436637324ac293f71c5a8b3
Author: Dominik Riemer <do...@gmail.com>
AuthorDate: Mon Mar 30 22:55:30 2020 +0200

    Revert "WIP: New Processor: StringCounter + StringTimer"
---
 .../pe/jvm/AllPipelineElementsInit.java            |   5 +-
 .../transformation/jvm/TransformationJvmInit.java  |   7 +-
 .../stringoperator/counter/StringCounter.java      |  79 ------------------
 .../counter/StringCounterController.java           |  63 ---------------
 .../counter/StringCounterParameters.java           |  36 ---------
 .../stringoperator/timer/StringTimer.java          |  85 -------------------
 .../timer/StringTimerController.java               |  90 ---------------------
 .../timer/StringTimerParameters.java               |  47 -----------
 .../documentation.md                               |  58 -------------
 .../icon.png                                       | Bin 17950 -> 0 bytes
 .../strings.en                                     |   8 --
 .../documentation.md                               |  50 ------------
 .../icon.png                                       | Bin 15788 -> 0 bytes
 .../strings.en                                     |  10 ---
 14 files changed, 3 insertions(+), 535 deletions(-)

diff --git a/streampipes-pipeline-elements-all-jvm/src/main/java/org/apache/streampipes/pe/jvm/AllPipelineElementsInit.java b/streampipes-pipeline-elements-all-jvm/src/main/java/org/apache/streampipes/pe/jvm/AllPipelineElementsInit.java
index 7280c12..0459d7c 100644
--- a/streampipes-pipeline-elements-all-jvm/src/main/java/org/apache/streampipes/pe/jvm/AllPipelineElementsInit.java
+++ b/streampipes-pipeline-elements-all-jvm/src/main/java/org/apache/streampipes/pe/jvm/AllPipelineElementsInit.java
@@ -56,8 +56,6 @@ import org.apache.streampipes.processors.transformation.jvm.processor.booloperat
 import org.apache.streampipes.processors.transformation.jvm.processor.booloperator.timekeeping.BooleanTimekeepingController;
 import org.apache.streampipes.processors.transformation.jvm.processor.booloperator.timer.BooleanTimerController;
 import org.apache.streampipes.processors.transformation.jvm.processor.csvmetadata.CsvMetadataEnrichmentController;
-import org.apache.streampipes.processors.transformation.jvm.processor.stringoperator.counter.StringCounterController;
-import org.apache.streampipes.processors.transformation.jvm.processor.stringoperator.timer.StringTimerController;
 import org.apache.streampipes.processors.transformation.jvm.processor.task.TaskDurationController;
 import org.apache.streampipes.processors.transformation.jvm.processor.timestampextractor.TimestampExtractorController;
 import org.apache.streampipes.processors.transformation.jvm.processor.value.change.ChangedValueDetectionController;
@@ -136,8 +134,7 @@ public class AllPipelineElementsInit extends StandaloneModelSubmitter {
             .add(new LatLngToGeoController())
             .add(new SpeedCalculatorController())
             .add(new StaticDistanceCalculatorController());
-            // .add(new StringCounterController())
-            // .add(new StringTimerController());
+
 
     DeclarersSingleton.getInstance().registerDataFormats(new JsonDataFormatFactory(),
             new CborDataFormatFactory(),
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/TransformationJvmInit.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/TransformationJvmInit.java
index c5b9b46..08bd7d5 100644
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/TransformationJvmInit.java
+++ b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/TransformationJvmInit.java
@@ -34,8 +34,6 @@ import org.apache.streampipes.processors.transformation.jvm.processor.booloperat
 import org.apache.streampipes.processors.transformation.jvm.processor.booloperator.timekeeping.BooleanTimekeepingController;
 import org.apache.streampipes.processors.transformation.jvm.processor.booloperator.timer.BooleanTimerController;
 import org.apache.streampipes.processors.transformation.jvm.processor.csvmetadata.CsvMetadataEnrichmentController;
-import org.apache.streampipes.processors.transformation.jvm.processor.stringoperator.counter.StringCounterController;
-import org.apache.streampipes.processors.transformation.jvm.processor.stringoperator.timer.StringTimerController;
 import org.apache.streampipes.processors.transformation.jvm.processor.task.TaskDurationController;
 import org.apache.streampipes.processors.transformation.jvm.processor.timestampextractor.TimestampExtractorController;
 import org.apache.streampipes.processors.transformation.jvm.processor.transformtoboolean.TransformToBooleanController;
@@ -58,9 +56,8 @@ public class TransformationJvmInit extends StandaloneModelSubmitter {
             .add(new BooleanTimerController())
             .add(new CsvMetadataEnrichmentController())
             .add(new TaskDurationController())
-            .add(new TransformToBooleanController())
-            .add(new StringCounterController())
-            .add(new StringTimerController());
+            .add(new BooleanInverterController())
+            .add(new TransformToBooleanController());
 
     DeclarersSingleton.getInstance().registerDataFormats(new JsonDataFormatFactory(),
             new CborDataFormatFactory(),
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounter.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounter.java
deleted file mode 100644
index 010c4d5..0000000
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounter.java
+++ /dev/null
@@ -1,79 +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.jvm.processor.stringoperator.counter;
-
-import org.apache.streampipes.logging.api.Logger;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.wrapper.context.EventProcessorRuntimeContext;
-import org.apache.streampipes.wrapper.routing.SpOutputCollector;
-import org.apache.streampipes.wrapper.runtime.EventProcessor;
-
-public class StringCounter implements EventProcessor<StringCounterParameters> {
-
-  private static Logger LOG;
-
-  private String fieldName;
-  private String fieldValueOfLastEvent;
-
-  private int counter;
-
-
-  @Override
-  public void onInvocation(StringCounterParameters stringCounterParametersParameters,
-                           SpOutputCollector spOutputCollector,
-                           EventProcessorRuntimeContext runtimeContext) {
-    LOG = stringCounterParametersParameters.getGraph().getLogger(StringCounter.class);
-    this.fieldName = stringCounterParametersParameters.getSelectedFieldName();
-
-    this.fieldValueOfLastEvent = "";
-    this.counter = 0;
-  }
-
-  @Override
-  public void onEvent(Event inputEvent, SpOutputCollector out) {
-
-      String value = inputEvent.getFieldBySelector(fieldName).getAsPrimitive().getAsString();
-      boolean updateCounter = false;
-
-      System.out.println(fieldValueOfLastEvent);
-
-      if (!this.fieldValueOfLastEvent.equals(value)) {
-          System.out.println("if: " + value);
-          updateCounter = true;
-      } else {
-          System.out.println("else: " + value);
-          updateCounter = false;
-      }
-
-      if (updateCounter) {
-          System.out.println("UpdateCounter: " + updateCounter);
-          this.counter++;
-          System.out.println(counter);
-          inputEvent.addField(StringCounterController.COUNT_FIELD_RUNTIME_NAME, this.counter);
-          out.collect(inputEvent);
-      }
-
-      this.fieldValueOfLastEvent = value;
-  }
-
-  @Override
-  public void onDetach() {
-  }
-
-}
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounterController.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounterController.java
deleted file mode 100644
index a06c0ac..0000000
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounterController.java
+++ /dev/null
@@ -1,63 +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.jvm.processor.stringoperator.counter;
-
-import org.apache.streampipes.model.graph.DataProcessorDescription;
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.model.schema.PropertyScope;
-import org.apache.streampipes.sdk.builder.ProcessingElementBuilder;
-import org.apache.streampipes.sdk.builder.StreamRequirementsBuilder;
-import org.apache.streampipes.sdk.extractor.ProcessingElementParameterExtractor;
-import org.apache.streampipes.sdk.helpers.*;
-import org.apache.streampipes.sdk.utils.Assets;
-import org.apache.streampipes.wrapper.standalone.ConfiguredEventProcessor;
-import org.apache.streampipes.wrapper.standalone.declarer.StandaloneEventProcessingDeclarer;
-
-public class StringCounterController extends StandaloneEventProcessingDeclarer<StringCounterParameters> {
-
-  public static final String FIELD_ID = "field";
-  public static final String COUNT_FIELD_ID = "countField";
-  public static final String COUNT_FIELD_RUNTIME_NAME = "counter";
-
-  @Override
-  public DataProcessorDescription declareModel() {
-    return ProcessingElementBuilder.create("org.apache.streampipes.processors.transformation.jvm.stringoperator.counter")
-            .withLocales(Locales.EN)
-            .withAssets(Assets.DOCUMENTATION, Assets.ICON)
-            .requiredStream(StreamRequirementsBuilder.create()
-                    .requiredPropertyWithUnaryMapping(
-                            EpRequirements.stringReq(),
-                            Labels.withId(FIELD_ID),
-                            PropertyScope.NONE)
-                    .build())
-            .outputStrategy(OutputStrategies.append(
-                    EpProperties.numberEp(Labels.withId(COUNT_FIELD_ID), COUNT_FIELD_RUNTIME_NAME, "http://schema.org/Number")
-            ))
-            .build();
-  }
-
-  @Override
-  public ConfiguredEventProcessor<StringCounterParameters> onInvocation(DataProcessorInvocation graph, ProcessingElementParameterExtractor extractor) {
-
-    String selectedFieldName = extractor.mappingPropertyValue(FIELD_ID);
-
-    StringCounterParameters params = new StringCounterParameters(graph, selectedFieldName);
-    return new ConfiguredEventProcessor<>(params, StringCounter::new);
-  }
-}
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounterParameters.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounterParameters.java
deleted file mode 100644
index 27c0cef..0000000
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/counter/StringCounterParameters.java
+++ /dev/null
@@ -1,36 +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.jvm.processor.stringoperator.counter;
-
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.wrapper.params.binding.EventProcessorBindingParams;
-
-public class StringCounterParameters extends EventProcessorBindingParams {
-    private String selectedFieldName;
-
-    public StringCounterParameters(DataProcessorInvocation graph, String selectedFieldName) {
-        super(graph);
-        this.selectedFieldName = selectedFieldName;
-    }
-
-    public String getSelectedFieldName() {
-        return selectedFieldName;
-    }
-
-}
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimer.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimer.java
deleted file mode 100644
index d6c2179..0000000
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimer.java
+++ /dev/null
@@ -1,85 +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.jvm.processor.stringoperator.timer;
-
-import org.apache.streampipes.logging.api.Logger;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.wrapper.context.EventProcessorRuntimeContext;
-import org.apache.streampipes.wrapper.routing.SpOutputCollector;
-import org.apache.streampipes.wrapper.runtime.EventProcessor;
-
-public class StringTimer implements EventProcessor<StringTimerParameters> {
-
-    private static Logger LOG;
-
-    private String fieldName;
-    private boolean measureTrue;
-
-    private Long timestamp;
-
-    private double outputDivisor;
-
-
-    @Override
-    public void onInvocation(StringTimerParameters booleanInverterParameters,
-                             SpOutputCollector spOutputCollector,
-                             EventProcessorRuntimeContext runtimeContext) {
-        LOG = booleanInverterParameters.getGraph().getLogger(StringTimer.class);
-        this.fieldName = booleanInverterParameters.getFieldName();
-        this.measureTrue = booleanInverterParameters.isMeasureTrue();
-        this.timestamp = Long.MIN_VALUE;
-        this.outputDivisor = booleanInverterParameters.getOutputDivisor();
-    }
-
-    @Override
-    public void onEvent(Event inputEvent, SpOutputCollector out) {
-
-        boolean field = inputEvent.getFieldBySelector(this.fieldName).getAsPrimitive().getAsBoolean();
-
-        if (this.measureTrue == field) {
-            if (timestamp == Long.MIN_VALUE) {
-                timestamp = System.currentTimeMillis();
-            }
-        } else {
-            if (timestamp != Long.MIN_VALUE) {
-                Long difference = System.currentTimeMillis() - timestamp;
-
-                double result = difference / this.outputDivisor;
-
-                inputEvent.addField("measured_time", result);
-                timestamp = Long.MIN_VALUE;
-                out.collect(inputEvent);
-            }
-        }
-
-    }
-
-    @Override
-    public void onDetach() {
-    }
-
-    public static void main(String... args) {
-
-        double result = (60000L / 631.1);
-
-        System.out.println(result);
-
-
-    }
-}
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimerController.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimerController.java
deleted file mode 100644
index 9591dc4..0000000
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimerController.java
+++ /dev/null
@@ -1,90 +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.jvm.processor.stringoperator.timer;
-
-import org.apache.streampipes.model.graph.DataProcessorDescription;
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.model.schema.PropertyScope;
-import org.apache.streampipes.sdk.builder.ProcessingElementBuilder;
-import org.apache.streampipes.sdk.builder.StreamRequirementsBuilder;
-import org.apache.streampipes.sdk.extractor.ProcessingElementParameterExtractor;
-import org.apache.streampipes.sdk.helpers.*;
-import org.apache.streampipes.sdk.utils.Assets;
-import org.apache.streampipes.wrapper.standalone.ConfiguredEventProcessor;
-import org.apache.streampipes.wrapper.standalone.declarer.StandaloneEventProcessingDeclarer;
-
-public class StringTimerController extends StandaloneEventProcessingDeclarer<StringTimerParameters> {
-
-  public static final String FIELD_ID = "field";
-  public static final String TIMER_FIELD_ID = "timerField";
-  public static final String MEASURED_TIME_ID = "measuresTime";
-
-  private static final String TRUE = "TRUE";
-  private static final String FALSE = "FALSE";
-
-  public static final String OUTPUT_UNIT_ID = "outputUnit";
-  private static final String MILLISECONDS = "Milliseconds";
-  private static final String SECONDS = "Seconds";
-  private static final String MINUTES = "Minutes";
-
-
-  @Override
-  public DataProcessorDescription declareModel() {
-    return ProcessingElementBuilder.create("org.apache.streampipes.processors.transformation.jvm.stringoperator.timer")
-            .withLocales(Locales.EN)
-            .withAssets(Assets.DOCUMENTATION, Assets.ICON)
-            .requiredStream(StreamRequirementsBuilder.create()
-                    .requiredPropertyWithUnaryMapping(
-                            EpRequirements.booleanReq(),
-                            Labels.withId(FIELD_ID),
-                            PropertyScope.NONE)
-                    .build())
-            .requiredSingleValueSelection(Labels.withId(TIMER_FIELD_ID), Options.from(TRUE, FALSE))
-            .requiredSingleValueSelection(Labels.withId(OUTPUT_UNIT_ID), Options.from(MILLISECONDS, SECONDS, MINUTES))
-            .outputStrategy(OutputStrategies.append(
-                    EpProperties.numberEp(Labels.withId(MEASURED_TIME_ID), "measured_time", "http://schema.org/Number")
-            ))
-            .build();
-  }
-
-  @Override
-  public ConfiguredEventProcessor<StringTimerParameters> onInvocation(DataProcessorInvocation graph, ProcessingElementParameterExtractor extractor) {
-
-    String invertFieldName = extractor.mappingPropertyValue(FIELD_ID);
-    String measureTrueString = extractor.selectedSingleValue(TIMER_FIELD_ID, String.class);
-    String outputUnit = extractor.selectedSingleValue(OUTPUT_UNIT_ID, String.class);
-
-    boolean measureTrue = false;
-
-    if (measureTrueString.equals(TRUE)) {
-      measureTrue = true;
-    }
-
-    double outputDivisor= 1.0;
-    if (outputUnit.equals(SECONDS)) {
-      outputDivisor = 1000.0;
-    } else if (outputUnit.equals(MINUTES)) {
-      outputDivisor = 60000.0;
-    }
-
-    StringTimerParameters params = new StringTimerParameters(graph, invertFieldName, measureTrue, outputDivisor);
-
-    return new ConfiguredEventProcessor<>(params, StringTimer::new);
-  }
-}
diff --git a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimerParameters.java b/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimerParameters.java
deleted file mode 100644
index 36ad6cd..0000000
--- a/streampipes-processors-transformation-jvm/src/main/java/org/apache/streampipes/processors/transformation/jvm/processor/stringoperator/timer/StringTimerParameters.java
+++ /dev/null
@@ -1,47 +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.jvm.processor.stringoperator.timer;
-
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.wrapper.params.binding.EventProcessorBindingParams;
-
-public class StringTimerParameters extends EventProcessorBindingParams {
-    private String fieldName;
-    private boolean measureTrue;
-    private double outputDivisor;
-
-    public StringTimerParameters(DataProcessorInvocation graph, String fieldName, boolean measureTrue, double outputDivisor) {
-        super(graph);
-        this.fieldName = fieldName;
-        this.measureTrue = measureTrue;
-        this.outputDivisor = outputDivisor;
-    }
-
-    public String getFieldName() {
-        return fieldName;
-    }
-
-    public boolean isMeasureTrue() {
-        return measureTrue;
-    }
-
-    public double getOutputDivisor() {
-        return outputDivisor;
-    }
-}
diff --git a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/documentation.md b/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/documentation.md
deleted file mode 100644
index a56db9b..0000000
--- a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/documentation.md
+++ /dev/null
@@ -1,58 +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.
-  ~
-  -->
-
-## Boolean Counter
-
-<p align="center"> 
-    <img src="icon.png" width="150px;" class="pe-image-documentation"/>
-</p>
-
-***
-
-## Description
-
-This processor monitors a boolean value and counts how often the value of the boolean changes. 
-A user can configure whether the changes from FALSE to TRUE, TRUE to FALSE, or BOTH changes should be counted.
-
-***
-
-## Required input
-
-A boolean value is required in the data stream and can be selected with the field mapping.
-
-### Boolean Field
-
-The boolean value to be monitored.
-
-***
-
-## Configuration
-
-A user can configure whether the changes from TRUE to FALSE, FALSE to TRUE, or all changes of the boolean value should be counted.
-
-### Flank parameter
-
-Either:
-* TRUE -> FALSE: Increase counter on a true followed by a false 
-* FALSE -> TRUE: Increase counter on a false followed by a true
-* BOTH: Increas counter on each change of the boolean value on two consecutive events
-
-## Output
-
-Adds an additional numerical field with the current count value to the event. Events are just emitted when the counter changes.
-Runtime Name: countField
\ No newline at end of file
diff --git a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/icon.png b/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/icon.png
deleted file mode 100644
index ebb26e0..0000000
Binary files a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/icon.png and /dev/null differ
diff --git a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/strings.en b/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/strings.en
deleted file mode 100644
index ae7e209..0000000
--- a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.counter/strings.en
+++ /dev/null
@@ -1,8 +0,0 @@
-org.apache.streampipes.processors.transformation.jvm.stringoperator.counter.title=String Counter
-org.apache.streampipes.processors.transformation.jvm.stringoperator.counter.description=Increases a counter on each change of a string value
-
-field.title=String Field
-field.description=The field of the string to monitor
-
-countField.title=Counter
-countField.description=Amount of changes of string value
diff --git a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /documentation.md b/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /documentation.md
deleted file mode 100644
index 0f648de..0000000
--- a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /documentation.md	
+++ /dev/null
@@ -1,50 +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.
-  ~
-  -->
-
-## Boolean Timer
-
-<p align="center"> 
-    <img src="icon.png" width="150px;" class="pe-image-documentation"/>
-</p>
-
-***
-
-## Description
-
-This processor measures how long a boolean value does not change. Once the value is changes the event with the measured time is emitted.
-
-
-***
-
-## Required input
-
-A boolean value is required in the data stream.
-
-### Field
-
-The boolean field which is monitored for state changes.
-
-***
-
-## Configuration
-
-### Timer value
-Define whether it should be measured how long the value is true or how long the value is false.
-
-## Output
-Appends a field with the time how long the value did not change. Is emitted on the change of the boolean value. Runtime name: measured_time 
diff --git a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /icon.png b/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /icon.png
deleted file mode 100644
index e56351b..0000000
Binary files a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /icon.png and /dev/null differ
diff --git a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /strings.en b/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /strings.en
deleted file mode 100644
index 00bc368..0000000
--- a/streampipes-processors-transformation-jvm/src/main/resources/org.apache.streampipes.processors.transformation.jvm.stringoperator.timer /strings.en	
+++ /dev/null
@@ -1,10 +0,0 @@
-org.apache.streampipes.processors.transformation.jvm.stringoperator.timer.title=String Timer
-org.apache.streampipes.processors.transformation.jvm.stringoperator.timer.description=Measures how long a string measure does not change
-
-field.title=String Field
-field.description=The string field that is monitored
-
-timerField.title=Value to observe
-timerField.description=Define whether the time for true or false should be measured
-
-