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/22 14:42:08 UTC

[incubator-streampipes-extensions] branch dev updated: Add speed calculation processor

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-extensions.git


The following commit(s) were added to refs/heads/dev by this push:
     new bafef74  Add speed calculation processor
     new c01e108  Merge branch 'dev' of github.com:apache/incubator-streampipes-extensions into dev
bafef74 is described below

commit bafef74ddfb2c04271ddc2683e121c2c2abdc35b
Author: Dominik Riemer <ri...@fzi.de>
AuthorDate: Sun Mar 22 15:41:37 2020 +0100

    Add speed calculation processor
---
 .../pe/jvm/AllPipelineElementsInit.java            |  4 +-
 .../streampipes/processors/geo/jvm/GeoJvmInit.java |  4 +-
 .../distancecalculator/DistanceCalculator.java     | 16 +---
 .../geo/jvm/processor/speed/SpeedCalculator.java   | 86 ++++++++++++++++++++
 .../processor/speed/SpeedCalculatorController.java | 91 ++++++++++++++++++++++
 .../processor/speed/SpeedCalculatorParameters.java | 56 +++++++++++++
 .../geo/jvm/processor/util/DistanceUtil.java       | 34 ++++++++
 .../documentation.md                               | 45 +++++++++++
 .../strings.en                                     | 14 ++++
 9 files changed, 334 insertions(+), 16 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 5468337..6869848 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
@@ -40,6 +40,7 @@ import org.apache.streampipes.processors.geo.jvm.jts.processor.setEPSG.SetEpsgCo
 import org.apache.streampipes.processors.geo.jvm.processor.distancecalculator.DistanceCalculatorController;
 import org.apache.streampipes.processors.geo.jvm.processor.geocoder.GoogleMapsGeocodingController;
 import org.apache.streampipes.processors.geo.jvm.processor.revgeocoder.ReverseGeocodingController;
+import org.apache.streampipes.processors.geo.jvm.processor.speed.SpeedCalculatorController;
 import org.apache.streampipes.processors.geo.jvm.processor.staticgeocoder.StaticGoogleMapsGeocodingController;
 import org.apache.streampipes.processors.imageprocessing.jvm.processor.genericclassification.GenericImageClassificationController;
 import org.apache.streampipes.processors.imageprocessing.jvm.processor.imagecropper.ImageCropperController;
@@ -129,7 +130,8 @@ public class AllPipelineElementsInit extends StandaloneModelSubmitter {
             .add(new StaticGoogleMapsGeocodingController())
             .add(new ReverseGeocodingController())
             .add(new SetEpsgController())
-            .add(new LatLngToGeoController());
+            .add(new LatLngToGeoController())
+            .add(new SpeedCalculatorController());
 
 
     DeclarersSingleton.getInstance().registerDataFormats(new JsonDataFormatFactory(),
diff --git a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/GeoJvmInit.java b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/GeoJvmInit.java
index 20c53bc..34df051 100644
--- a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/GeoJvmInit.java
+++ b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/GeoJvmInit.java
@@ -32,6 +32,7 @@ import org.apache.streampipes.processors.geo.jvm.jts.processor.setEPSG.SetEpsgCo
 import org.apache.streampipes.processors.geo.jvm.processor.distancecalculator.DistanceCalculatorController;
 import org.apache.streampipes.processors.geo.jvm.processor.geocoder.GoogleMapsGeocodingController;
 import org.apache.streampipes.processors.geo.jvm.processor.revgeocoder.ReverseGeocodingController;
+import org.apache.streampipes.processors.geo.jvm.processor.speed.SpeedCalculatorController;
 import org.apache.streampipes.processors.geo.jvm.processor.staticgeocoder.StaticGoogleMapsGeocodingController;
 
 public class GeoJvmInit extends StandaloneModelSubmitter {
@@ -44,7 +45,8 @@ public class GeoJvmInit extends StandaloneModelSubmitter {
         .add(new StaticGoogleMapsGeocodingController())
         .add(new ReverseGeocodingController())
         .add(new SetEpsgController())
-        .add(new LatLngToGeoController());
+        .add(new LatLngToGeoController())
+        .add(new SpeedCalculatorController());
 
 
     DeclarersSingleton.getInstance().registerDataFormats(new JsonDataFormatFactory(),
diff --git a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/distancecalculator/DistanceCalculator.java b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/distancecalculator/DistanceCalculator.java
index a4ba37e..d310f1b 100644
--- a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/distancecalculator/DistanceCalculator.java
+++ b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/distancecalculator/DistanceCalculator.java
@@ -19,6 +19,7 @@
 package org.apache.streampipes.processors.geo.jvm.processor.distancecalculator;
 
 import org.apache.streampipes.model.runtime.Event;
+import org.apache.streampipes.processors.geo.jvm.processor.util.DistanceUtil;
 import org.apache.streampipes.wrapper.context.EventProcessorRuntimeContext;
 import org.apache.streampipes.wrapper.routing.SpOutputCollector;
 import org.apache.streampipes.wrapper.runtime.EventProcessor;
@@ -41,7 +42,7 @@ public class DistanceCalculator implements EventProcessor<DistanceCalculatorPara
     float lat2 = event.getFieldBySelector(this.params.getLat2PropertyName()).getAsPrimitive().getAsFloat();
     float long2 = event.getFieldBySelector(this.params.getLong2PropertyName()).getAsPrimitive().getAsFloat();
 
-    double resultDist = dist(lat1, long1, lat2, long2);
+    double resultDist = DistanceUtil.dist(lat1, long1, lat2, long2);
 
     event.addField("distance", resultDist);
 
@@ -53,17 +54,4 @@ public class DistanceCalculator implements EventProcessor<DistanceCalculatorPara
 
   }
 
-
-  public static float dist(float lat1, float lng1, float lat2, float lng2) {
-    double earthRadius = 6371000; //meters
-    double dLat = Math.toRadians(lat2-lat1);
-    double dLng = Math.toRadians(lng2-lng1);
-    double a = Math.sin(dLat/2) * Math.sin(dLat/2) +
-            Math.cos(Math.toRadians(lat1)) * Math.cos(Math.toRadians(lat2)) *
-                    Math.sin(dLng/2) * Math.sin(dLng/2);
-    double c = 2 * Math.atan2(Math.sqrt(a), Math.sqrt(1-a));
-    float dist = (float) (earthRadius * c);
-
-    return dist / 1000;
-  }
 }
diff --git a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculator.java b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculator.java
new file mode 100644
index 0000000..307c00a
--- /dev/null
+++ b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculator.java
@@ -0,0 +1,86 @@
+/*
+ *   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.geo.jvm.processor.speed;
+
+import org.apache.commons.collections.buffer.CircularFifoBuffer;
+import org.apache.streampipes.commons.exceptions.SpRuntimeException;
+import org.apache.streampipes.model.runtime.Event;
+import org.apache.streampipes.processors.geo.jvm.processor.util.DistanceUtil;
+import org.apache.streampipes.wrapper.context.EventProcessorRuntimeContext;
+import org.apache.streampipes.wrapper.routing.SpOutputCollector;
+import org.apache.streampipes.wrapper.runtime.EventProcessor;
+
+public class SpeedCalculator implements EventProcessor<SpeedCalculatorParameters> {
+
+  private CircularFifoBuffer buffer;
+
+  private String latitudeFieldName;
+  private String longitudeFieldName;
+  private String timestampFieldName;
+
+  @Override
+  public void onInvocation(SpeedCalculatorParameters parameters, SpOutputCollector spOutputCollector, EventProcessorRuntimeContext runtimeContext) throws SpRuntimeException {
+    this.buffer = new CircularFifoBuffer(parameters.getCountWindowSize());
+    this.latitudeFieldName = parameters.getLatitudeFieldName();
+    this.longitudeFieldName = parameters.getLongitudeFieldName();
+    this.timestampFieldName = parameters.getTimestampFieldName();
+  }
+
+  @Override
+  public void onEvent(Event event, SpOutputCollector collector) throws SpRuntimeException {
+    if (this.buffer.isFull()) {
+      Event firstEvent = (Event) buffer.get();
+      Float speed = calculateSpeed(firstEvent, event);
+      event.addField("speed", speed);
+      collector.collect(event);
+    }
+    this.buffer.add(event);
+  }
+
+  private Float calculateSpeed(Event firstEvent, Event currentEvent) {
+    Float firstLatitude = getFloat(firstEvent, latitudeFieldName);
+    Float firstLongitude = getFloat(firstEvent, longitudeFieldName);
+    Long firstTimestamp = getLong(firstEvent, timestampFieldName);
+
+    Float currentLatitude = getFloat(currentEvent, latitudeFieldName);
+    Float currentLongitude = getFloat(currentEvent, longitudeFieldName);
+    Long currentTimestamp = getLong(currentEvent, timestampFieldName);
+
+    Float distanceInKm = DistanceUtil.dist(firstLatitude, firstLongitude, currentLatitude,
+            currentLongitude);
+
+    Long durationInSeconds = (currentTimestamp - firstTimestamp) / 1000;
+
+    Float speedInKilometersPerSecond = distanceInKm / durationInSeconds;
+    Float speedInKilometerPerHour = speedInKilometersPerSecond * 3600;
+
+    return speedInKilometerPerHour;
+  }
+
+  private Long getLong(Event event, String fieldName) {
+    return event.getFieldBySelector(fieldName).getAsPrimitive().getAsLong();
+  }
+
+  private Float getFloat(Event event, String fieldName) {
+    return event.getFieldBySelector(fieldName).getAsPrimitive().getAsFloat();
+  }
+
+  @Override
+  public void onDetach() throws SpRuntimeException {
+
+  }
+}
diff --git a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculatorController.java b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculatorController.java
new file mode 100644
index 0000000..a9170d4
--- /dev/null
+++ b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculatorController.java
@@ -0,0 +1,91 @@
+/*
+ *   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.geo.jvm.processor.speed;
+
+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.PrimitivePropertyBuilder;
+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.EpRequirements;
+import org.apache.streampipes.sdk.helpers.Labels;
+import org.apache.streampipes.sdk.helpers.Locales;
+import org.apache.streampipes.sdk.helpers.OutputStrategies;
+import org.apache.streampipes.sdk.utils.Assets;
+import org.apache.streampipes.sdk.utils.Datatypes;
+import org.apache.streampipes.vocabulary.Geo;
+import org.apache.streampipes.vocabulary.SO;
+import org.apache.streampipes.wrapper.standalone.ConfiguredEventProcessor;
+import org.apache.streampipes.wrapper.standalone.declarer.StandaloneEventProcessingDeclarer;
+
+import java.net.URI;
+
+public class SpeedCalculatorController extends StandaloneEventProcessingDeclarer<SpeedCalculatorParameters> {
+
+  private static final String TIMESTAMP_KEY = "timestamp-key";
+  private static final String LATITUDE_KEY = "latitude-key";
+  private static final String LONGITUDE_KEY = "longitude-key" ;
+  private static final String SPEED_KEY = "speed-key";
+  private static final String COUNT_WINDOW_KEY = "count-window-key";
+
+  @Override
+  public DataProcessorDescription declareModel() {
+    return ProcessingElementBuilder.create("org.apache.streampipes.processors.geo.jvm.processor" +
+            ".speed")
+            .category(DataProcessorType.ALGORITHM)
+            .withAssets(Assets.DOCUMENTATION)
+            .withLocales(Locales.EN)
+            .requiredStream(StreamRequirementsBuilder
+              .create()
+              .requiredPropertyWithUnaryMapping(EpRequirements.timestampReq(),
+                      Labels.withId(TIMESTAMP_KEY), PropertyScope.HEADER_PROPERTY)
+              .requiredPropertyWithUnaryMapping(EpRequirements.domainPropertyReq(Geo.lat)
+                      , Labels.withId(LATITUDE_KEY), PropertyScope.MEASUREMENT_PROPERTY)
+              .requiredPropertyWithUnaryMapping(EpRequirements.domainPropertyReq(Geo.lng)
+                      , Labels.withId(LONGITUDE_KEY), PropertyScope.MEASUREMENT_PROPERTY)
+              .build())
+            .requiredIntegerParameter(Labels.withId(COUNT_WINDOW_KEY))
+            .outputStrategy(
+              OutputStrategies.append(PrimitivePropertyBuilder
+                      .create(Datatypes.Float,"speed")
+                      .domainProperty(SO.Number)
+                      .measurementUnit(URI.create("http://qudt.org/vocab/unit#KilometerPerHour"))
+                      .build())
+            )
+            .build();
+  }
+
+  @Override
+  public ConfiguredEventProcessor<SpeedCalculatorParameters> onInvocation(DataProcessorInvocation graph,
+                                                  ProcessingElementParameterExtractor extractor) {
+    String latitudeFieldName = extractor.mappingPropertyValue(LATITUDE_KEY);
+    String longitudeFieldName = extractor.mappingPropertyValue(LONGITUDE_KEY);
+    String timestampFieldName = extractor.mappingPropertyValue(TIMESTAMP_KEY);
+
+    Integer countWindowSize = extractor.singleValueParameter(COUNT_WINDOW_KEY, Integer.class);
+
+    SpeedCalculatorParameters staticParam = new SpeedCalculatorParameters(graph,
+            latitudeFieldName, longitudeFieldName, timestampFieldName, countWindowSize);
+
+    return new ConfiguredEventProcessor<>(staticParam, SpeedCalculator::new);
+  }
+
+
+}
diff --git a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculatorParameters.java b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculatorParameters.java
new file mode 100644
index 0000000..8f865cb
--- /dev/null
+++ b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/speed/SpeedCalculatorParameters.java
@@ -0,0 +1,56 @@
+/*
+ *   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.geo.jvm.processor.speed;
+
+import org.apache.streampipes.model.graph.DataProcessorInvocation;
+import org.apache.streampipes.wrapper.params.binding.EventProcessorBindingParams;
+
+public class SpeedCalculatorParameters extends EventProcessorBindingParams {
+
+  private String latitudeFieldName;
+  private String longitudeFieldName;
+  private String timestampFieldName;
+  private Integer countWindowSize;
+
+  public SpeedCalculatorParameters(DataProcessorInvocation graph,
+                                   String latitudeFieldName,
+                                   String longitudeFieldName,
+                                   String timestampFieldName,
+                                   Integer countWindowSize) {
+    super(graph);
+    this.latitudeFieldName = latitudeFieldName;
+    this.longitudeFieldName = longitudeFieldName;
+    this.timestampFieldName = timestampFieldName;
+    this.countWindowSize = countWindowSize;
+  }
+
+  public String getLatitudeFieldName() {
+    return latitudeFieldName;
+  }
+
+  public String getLongitudeFieldName() {
+    return longitudeFieldName;
+  }
+
+  public String getTimestampFieldName() {
+    return timestampFieldName;
+  }
+
+  public Integer getCountWindowSize() {
+    return countWindowSize;
+  }
+}
diff --git a/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/util/DistanceUtil.java b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/util/DistanceUtil.java
new file mode 100644
index 0000000..136eecd
--- /dev/null
+++ b/streampipes-processors-geo-jvm/src/main/java/org/apache/streampipes/processors/geo/jvm/processor/util/DistanceUtil.java
@@ -0,0 +1,34 @@
+/*
+ *   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.geo.jvm.processor.util;
+
+public class DistanceUtil {
+
+  public static float dist(float lat1, float lng1, float lat2, float lng2) {
+    double earthRadius = 6371000; //meters
+    double dLat = Math.toRadians(lat2-lat1);
+    double dLng = Math.toRadians(lng2-lng1);
+    double a = Math.sin(dLat/2) * Math.sin(dLat/2) +
+            Math.cos(Math.toRadians(lat1)) * Math.cos(Math.toRadians(lat2)) *
+                    Math.sin(dLng/2) * Math.sin(dLng/2);
+    double c = 2 * Math.atan2(Math.sqrt(a), Math.sqrt(1-a));
+    float dist = (float) (earthRadius * c);
+
+    return dist / 1000;
+  }
+
+}
diff --git a/streampipes-processors-geo-jvm/src/main/resources/org.apache.streampipes.processors.geo.jvm.processor.speed/documentation.md b/streampipes-processors-geo-jvm/src/main/resources/org.apache.streampipes.processors.geo.jvm.processor.speed/documentation.md
new file mode 100644
index 0000000..605501f
--- /dev/null
+++ b/streampipes-processors-geo-jvm/src/main/resources/org.apache.streampipes.processors.geo.jvm.processor.speed/documentation.md
@@ -0,0 +1,45 @@
+<!--
+  ~ 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.
+  ~
+  -->
+
+## Speed Calculator
+
+***
+
+## Description
+
+Calculates the speed (in km/h) based on two latitude/longitude pairs. The distance of the two location pairs can be
+ configured.
+
+***
+
+## Required input
+
+Requires a data stream that provides latitude and longitude values.
+
+***
+
+## Configuration
+
+Describe the configuration parameters here
+
+### 1st parameter
+
+
+### 2nd parameter
+
+## Output
\ No newline at end of file
diff --git a/streampipes-processors-geo-jvm/src/main/resources/org.apache.streampipes.processors.geo.jvm.processor.speed/strings.en b/streampipes-processors-geo-jvm/src/main/resources/org.apache.streampipes.processors.geo.jvm.processor.speed/strings.en
new file mode 100644
index 0000000..a695358
--- /dev/null
+++ b/streampipes-processors-geo-jvm/src/main/resources/org.apache.streampipes.processors.geo.jvm.processor.speed/strings.en
@@ -0,0 +1,14 @@
+org.apache.streampipes.processors.geo.jvm.processor.speed.title=Speed Calculator
+org.apache.streampipes.processors.geo.jvm.processor.speed.description=Calculates the speed of two latlng pairs in kilometers per hour
+
+timestamp-key.title=Timestamp field
+timestamp-key.description=
+
+latitude-key.title=Latitude field
+latitude-key.description=
+
+longitude-key.title=Longitude field
+longitude-key.description=
+
+count-window-key.title=Count window
+count-window-key.description=
\ No newline at end of file