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 2022/08/12 11:15:10 UTC

[incubator-streampipes] branch dev updated: [STREAMPIPES-575] Remove math processors from enricher-flink module

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

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


The following commit(s) were added to refs/heads/dev by this push:
     new aacef7a45 [STREAMPIPES-575] Remove math processors from enricher-flink module
aacef7a45 is described below

commit aacef7a45c1938acdb49ffb1757de8f165e0c7f9
Author: Dominik Riemer <do...@gmail.com>
AuthorDate: Fri Aug 12 13:15:01 2022 +0200

    [STREAMPIPES-575] Remove math processors from enricher-flink module
---
 .../enricher/flink/EnricherFlinkInit.java          |   8 +-
 .../flink/processor/math/mathop/MathOp.java        |  50 -----------
 .../processor/math/mathop/MathOpController.java    |  98 ---------------------
 .../processor/math/mathop/MathOpParameters.java    |  55 ------------
 .../flink/processor/math/mathop/MathOpProgram.java |  41 ---------
 .../flink/processor/math/operation/Operation.java  |  26 ------
 .../math/operation/OperationAddition.java          |  27 ------
 .../processor/math/operation/OperationDivide.java  |  27 ------
 .../processor/math/operation/OperationModulo.java  |  27 ------
 .../math/operation/OperationMultiply.java          |  27 ------
 .../math/operation/OperationSubtracting.java       |  27 ------
 .../processor/math/staticmathop/StaticMathOp.java  |  50 -----------
 .../math/staticmathop/StaticMathOpController.java  |  95 --------------------
 .../math/staticmathop/StaticMathOpParameters.java  |  55 ------------
 .../math/staticmathop/StaticMathOpProgram.java     |  41 ---------
 .../flink/processor/trigonometry/Operation.java    |  25 ------
 .../flink/processor/trigonometry/Trigonometry.java |  53 -----------
 .../trigonometry/TrigonometryController.java       |  86 ------------------
 .../trigonometry/TrigonometryParameters.java       |  48 ----------
 .../trigonometry/TrigonometryProgram.java          |  39 --------
 .../documentation.md                               |  50 -----------
 .../icon.png                                       | Bin 22150 -> 0 bytes
 .../strings.en                                     |  11 ---
 .../documentation.md                               |  50 -----------
 .../icon.png                                       | Bin 10608 -> 0 bytes
 .../strings.en                                     |  10 ---
 .../documentation.md                               |  50 -----------
 .../icon.png                                       | Bin 36697 -> 0 bytes
 .../strings.en                                     |   9 --
 29 files changed, 1 insertion(+), 1084 deletions(-)

diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/EnricherFlinkInit.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/EnricherFlinkInit.java
index 2d36358af..28d78036d 100644
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/EnricherFlinkInit.java
+++ b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/EnricherFlinkInit.java
@@ -29,10 +29,7 @@ import org.apache.streampipes.messaging.jms.SpJmsProtocolFactory;
 import org.apache.streampipes.messaging.kafka.SpKafkaProtocolFactory;
 import org.apache.streampipes.messaging.mqtt.SpMqttProtocolFactory;
 import org.apache.streampipes.processors.enricher.flink.config.ConfigKeys;
-import org.apache.streampipes.processors.enricher.flink.processor.math.mathop.MathOpController;
-import org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop.StaticMathOpController;
 import org.apache.streampipes.processors.enricher.flink.processor.timestamp.TimestampController;
-import org.apache.streampipes.processors.enricher.flink.processor.trigonometry.TrigonometryController;
 import org.apache.streampipes.processors.enricher.flink.processor.urldereferencing.UrlDereferencingController;
 
 public class EnricherFlinkInit extends StandaloneModelSubmitter {
@@ -48,10 +45,7 @@ public class EnricherFlinkInit extends StandaloneModelSubmitter {
                     "",
                     8090)
             .registerPipelineElements(new TimestampController(),
-                    new MathOpController(),
-                    new StaticMathOpController(),
-                    new UrlDereferencingController(),
-                    new TrigonometryController())
+                    new UrlDereferencingController())
             .registerMessagingFormats(
                     new JsonDataFormatFactory(),
                     new CborDataFormatFactory(),
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOp.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOp.java
deleted file mode 100644
index 13ce56923..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOp.java
+++ /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.
- *
- */
-
-package org.apache.streampipes.processors.enricher.flink.processor.math.mathop;
-
-import org.apache.flink.api.common.functions.FlatMapFunction;
-import org.apache.flink.util.Collector;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.enricher.flink.processor.math.operation.Operation;
-
-public class MathOp implements FlatMapFunction<Event, Event> {
-
-    private Operation operation;
-    private String leftOperand;
-    private String rightOperand;
-    private String resulField;
-
-    public MathOp(Operation operation, String leftOperand, String rightOperand, String resulField) {
-        this.operation = operation;
-        this.leftOperand = leftOperand;
-        this.rightOperand = rightOperand;
-        this.resulField = resulField;
-    }
-
-    @Override
-    public void flatMap(Event in, Collector<Event> out) throws Exception {
-        Double leftValue  = in.getFieldBySelector(leftOperand).getAsPrimitive().getAsDouble();
-        Double rightValue = in.getFieldBySelector(rightOperand).getAsPrimitive().getAsDouble();
-
-        Double result = operation.operate(leftValue, rightValue);
-        in.addField(resulField, result);
-
-        out.collect(in);
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpController.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpController.java
deleted file mode 100644
index f5c4f2e1b..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpController.java
+++ /dev/null
@@ -1,98 +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.enricher.flink.processor.math.mathop;
-
-import org.apache.streampipes.client.StreamPipesClient;
-import org.apache.streampipes.container.config.ConfigExtractor;
-import org.apache.streampipes.model.DataProcessorType;
-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.processors.enricher.flink.processor.math.operation.*;
-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.vocabulary.SO;
-import org.apache.streampipes.wrapper.flink.FlinkDataProcessorDeclarer;
-import org.apache.streampipes.wrapper.flink.FlinkDataProcessorRuntime;
-
-public class MathOpController extends FlinkDataProcessorDeclarer<MathOpParameters> {
-
-  private final String RESULT_FIELD = "calculationResult";
-  private final String LEFT_OPERAND = "leftOperand";
-  private final String RIGHT_OPERAND = "rightOperand";
-  private final String OPERATION = "operation";
-
-  @Override
-  public DataProcessorDescription declareModel() {
-    return ProcessingElementBuilder.create("org.apache.streampipes.processors.enricher.flink.processor.math.mathop")
-            .withAssets(Assets.DOCUMENTATION, Assets.ICON)
-            .withLocales(Locales.EN)
-            .category(DataProcessorType.ALGORITHM)
-            .requiredStream(StreamRequirementsBuilder
-                    .create()
-                    .requiredPropertyWithUnaryMapping(EpRequirements.numberReq(),
-                            Labels.withId(LEFT_OPERAND),
-                            PropertyScope.NONE)
-                    .requiredPropertyWithUnaryMapping(EpRequirements.numberReq(),
-                            Labels.withId(RIGHT_OPERAND),
-                            PropertyScope.NONE)
-                    .build())
-            .outputStrategy(
-                    OutputStrategies.append(
-                            EpProperties.numberEp(Labels.empty(), RESULT_FIELD, SO.Number)))
-            .requiredSingleValueSelection(Labels.withId(OPERATION), Options.from("+", "-", "/",
-                    "*", "%"))
-            .build();
-  }
-
-  @Override
-  public FlinkDataProcessorRuntime<MathOpParameters> getRuntime(DataProcessorInvocation graph,
-                                                                ProcessingElementParameterExtractor extractor,
-                                                                ConfigExtractor configExtractor,
-                                                                StreamPipesClient streamPipesClient) {
-    String leftOperand = extractor.mappingPropertyValue(LEFT_OPERAND);
-    String rightOperand = extractor.mappingPropertyValue(RIGHT_OPERAND);
-    String operation = extractor.selectedSingleValue(OPERATION, String.class);
-
-    Operation arithmeticOperation = null;
-    switch (operation) {
-      case "+":
-        arithmeticOperation = new OperationAddition();
-        break;
-      case "-":
-        arithmeticOperation = new OperationSubtracting();
-        break;
-      case "*":
-        arithmeticOperation = new OperationMultiply();
-        break;
-      case "/":
-        arithmeticOperation = new OperationDivide();
-        break;
-      case "%":
-        arithmeticOperation = new OperationModulo();
-    }
-
-    MathOpParameters parameters = new MathOpParameters(graph, arithmeticOperation, leftOperand, rightOperand, RESULT_FIELD);
-
-    return new MathOpProgram(parameters, configExtractor, streamPipesClient);
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpParameters.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpParameters.java
deleted file mode 100644
index 228a0ed49..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpParameters.java
+++ /dev/null
@@ -1,55 +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.enricher.flink.processor.math.mathop;
-
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.processors.enricher.flink.processor.math.operation.Operation;
-import org.apache.streampipes.wrapper.params.binding.EventProcessorBindingParams;
-
-public class MathOpParameters extends EventProcessorBindingParams {
-
-    private Operation operation;
-    private String leftOperand;
-    private String rightOperand;
-    private String resultField;
-
-    public MathOpParameters(DataProcessorInvocation graph, Operation operation, String leftOperand, String rightOperand, String resultField) {
-        super(graph);
-        this.operation = operation;
-        this.leftOperand = leftOperand;
-        this.rightOperand = rightOperand;
-        this.resultField = resultField;
-    }
-
-    public Operation getOperation() {
-        return operation;
-    }
-
-    public String getLeftOperand() {
-        return leftOperand;
-    }
-
-    public String getRightOperand() {
-        return rightOperand;
-    }
-
-    public String getResultField() {
-        return resultField;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpProgram.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpProgram.java
deleted file mode 100644
index bb61a3e8f..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/mathop/MathOpProgram.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.processors.enricher.flink.processor.math.mathop;
-
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.apache.streampipes.client.StreamPipesClient;
-import org.apache.streampipes.container.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.enricher.flink.AbstractEnricherProgram;
-
-public class MathOpProgram extends AbstractEnricherProgram<MathOpParameters> {
-
-    public MathOpProgram(MathOpParameters params,
-                         ConfigExtractor configExtractor,
-                         StreamPipesClient streamPipesClient) {
-        super(params, configExtractor, streamPipesClient);
-    }
-
-    @Override
-    protected DataStream<Event> getApplicationLogic(DataStream<Event>... dataStreams) {
-        return dataStreams[0]
-                .flatMap(new MathOp(params.getOperation(), params.getLeftOperand(),
-                                    params.getRightOperand(), params.getResultField()));
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/Operation.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/Operation.java
deleted file mode 100644
index e9cd59352..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/Operation.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.processors.enricher.flink.processor.math.operation;
-
-import java.io.Serializable;
-
-public interface Operation extends Serializable {
-
-    Double operate(Double valLeft, Double valRight);
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationAddition.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationAddition.java
deleted file mode 100644
index 8a19293f6..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationAddition.java
+++ /dev/null
@@ -1,27 +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.enricher.flink.processor.math.operation;
-
-public class OperationAddition implements Operation {
-
-    @Override
-    public Double operate(Double valLeft, Double valRight) {
-        return valLeft + valRight;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationDivide.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationDivide.java
deleted file mode 100644
index b648a20f2..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationDivide.java
+++ /dev/null
@@ -1,27 +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.enricher.flink.processor.math.operation;
-
-public class OperationDivide implements Operation {
-
-    @Override
-    public Double operate(Double valLeft, Double valRight) {
-        return valLeft / valRight;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationModulo.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationModulo.java
deleted file mode 100644
index ab50adf8a..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationModulo.java
+++ /dev/null
@@ -1,27 +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.enricher.flink.processor.math.operation;
-
-public class OperationModulo implements Operation {
-
-    @Override
-    public Double operate(Double valLeft, Double valRight) {
-        return valLeft % valRight;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationMultiply.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationMultiply.java
deleted file mode 100644
index e35924431..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationMultiply.java
+++ /dev/null
@@ -1,27 +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.enricher.flink.processor.math.operation;
-
-public class OperationMultiply implements Operation{
-
-    @Override
-    public Double operate(Double valLeft, Double valRight) {
-        return valLeft * valRight;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationSubtracting.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationSubtracting.java
deleted file mode 100644
index 27163a4a8..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/operation/OperationSubtracting.java
+++ /dev/null
@@ -1,27 +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.enricher.flink.processor.math.operation;
-
-public class OperationSubtracting implements Operation {
-
-    @Override
-    public Double operate(Double valLeft, Double valRight) {
-        return valLeft - valRight;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOp.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOp.java
deleted file mode 100644
index 60e68df15..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOp.java
+++ /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.
- *
- */
-
-package org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop;
-
-import org.apache.flink.api.common.functions.FlatMapFunction;
-import org.apache.flink.util.Collector;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.enricher.flink.processor.math.operation.Operation;
-
-public class StaticMathOp implements FlatMapFunction<Event, Event> {
-
-    private Operation operation;
-    private String leftOperand;
-    private double rightOperandValue;
-    private String resulField;
-
-    public StaticMathOp(Operation operation, String leftOperand, double rightOperandValue, String resultField) {
-        this.operation = operation;
-        this.leftOperand = leftOperand;
-        this.rightOperandValue = rightOperandValue;
-        this.resulField = resultField;
-    }
-
-    @Override
-    public void flatMap(Event in, Collector<Event> out) throws Exception {
-        Double leftValue  = Double.parseDouble(String.valueOf(in.getFieldBySelector(leftOperand)
-                .getAsPrimitive().getAsDouble()));
-
-        Double result = operation.operate(leftValue, rightOperandValue);
-        in.updateFieldBySelector(leftOperand, result);
-
-        out.collect(in);
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpController.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpController.java
deleted file mode 100644
index 6cf6bbd7d..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpController.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.enricher.flink.processor.math.staticmathop;
-
-import org.apache.streampipes.client.StreamPipesClient;
-import org.apache.streampipes.container.config.ConfigExtractor;
-import org.apache.streampipes.model.DataProcessorType;
-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.processors.enricher.flink.processor.math.operation.*;
-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.flink.FlinkDataProcessorDeclarer;
-import org.apache.streampipes.wrapper.flink.FlinkDataProcessorRuntime;
-
-public class StaticMathOpController extends FlinkDataProcessorDeclarer<StaticMathOpParameters> {
-
-  private final String RESULT_FIELD = "calculationResultStatic";
-  private final String LEFT_OPERAND = "leftOperand";
-  private final String RIGHT_OPERAND_VALUE = "rightOperandValue";
-  private final String OPERATION = "operation";
-
-  @Override
-  public DataProcessorDescription declareModel() {
-    return ProcessingElementBuilder.create("org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop")
-            .withAssets(Assets.DOCUMENTATION, Assets.ICON)
-            .withLocales(Locales.EN)
-            .category(DataProcessorType.ALGORITHM)
-            .requiredStream(StreamRequirementsBuilder
-                    .create()
-                    .requiredPropertyWithUnaryMapping(EpRequirements.numberReq(),
-                            Labels.withId(LEFT_OPERAND),
-                            PropertyScope.NONE)
-                    .build())
-            .requiredFloatParameter(Labels.withId(RIGHT_OPERAND_VALUE))
-            .outputStrategy(
-                    OutputStrategies.keep())
-            .requiredSingleValueSelection(Labels.withId(OPERATION),
-                    Options.from("+", "-", "/", "*", "%"))
-            .build();
-  }
-
-  @Override
-  public FlinkDataProcessorRuntime<StaticMathOpParameters> getRuntime(DataProcessorInvocation graph,
-                                                                      ProcessingElementParameterExtractor extractor,
-                                                                      ConfigExtractor configExtractor,
-                                                                      StreamPipesClient streamPipesClient) {
-    String leftOperand = extractor.mappingPropertyValue(LEFT_OPERAND);
-    double rightOperand = extractor.singleValueParameter(RIGHT_OPERAND_VALUE, Double.class);
-    String operation = extractor.selectedSingleValue(OPERATION, String.class);
-
-    Operation arithmeticOperation = null;
-    switch (operation) {
-      case "+":
-        arithmeticOperation = new OperationAddition();
-        break;
-      case "-":
-        arithmeticOperation = new OperationSubtracting();
-        break;
-      case "*":
-        arithmeticOperation = new OperationMultiply();
-        break;
-      case "/":
-        arithmeticOperation = new OperationDivide();
-        break;
-      case "%":
-        arithmeticOperation = new OperationModulo();
-    }
-
-    StaticMathOpParameters parameters = new StaticMathOpParameters(graph, arithmeticOperation, leftOperand, rightOperand, RESULT_FIELD);
-
-    return new StaticMathOpProgram(parameters, configExtractor, streamPipesClient);
-
-  }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpParameters.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpParameters.java
deleted file mode 100644
index b8466d2d5..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpParameters.java
+++ /dev/null
@@ -1,55 +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.enricher.flink.processor.math.staticmathop;
-
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.processors.enricher.flink.processor.math.operation.Operation;
-import org.apache.streampipes.wrapper.params.binding.EventProcessorBindingParams;
-
-public class StaticMathOpParameters extends EventProcessorBindingParams {
-
-    private Operation operation;
-    private String leftOperand;
-    private double rightOperandValue;
-    private String resultField;
-
-    public StaticMathOpParameters(DataProcessorInvocation graph, Operation operation, String leftOperand, double rightOperandValue, String resultField) {
-        super(graph);
-        this.operation = operation;
-        this.leftOperand = leftOperand;
-        this.rightOperandValue = rightOperandValue;
-        this.resultField = resultField;
-    }
-
-    public Operation getOperation() {
-        return operation;
-    }
-
-    public String getLeftOperand() {
-        return leftOperand;
-    }
-
-    public double getRightOperandValue() {
-        return rightOperandValue;
-    }
-
-    public String getResultField() {
-        return resultField;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpProgram.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpProgram.java
deleted file mode 100644
index 57c0dcf94..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/math/staticmathop/StaticMathOpProgram.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.processors.enricher.flink.processor.math.staticmathop;
-
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.apache.streampipes.client.StreamPipesClient;
-import org.apache.streampipes.container.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.enricher.flink.AbstractEnricherProgram;
-
-public class StaticMathOpProgram extends AbstractEnricherProgram<StaticMathOpParameters> {
-
-    public StaticMathOpProgram(StaticMathOpParameters params,
-                               ConfigExtractor configExtractor,
-                               StreamPipesClient streamPipesClient) {
-        super(params, configExtractor, streamPipesClient);
-    }
-
-    @Override
-    protected DataStream<Event> getApplicationLogic(DataStream<Event>... dataStreams) {
-        return dataStreams[0]
-                .flatMap(new StaticMathOp(params.getOperation(), params.getLeftOperand(),
-                        params.getRightOperandValue(), params.getResultField()));
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/Operation.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/Operation.java
deleted file mode 100644
index 794a000c6..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/Operation.java
+++ /dev/null
@@ -1,25 +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.enricher.flink.processor.trigonometry;
-
-public enum Operation {
-    SIN,
-    COS,
-    TAN
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/Trigonometry.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/Trigonometry.java
deleted file mode 100644
index e7fd00f49..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/Trigonometry.java
+++ /dev/null
@@ -1,53 +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.enricher.flink.processor.trigonometry;
-
-import org.apache.flink.api.common.functions.FlatMapFunction;
-import org.apache.flink.util.Collector;
-import org.apache.streampipes.model.runtime.Event;
-
-public class Trigonometry implements FlatMapFunction<Event, Event> {
-
-    private String operand;
-    private Operation operation;
-    private String resultField;
-
-    public Trigonometry(String operand, Operation operation, String resultField) {
-        this.operand = operand;
-        this.operation = operation;
-        this.resultField = resultField;
-    }
-
-    @Override
-    public void flatMap(Event in, Collector<Event> out) throws Exception {
-        double value = in.getFieldBySelector(operand).getAsPrimitive().getAsDouble();
-        double result;
-
-        if (operation == Operation.SIN) {
-            result = Math.sin(value);
-        } else if (operation == Operation.COS) {
-            result = Math.cos(value);
-        } else {
-            result = Math.tan(value);
-        }
-        in.addField(resultField, result);
-
-        out.collect(in);
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryController.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryController.java
deleted file mode 100644
index 29735c814..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryController.java
+++ /dev/null
@@ -1,86 +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.enricher.flink.processor.trigonometry;
-
-import org.apache.streampipes.client.StreamPipesClient;
-import org.apache.streampipes.container.config.ConfigExtractor;
-import org.apache.streampipes.model.DataProcessorType;
-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.vocabulary.SO;
-import org.apache.streampipes.wrapper.flink.FlinkDataProcessorDeclarer;
-import org.apache.streampipes.wrapper.flink.FlinkDataProcessorRuntime;
-
-public class TrigonometryController extends FlinkDataProcessorDeclarer<TrigonometryParameters> {
-
-    private final String OPERAND = "operand";
-    private final String OPERATION = "operation";
-    private final String RESULT_FIELD = "trigonometryResult";
-
-
-    @Override
-    public DataProcessorDescription declareModel() {
-        return ProcessingElementBuilder.create("org.apache.streampipes.processors.enricher.flink.processor.trigonometry")
-                .withAssets(Assets.DOCUMENTATION, Assets.ICON)
-                .withLocales(Locales.EN)
-                .category(DataProcessorType.ALGORITHM)
-                .requiredStream(StreamRequirementsBuilder
-                        .create()
-                        .requiredPropertyWithUnaryMapping(EpRequirements.numberReq(),
-                                Labels.withId(OPERAND),
-                                PropertyScope.NONE)
-                        .build())
-                .outputStrategy(
-                        OutputStrategies.append(
-                                EpProperties.numberEp(Labels.empty(), RESULT_FIELD, SO.Number)))
-                .requiredSingleValueSelection(Labels.withId(OPERATION),
-                        Options.from("sin(a)", "cos(a)", "tan(a)" ))
-                .build();
-    }
-
-    @Override
-    public FlinkDataProcessorRuntime<TrigonometryParameters> getRuntime(DataProcessorInvocation graph,
-                                                                        ProcessingElementParameterExtractor extractor,
-                                                                        ConfigExtractor configExtractor,
-                                                                        StreamPipesClient streamPipesClient) {
-        String operand = extractor.mappingPropertyValue(OPERAND);
-        String operation = extractor.selectedSingleValue(OPERATION, String.class);
-
-        Operation trigonometryFunction = null;
-        switch (operation) {
-            case "sin(a)": trigonometryFunction = Operation.SIN;
-                break;
-            case "cos(a)": trigonometryFunction = Operation.COS;
-                break;
-            case "tan(a)": trigonometryFunction = Operation.TAN;
-
-        }
-
-
-        TrigonometryParameters parameters = new TrigonometryParameters(graph, operand, trigonometryFunction, RESULT_FIELD);
-
-        return new TrigonometryProgram(parameters, configExtractor, streamPipesClient);
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryParameters.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryParameters.java
deleted file mode 100644
index 5c0d80cf4..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryParameters.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.enricher.flink.processor.trigonometry;
-
-import org.apache.streampipes.model.graph.DataProcessorInvocation;
-import org.apache.streampipes.wrapper.params.binding.EventProcessorBindingParams;
-
-public class TrigonometryParameters extends EventProcessorBindingParams {
-
-    private String operand;
-    private Operation operation;
-    private String resultField;
-
-    public TrigonometryParameters(DataProcessorInvocation graph, String operand, Operation operation, String resultField) {
-        super(graph);
-        this.operand = operand;
-        this.operation = operation;
-        this.resultField = resultField;
-    }
-
-    public String getOperand() {
-        return operand;
-    }
-
-    public Operation getOperation() {
-        return operation;
-    }
-
-    public String getResultField() {
-        return resultField;
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryProgram.java b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryProgram.java
deleted file mode 100644
index ceb2d8372..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/java/org/apache/streampipes/processors/enricher/flink/processor/trigonometry/TrigonometryProgram.java
+++ /dev/null
@@ -1,39 +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.enricher.flink.processor.trigonometry;
-
-import org.apache.flink.streaming.api.datastream.DataStream;
-import org.apache.streampipes.client.StreamPipesClient;
-import org.apache.streampipes.container.config.ConfigExtractor;
-import org.apache.streampipes.model.runtime.Event;
-import org.apache.streampipes.processors.enricher.flink.AbstractEnricherProgram;
-
-public class TrigonometryProgram extends AbstractEnricherProgram<TrigonometryParameters> {
-
-    public TrigonometryProgram(TrigonometryParameters params,
-                               ConfigExtractor configExtractor,
-                               StreamPipesClient streamPipesClient) {
-        super(params, configExtractor, streamPipesClient);
-    }
-
-    @Override
-    protected DataStream<Event> getApplicationLogic(DataStream<Event>... dataStreams) {
-        return dataStreams[0].flatMap(new Trigonometry(params.getOperand(), params.getOperation(), params.getResultField()));
-    }
-}
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/documentation.md b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/documentation.md
deleted file mode 100644
index 94c104f76..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/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.
-  ~
-  -->
-
-## Math
-
-<p align="center"> 
-    <img src="icon.png" width="150px;" class="pe-image-documentation"/>
-</p>
-
-***
-
-## Description
-
-Performs calculations on event properties (+, -, *, /, %).
-
-***
-
-## Required input
-The math processor works with any event that has at least one field containing a numerical value.
-
-***
-
-## Configuration
-
-### Left operand
-The field from the input event that should be used as the left operand.
-
-### Right operand
-The field from the input event that should be used as the right operand.
-
-### Operation
-The math operation that should be performed.
-
-## Output
-The processor appends the calculation result to each input event.
\ No newline at end of file
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/icon.png b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/icon.png
deleted file mode 100644
index 4da278963..000000000
Binary files a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/icon.png and /dev/null differ
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/strings.en b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/strings.en
deleted file mode 100644
index 877a15a17..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.mathop/strings.en
+++ /dev/null
@@ -1,11 +0,0 @@
-org.apache.streampipes.processors.enricher.flink.processor.math.mathop.title=Math
-org.apache.streampipes.processors.enricher.flink.processor.math.mathop.description=Performs calculations on event properties (+, -, *, /, %)
-
-leftOperand.title=Left operand
-leftOperand.description=Select left operand
-
-rightOperand.title=Right operand
-rightOperand.description=Select right operand
-
-operation.title=Select Operation
-operation.description=
\ No newline at end of file
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/documentation.md b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/documentation.md
deleted file mode 100644
index 4e699fe7d..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/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.
-  ~
-  -->
-
-## Static Math
-
-<p align="center"> 
-    <img src="icon.png" width="150px;" class="pe-image-documentation"/>
-</p>
-
-***
-
-## Description
-
-Performs calculation on an event property with a static value (+, -, *, /, %).
-
-***
-
-## Required input
-The math processor works with any event that has at least one field containing a numerical value.
-
-***
-
-## Configuration
-
-### Left operand
-The field from the input event that should be used as the left operand.
-
-### Right operand value
-Specify the value of the right operand.
-
-### Operation
-The math operation that should be performed.
-
-## Output
-The processor appends the calculation result to each input event.
\ No newline at end of file
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/icon.png b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/icon.png
deleted file mode 100644
index 6146d8da1..000000000
Binary files a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/icon.png and /dev/null differ
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/strings.en b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/strings.en
deleted file mode 100644
index 3825f6e53..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop/strings.en
+++ /dev/null
@@ -1,10 +0,0 @@
-org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop.title=Static Math
-org.apache.streampipes.processors.enricher.flink.processor.math.staticmathop.description=Performs calculation on an event property with a static value (+, -, *, /, %)
-
-leftOperand.title=Left operand
-leftOperand.description=Select left operand
-
-rightOperandValue.title=Right operand value
-rightOperandValue.description=Specify the value of the right operand.
-
-operation.title=Select operation
\ No newline at end of file
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/documentation.md b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/documentation.md
deleted file mode 100644
index 0454239b9..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/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.
-  ~
-  -->
-
-## Trigonometry
-
-<p align="center"> 
-    <img src="icon.png" width="150px;" class="pe-image-documentation"/>
-</p>
-
-***
-
-## Description
-
-Performs Trigonometric functions (sin, cos, tan) on event properties.
-
-***
-
-## Required input
-The trigonometry processor works with any event that has at least one field containing a numerical value.
-
-***
-
-## Configuration
-
-Describe the configuration parameters here
-
-### Alpha
-The field that should be used for calculating the trigonometric function.
-
-
-### Operation
-The trigonometric function that should be calculated.
-
-## Output
-The processor appends the calculation result to each input event.
\ No newline at end of file
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/icon.png b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/icon.png
deleted file mode 100644
index 77fc667cb..000000000
Binary files a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/icon.png and /dev/null differ
diff --git a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/strings.en b/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/strings.en
deleted file mode 100644
index 051c848b9..000000000
--- a/streampipes-extensions/streampipes-processors-enricher-flink/src/main/resources/org.apache.streampipes.processors.enricher.flink.processor.trigonometry/strings.en
+++ /dev/null
@@ -1,9 +0,0 @@
-org.apache.streampipes.processors.enricher.flink.processor.trigonometry.title=Trigonometry Functions
-org.apache.streampipes.processors.enricher.flink.processor.trigonometry.description=Performs Trigonometric functions on event properties
-
-operand.title=Alpha
-operand.description=Select the alpha parameter
-
-operation.title=Operation
-operation.description=
-