You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@streampipes.apache.org by wi...@apache.org on 2020/08/10 13:06:30 UTC

[incubator-streampipes] branch dev updated (6269512 -> b618b85)

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

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


    from 6269512  [hotfix] Add missing license headers
     new be26f97  [hotfix] some minor renamings
     new 86dbbde  Merge branch 'dev' of https://github.com/apache/incubator-streampipes into dev
     new b618b85  [hotfix] updated setup.py and README.md

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


Summary of changes:
 streampipes-wrapper-python/README.md           | 52 ++++++++++++++++++--------
 streampipes-wrapper-python/setup.py            |  4 +-
 streampipes-wrapper-python/streampipes/core.py | 24 ++++++------
 3 files changed, 52 insertions(+), 28 deletions(-)


[incubator-streampipes] 01/03: [hotfix] some minor renamings

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

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

commit be26f979fe4c052384423502a88bfd654cf58ba4
Author: Patrick Wiener <wi...@fzi.de>
AuthorDate: Mon Aug 10 11:04:26 2020 +0200

    [hotfix] some minor renamings
---
 streampipes-wrapper-python/streampipes/core.py | 24 +++++++++++++-----------
 1 file changed, 13 insertions(+), 11 deletions(-)

diff --git a/streampipes-wrapper-python/streampipes/core.py b/streampipes-wrapper-python/streampipes/core.py
index b2fa5c3..543f5d7 100644
--- a/streampipes-wrapper-python/streampipes/core.py
+++ b/streampipes-wrapper-python/streampipes/core.py
@@ -15,15 +15,17 @@
 # limitations under the License.
 #
 """contains relevant base classes"""
+import abc
 import json
 import logging
 import threading
-from abc import ABC, abstractmethod
 from confluent_kafka.admin import AdminClient
 from confluent_kafka import Producer, Consumer
 
 
-class EventProcessor(ABC):
+class EventProcessor(object):
+    __metaclass__ = abc.ABC
+
     _DEFAULT_KAFKA_CONSUMER_CONFIG = {
         'bootstrap.servers': 'kafka:9092',
         'enable.auto.commit': True,
@@ -67,7 +69,7 @@ class EventProcessor(ABC):
 
     def init(self):
         self.logger.info('start processor {}'.format(self.invocation_id))
-        thread = threading.Thread(target=self.__consume, name=self.invocation_id)
+        thread = threading.Thread(target=self._consume, name=self.invocation_id)
         thread.start()
         self._threads['kafka'] = thread
 
@@ -81,27 +83,27 @@ class EventProcessor(ABC):
     def __del__(self):
         pass
 
-    @abstractmethod
+    @abc.abstractmethod
     def on_invocation(self):
         """ on_invocation is called when processor is started """
 
-    @abstractmethod
+    @abc.abstractmethod
     def on_event(self, event):
         """ on_event receives kafka consumer messages """
         pass
 
-    @abstractmethod
+    @abc.abstractmethod
     def on_detach(self):
         """ on_detach is called when processor is stopped """
         pass
 
-    def __on_event(self, event):
+    def _on_event(self, event):
         result = self.on_event(event)
 
         if result is not None:
-            self.__produce(result)
+            self._produce(result)
 
-    def __consume(self):
+    def _consume(self):
         """ retrieve events from kafka """
         self._consumer.subscribe(topics=[self._input_topics])
         self._running = True
@@ -127,9 +129,9 @@ class EventProcessor(ABC):
                     self.logger.info("Not a valid json {}".format(e))
                     continue
 
-                self.__on_event(event)
+                self._on_event(event)
 
-    def __produce(self, result):
+    def _produce(self, result):
         """ send events to kafka """
         event = json.dumps(result).encode('utf-8')
         try:


[incubator-streampipes] 03/03: [hotfix] updated setup.py and README.md

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

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

commit b618b859d16ce37a3a7244530828238b664996b1
Author: Patrick Wiener <wi...@fzi.de>
AuthorDate: Mon Aug 10 15:06:07 2020 +0200

    [hotfix] updated setup.py and README.md
---
 streampipes-wrapper-python/README.md           | 52 ++++++++++++++++++--------
 streampipes-wrapper-python/setup.py            |  4 +-
 streampipes-wrapper-python/streampipes/core.py |  2 +-
 3 files changed, 40 insertions(+), 18 deletions(-)

diff --git a/streampipes-wrapper-python/README.md b/streampipes-wrapper-python/README.md
index d77ce90..9d31a29 100644
--- a/streampipes-wrapper-python/README.md
+++ b/streampipes-wrapper-python/README.md
@@ -15,15 +15,37 @@
   ~ limitations under the License.
   ~
   -->
-# [WIP] Apache StreamPipes Wrapper for Python
 
+[![Github Actions](https://img.shields.io/github/workflow/status/apache/incubator-streampipes/build-and-deploy-docker-dev)](https://github.com/apache/incubator-streampipes/actions/)
+[![Docker pulls](https://img.shields.io/docker/pulls/apachestreampipes/backend.svg)](https://hub.docker.com/r/apachestreampipes/backend/)
+[![Maven central](https://img.shields.io/maven-central/v/org.apache.streampipes/streampipes-backend.svg)](https://img.shields.io/maven-central/v/org.apache.streampipes/streampipes-backend.svg)
+[![License](https://img.shields.io/github/license/apache/incubator-streampipes.svg)](http://www.apache.org/licenses/LICENSE-2.0)
+[![Last commit](https://img.shields.io/github/last-commit/apache/incubator-streampipes.svg)]()
+[![Twitter](https://img.shields.io/twitter/follow/StreamPipes.svg?label=Follow&style=social)](https://twitter.com/StreamPipes)
+
+## Apache StreamPipes Wrapper for Python [WIP]
 **NOTE**: 
 
-> The python wrapper is currently under development. Thus, it only works in combination when having Java processor for describing, registration and talking to the backend.
+> The StreamPipes wrapper for python is currently under development. Thus, the processor model description still needs to be implemented externally in Java.
+
+## Apache StreamPipes
+Apache StreamPipes (incubating) enables flexible modeling of stream processing pipelines by providing a graphical 
+modeling editor on top of existing stream processing frameworks.
+
+It leverages non-technical users to quickly define and execute processing pipelines based on an easily extensible 
+toolbox of data sources, data processors and data sinks. StreamPipes has an exchangeable runtime execution layer and executes pipelines using one of the provided wrappers, e.g., for Apache Flink or Apache Kafka Streams.
+
+Pipeline elements in StreamPipes can be installed at runtime - the built-in SDK allows to easily implement new 
+pipeline elements according to your needs. Pipeline elements are standalone microservices that can run anywhere - centrally on your server, in a large-scale cluster or close at the edge.
+
 
-### A minimal example
-#### Define a processor
-```
+## A Speudocode Example
+**NOTE**:
+Only works in combination with Java!
+````
+from streampipes.core import StandaloneModelSubmitter
+from streampipes.manager import Declarer
+from streampipes.model.pipeline_element_config import Config
 from streampipes.core import EventProcessor
 
 
@@ -38,15 +60,6 @@ class HelloWorldProcessor(EventProcessor):
 
     def on_detach(self):
         pass
-```
-This processor received an event `dict` and adds a new `greeting` field including the message `hello world` to it.
-#### Add to processor dict
-````
-from streampipes.core import StandaloneModelSubmitter
-from streampipes.manager import Declarer
-from streampipes.model.pipeline_element_config import Config
-
-from helloworld import HelloWorldProcessor
 
 
 def main():
@@ -85,4 +98,13 @@ def main():
 if __name__ == '__main__':
     main()
 ````
-Add the newly defined `HelloWorldProcessor` to the processors dictionary including a unique id `org.apache.streampipes.processors.python.helloworld`.
+
+### DISCLAIMER (WIP)
+Apache StreamPipes is an effort undergoing incubation at The Apache Software Foundation (ASF), sponsored by the Apache
+Incubator. Incubation is required of all newly accepted projects until a further review indicates that the
+infrastructure, communications, and decision making process have stabilized in a manner consistent with other successful ASF projects. While incubation status is not necessarily a reflection of the completeness or stability of the code, it does indicate that the project has yet to be fully endorsed by the ASF.
+
+Some of the incubating project’s releases may not be fully compliant with ASF policy. For example, releases may have incomplete or un-reviewed licensing conditions. What follows is a list of known issues the project is currently aware of (note that this list, by definition, is likely to be incomplete):
+(currently no issues are known)
+
+If you are planning to incorporate this work into your product/project, please be aware that you will need to conduct a thorough licensing review to determine the overall implications of including this work. For the current status of this project through the Apache Incubator visit: https://incubator.apache.org/projects/streampipes.html
diff --git a/streampipes-wrapper-python/setup.py b/streampipes-wrapper-python/setup.py
index 7d51140..a4e074c 100644
--- a/streampipes-wrapper-python/setup.py
+++ b/streampipes-wrapper-python/setup.py
@@ -26,8 +26,8 @@ with io.open(os.path.join(this_directory, 'README.md'), 'r', encoding='utf-8') a
     long_description = f.read()
 
 setup(
-    name='apache-streampipes-python',
-    version='0.67.0-SNAPSHOT',
+    name='apache-streampipes',
+    version='0.67.0.dev1',
     packages=find_packages(),
     package_data={'streampipes': ['api/templates/*']},
     url='https://github.com/apache/incubator-streampipes',
diff --git a/streampipes-wrapper-python/streampipes/core.py b/streampipes-wrapper-python/streampipes/core.py
index 543f5d7..cf21c91 100644
--- a/streampipes-wrapper-python/streampipes/core.py
+++ b/streampipes-wrapper-python/streampipes/core.py
@@ -24,7 +24,7 @@ from confluent_kafka import Producer, Consumer
 
 
 class EventProcessor(object):
-    __metaclass__ = abc.ABC
+    __metaclass__ = abc.ABC0
 
     _DEFAULT_KAFKA_CONSUMER_CONFIG = {
         'bootstrap.servers': 'kafka:9092',


[incubator-streampipes] 02/03: Merge branch 'dev' of https://github.com/apache/incubator-streampipes into dev

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

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

commit 86dbbdecf52a6683cd75dfbb38b02837a6234107
Merge: be26f97 6269512
Author: Patrick Wiener <wi...@fzi.de>
AuthorDate: Mon Aug 10 11:04:34 2020 +0200

    Merge branch 'dev' of https://github.com/apache/incubator-streampipes into dev

 .github/workflows/build.yml                        |    2 +-
 pom.xml                                            |    1 +
 .../backend/StreamPipesBackendApplication.java     |   11 +-
 .../backend/StreamPipesResourceConfig.java         |   42 +-
 .../init/AdapterMasterContainerResourceConfig.java |    4 +
 .../master/management/GuessManagement.java         |   69 +-
 .../master/management/SourcesManagement.java       |    1 +
 .../master/management/WorkerRestClient.java        |   27 +-
 .../container/master/rest/AdapterResource.java     |   45 +-
 .../master/rest/AdapterTemplateResource.java       |   30 +-
 .../container/master/rest/DescriptionResource.java |   27 +-
 .../container/master/rest/GuessResource.java       |   53 +-
 .../master/rest/RuntimeResolvableResource.java     |   21 +-
 .../container/master/rest/SourcesResource.java     |    2 +-
 .../master/rest/WorkerAdministrationResource.java  |   16 +-
 .../init/AdapterWorkerContainerResourceConfig.java |    3 +
 .../worker/management/MasterRestClient.java        |   10 +-
 .../container/worker/rest/FileResource.java        |   10 +-
 .../container/worker/rest/GuessResource.java       |   24 +-
 .../worker/rest/RuntimeResolvableResource.java     |   47 +-
 .../container/worker/rest/WorkerResource.java      |   63 +-
 .../connect/rest/AbstractContainerResource.java    |    9 +-
 .../streampipes/connect/adapter/Adapter.java       |    4 +-
 .../adapter/exception/WorkerAdapterException.java  |   23 +-
 .../TransformSchemaAdapterPipelineElement.java     |    2 +-
 .../elements/TransformStreamAdapterElement.java    |    4 +-
 .../container/html/model/Description.java          |    9 +
 .../html/page/WelcomePageGeneratorImpl.java        |    6 +-
 streampipes-model-client/pom.xml                   |   52 +-
 .../model/client/endpoint/RdfEndpoint.java         |    4 +
 .../model/client/endpoint/RdfEndpointItem.java     |    9 +
 .../client/matching/MatchingResultMessage.java     |    3 +
 .../client/messages/AppInstallationMessage.java    |   61 -
 .../messages/ProaSenseNotificationMessage.java     |  113 -
 .../model/client/messages/SuccessMessageLd.java    |   42 -
 .../apache/streampipes/model/client/user/Role.java |    7 +-
 .../client/user/ShiroAuthenticationRequest.java    |    4 +
 .../apache/streampipes/model/client/user/User.java |   31 +-
 .../pom.xml                                        |   24 +-
 .../model/shared/annotation/TsIgnore.java          |    9 +-
 .../model/shared/annotation/TsModel.java           |    9 +-
 streampipes-model/pom.xml                          |  159 +-
 .../org/apache/streampipes/model/AdapterType.java  |   16 +
 .../streampipes/model/DataProcessorType.java       |   15 +
 .../org/apache/streampipes/model/DataSinkType.java |   16 +
 .../apache/streampipes/model}/ErrorMessageLd.java  |    2 +-
 .../org/apache/streampipes/model}/MessageLd.java   |    2 +-
 .../apache/streampipes/model}/NotificationLd.java  |    2 +-
 .../org/apache/streampipes/model/SpDataSet.java    |    3 +-
 .../org/apache/streampipes/model/SpDataStream.java |   14 +-
 .../apache/streampipes/model}/VirtualSensor.java   |    4 +-
 .../model/base/AbstractStreamPipesEntity.java      |   13 +-
 .../model/base/ConsumableStreamPipesEntity.java    |    5 +-
 .../model/base/InvocableStreamPipesEntity.java     |   21 +-
 .../model/base/StreamPipesJsonLdContainer.java     |   10 +-
 .../model/base/UnnamedStreamPipesEntity.java       |   11 +-
 .../streampipes/model/connect/ListDescription.java |   56 -
 .../model/connect/adapter/AdapterDescription.java  |   21 +-
 .../connect/adapter/AdapterDescriptionList.java    |    2 +
 .../connect/adapter/AdapterSetDescription.java     |    5 +
 .../connect/adapter/AdapterStreamDescription.java  |    5 +
 .../adapter/GenericAdapterSetDescription.java      |    2 +
 .../adapter/GenericAdapterStreamDescription.java   |    2 +
 .../adapter/SpecificAdapterSetDescription.java     |    2 +
 .../adapter/SpecificAdapterStreamDescription.java  |    2 +
 .../model/connect/grounding/FormatDescription.java |    7 +-
 .../connect/grounding/FormatDescriptionList.java   |    2 +
 .../connect/grounding/ProtocolDescription.java     |    7 +-
 .../connect/grounding/ProtocolDescriptionList.java |    2 +
 .../model/connect/guess/GuessSchema.java           |    2 +
 .../rules/TransformationRuleDescription.java       |   29 +
 .../CreateNestedRuleDescription.java               |    2 +-
 .../{Schema => schema}/DeleteRuleDescription.java  |    2 +-
 .../{Schema => schema}/MoveRuleDescription.java    |    2 +-
 .../{Schema => schema}/RenameRuleDescription.java  |    2 +-
 .../SchemaTransformationRuleDescription.java       |    3 +-
 .../EventRateTransformationRuleDescription.java    |    2 +-
 ...oveDuplicatesTransformationRuleDescription.java |    2 +-
 .../StreamTransformationRuleDescription.java       |    8 +-
 .../value/TimestampTransformationRuleMode.java     |    1 +
 .../value/ValueTransformationRuleDescription.java  |    7 +
 .../model/dashboard/DashboardEntity.java           |   14 +-
 .../model/dashboard/DashboardModel.java            |   11 +-
 .../model/dashboard/DashboardWidgetModel.java      |    2 +
 .../model/dashboard/DashboardWidgetSettings.java   |   13 +-
 .../model/dashboard/VisualizablePipeline.java      |   12 +
 .../model/graph/DataProcessorDescription.java      |    5 +-
 .../model/graph/DataProcessorInvocation.java       |    9 +-
 .../model/graph/DataSinkDescription.java           |    5 +-
 .../model/graph/DataSinkInvocation.java            |    7 +-
 .../model/graph/DataSourceDescription.java         |    9 +-
 .../model/grounding/EventGrounding.java            |   13 +-
 .../model/grounding/TopicDefinition.java           |    5 +
 .../model/grounding/TransportProtocol.java         |   26 +-
 .../model/message}/DataSetModificationMessage.java |    5 +-
 .../streampipes/model/message}/ErrorMessage.java   |    9 +-
 .../apache/streampipes/model/message}/Message.java |   16 +-
 .../streampipes/model/message}/Notification.java   |    6 +-
 .../model/message}/NotificationType.java           |    2 +-
 .../streampipes/model/message}/Notifications.java  |   37 +-
 .../message}/PipelineModificationMessage.java      |    6 +-
 .../model/message}/PipelineStatusMessage.java      |    5 +-
 .../model/message}/PipelineStatusMessageType.java  |    2 +-
 .../model/message}/SetupStatusMessage.java         |    2 +-
 .../streampipes/model/message}/SuccessMessage.java |    5 +-
 .../streampipes/model/output/OutputStrategy.java   |   18 +-
 .../model}/pipeline/ElementComposition.java        |    2 +-
 .../streampipes/model}/pipeline/Pipeline.java      |   14 +-
 .../model}/pipeline/PipelineCategory.java          |   10 +-
 .../pipeline/PipelineElementRecommendation.java    |    2 +-
 .../PipelineElementRecommendationMessage.java      |    5 +-
 .../model}/pipeline/PipelineElementStatus.java     |    2 +-
 .../model}/pipeline/PipelineModification.java      |    2 +-
 .../PipelineModificationErrorDescription.java      |    2 +-
 .../model}/pipeline/PipelineOperationStatus.java   |    5 +-
 .../quality/EventPropertyQualityDefinition.java    |    7 +
 .../quality/EventStreamQualityDefinition.java      |    5 +
 .../model/quality/MeasurementProperty.java         |    7 +-
 .../ContainerProvidedOptionsParameterRequest.java  |    2 +-
 .../model/runtime/RuntimeOptionsRequest.java       |    5 +-
 .../model/runtime/RuntimeOptionsResponse.java      |    5 +-
 .../streampipes/model/schema/EventProperty.java    |   15 +-
 .../model/schema/ValueSpecification.java           |    5 +
 .../model/staticproperty/MappingProperty.java      |   13 +-
 .../model/staticproperty/MappingPropertyNary.java  |    5 +-
 .../model/staticproperty/OneOfStaticProperty.java  |    4 +
 .../RuntimeResolvableAnyStaticProperty.java        |    3 +-
 .../RuntimeResolvableOneOfStaticProperty.java      |    3 +-
 .../staticproperty/SelectionStaticProperty.java    |   12 +-
 .../model/staticproperty/StaticProperty.java       |   22 +
 .../org/apache/streampipes/model/user/User.java    |   77 -
 .../org/apache/streampipes/model/util/Cloner.java  |    2 +
 .../streampipes/model/util/RdfIdGenerator.java     |   24 +-
 .../connect/adapter/AdapterDescriptionTest.java    |    6 +-
 .../performance/pipeline/PipelineGenerator.java    |    4 +-
 .../manager/data/PipelineGraphBuilder.java         |    2 +-
 .../manager/endpoint/EndpointItemParser.java       |    6 +-
 .../manager/execution/http/GraphSubmitter.java     |    6 +-
 .../manager/execution/http/HttpRequestBuilder.java |    2 +-
 .../manager/execution/http/PipelineExecutor.java   |    8 +-
 .../execution/http/PipelineStorageService.java     |    2 +-
 .../execution/status/PipelineStatusManager.java    |    2 +-
 .../manager/matching/DataSetGroundingSelector.java |    2 +-
 .../matching/PipelineVerificationHandler.java      |    6 +-
 .../monitoring/runtime/PipelineObserver.java       |    4 +-
 .../monitoring/runtime/PipelineStreamReplacer.java |    2 +-
 .../monitoring/runtime/SepStoppedMonitoring.java   |    2 +-
 .../SepStoppedMonitoringPipelineBuilder.java       |    4 +-
 .../monitoring/runtime/SimilarStreamFinder.java    |    2 +-
 .../streampipes/manager/operations/Operations.java |   14 +-
 .../manager/recommender/ElementRecommender.java    |    6 +-
 .../remote/ContainerProvidedOptionsHandler.java    |    2 +-
 .../setup/CacheInitializationInstallationStep.java |    4 +-
 .../manager/setup/CouchDbInstallationStep.java     |    4 +-
 .../setup/EmpireInitializerInstallationStep.java   |    4 +-
 .../manager/setup/InstallationStep.java            |    2 +-
 .../streampipes/manager/setup/Installer.java       |    4 +-
 .../setup/PipelineElementInstallationStep.java     |    4 +-
 .../setup/UserRegistrationInstallationStep.java    |    4 +-
 .../streampipes/manager/storage/UserService.java   |   30 +-
 .../manager/template/PipelineGenerator.java        |    6 +-
 .../template/PipelineTemplateGenerator.java        |    2 +-
 .../PipelineTemplateInvocationGenerator.java       |    2 +-
 .../PipelineTemplateInvocationHandler.java         |    4 +-
 .../manager/util/PipelineVerificationUtils.java    |    2 +-
 .../manager/verification/ElementVerifier.java      |   10 +-
 .../verification/messages/VerificationError.java   |    2 +-
 .../verification/messages/VerificationResult.java  |    4 +-
 .../verification/messages/VerificationWarning.java |    2 +-
 .../verification/structure/AbstractVerifier.java   |    2 +-
 .../verification/structure/GeneralVerifier.java    |    2 +-
 .../streampipes/manager/matching/v2/TestUtils.java |    2 +-
 .../streampipes/manager/pipeline/StopPipeline.java |    2 +-
 .../manager/pipeline/TestPipelineExecution.java    |    2 +-
 .../manager/pipeline/TestPipelineStorage.java      |    2 +-
 streampipes-rest-shared/pom.xml                    |    4 -
 .../rest/shared/annotation/JacksonSerialized.java  |   22 +-
 .../shared/serializer/GsonClientModelProvider.java |    7 +
 .../rest/shared/serializer/GsonJerseyProvider.java |   91 +-
 .../rest/shared/serializer/GsonWithIdProvider.java |   11 +-
 .../shared/serializer/GsonWithoutIdProvider.java   |   11 +-
 .../serializer/JacksonSerializationProvider.java   |   62 +
 ...JerseyProvider.java => JsonJerseyProvider.java} |   37 +-
 .../rest/shared/serializer/JsonLdProvider.java     |   11 +-
 .../streampipes/rest/shared/util/JsonLdUtils.java  |   25 +-
 .../streampipes/rest/shared/util/SpMediaType.java  |    4 +
 .../org/apache/streampipes/rest/api/IPipeline.java |    2 +-
 .../rest/impl/AbstractRestInterface.java           |   48 +-
 .../streampipes/rest/impl/Authentication.java      |    8 +-
 .../rest/impl/ContainerProvidedOptions.java        |    2 +-
 .../apache/streampipes/rest/impl/Deployment.java   |    4 +-
 .../rest/impl/InternalPipelineTemplates.java       |    2 +-
 .../apache/streampipes/rest/impl/Notification.java |    2 +-
 .../streampipes/rest/impl/OntologyContext.java     |    2 +-
 .../streampipes/rest/impl/OntologyKnowledge.java   |    2 +-
 .../rest/impl/OntologyPipelineElement.java         |   49 +-
 .../streampipes/rest/impl/PipelineCategory.java    |   16 +-
 .../rest/impl/PipelineElementCategory.java         |   19 +-
 .../rest/impl/PipelineElementImport.java           |   49 +-
 .../rest/impl/PipelineElementRuntimeInfo.java      |    6 +-
 .../streampipes/rest/impl/PipelineTemplate.java    |    2 +-
 .../rest/impl/PipelineWithUserResource.java        |   59 +-
 .../apache/streampipes/rest/impl/RdfEndpoint.java  |   69 +-
 .../rest/impl/SemanticEventConsumer.java           |   49 +-
 .../rest/impl/SemanticEventProcessingAgent.java    |   58 +-
 .../rest/impl/SemanticEventProducer.java           |   54 +-
 .../org/apache/streampipes/rest/impl/Setup.java    |    4 +-
 .../org/apache/streampipes/rest/impl/User.java     |    2 +-
 .../streampipes/rest/impl/VirtualSensor.java       |    4 +-
 .../streampipes/rest/impl/dashboard/Dashboard.java |    2 +-
 .../rest/impl/dashboard/DashboardWidget.java       |   33 +-
 .../rest/impl/dashboard/VisualizablePipeline.java  |   25 +-
 .../impl/datalake/DataLakeNoUserResourceV3.java    |   15 +-
 .../rest/impl/datalake/DataLakeResourceV3.java     |   20 +-
 .../rest/impl/datalake/DataLakeWidgetResource.java |   25 +-
 .../impl/nouser/PipelineElementImportNoUser.java   |   40 +-
 .../rest/management/PipelineManagement.java        |    8 +-
 ...AbstractConfigurablePipelineElementBuilder.java |   30 +
 .../sdk/extractor/AbstractParameterExtractor.java  |    4 +
 streampipes-serializers/pom.xml                    |    4 +
 .../serializers/json/GsonSerializer.java           |   14 +-
 .../json/{Utils.java => JacksonSerializer.java}    |   32 +-
 .../apache/streampipes/serializers/json/Utils.java |    2 +-
 .../jsonld/CustomAnnotationProvider.java           |   33 +-
 .../storage/api/IPipelineCategoryStorage.java      |    2 +-
 .../api/IPipelineElementConnectionStorage.java     |    2 +-
 .../api/IPipelineElementDescriptionStorage.java    |    7 +-
 .../streampipes/storage/api/IPipelineStorage.java  |    4 +-
 .../couchdb/impl/ConnectionStorageImpl.java        |    2 +-
 .../couchdb/impl/PipelineCategoryStorageImpl.java  |    2 +-
 .../storage/couchdb/impl/PipelineStorageImpl.java  |    4 +-
 .../rdf4j/impl/PipelineElementStorageRequests.java |   24 +-
 .../apache/streampipes/vocabulary/StreamPipes.java |    1 +
 .../streampipes/api/__init__.py                    |   16 +
 .../streampipes/api/resources/__init__.py          |   16 +
 .../streampipes/api/templates/index.html           |   18 +
 .../streampipes/base/__init__.py                   |   16 +
 .../streampipes/model/__init__.py                  |   16 +
 .../streampipes/utils/__init__.py                  |   16 +
 ui/angular.json                                    |    4 +-
 ui/deployment/app.module.mst                       |   11 +-
 ui/deployment/appng5.module.mst                    |   12 +
 ui/deployment/dev/config.yml                       |    1 -
 ui/deployment/modules.yml                          |   51 +-
 ui/deployment/rel/config.yml                       |    2 +-
 ui/deployment/state.config.mst                     |   14 +-
 ui/package.json                                    |   12 +-
 ui/src/app/NS/XS.service.ts                        |   24 +-
 ui/src/app/add/add.component.html                  |   71 +
 .../add.component.scss}                            |   11 +-
 ui/src/app/add/add.component.ts                    |  159 ++
 ui/src/app/add/add.controller.ts                   |  219 --
 ui/src/app/add/add.html                            |  103 -
 ui/src/app/add/add.module.ts                       |   56 +-
 .../endpoint-item/endpoint-item.component.html     |   71 +
 .../endpoint-item/endpoint-item.component.scss}    |   24 +-
 .../endpoint-item/endpoint-item.component.ts       |  117 +
 .../add-endpoint/add-endpoint.component.html       |   62 +
 .../add-endpoint/add-endpoint.component.scss}      |    5 +-
 ...int.controller.ts => add-endpoint.component.ts} |  156 +-
 .../dialogs/add-endpoint/add-endpoint.tmpl.html    |   67 -
 .../endpoint-installation.component.html           |   51 +
 .../endpoint-installation.component.scss}          |    1 +
 .../endpoint-installation.component.ts             |  126 +
 .../endpoint-installation.controller.ts            |  128 -
 .../endpoint-installation.tmpl.html                |   60 -
 ui/src/app/add/endpoint-item.tmpl.html             |   77 -
 .../filter/order-by.pipe.ts}                       |   43 +-
 .../filter/pipeline-element-type.pipe.ts}          |   15 +-
 ui/src/app/add/services/add.service.ts             |   49 +
 .../app-image-labeling.component.ts                |    2 +-
 ui/src/app/applinks/applinks.module.ts             |   27 -
 ui/src/app/applinks/applinks.tmpl.html             |   65 -
 ui/src/app/connect/connect.module.ts               |  170 +-
 ui/src/app/connect/connect.service.ts              |   14 +-
 .../adapter-description.component.html             |   27 +-
 .../adapter-description.component.ts               |   11 +-
 .../adapter-upload-dialog.component.ts             |   25 +-
 .../data-marketplace.component.css                 |   41 -
 .../data-marketplace.component.html                |   15 +-
 .../data-marketplace/data-marketplace.component.ts |   93 +-
 .../data-marketplace/data-marketplace.service.ts   |  271 +-
 ui/src/app/connect/data-marketplace/filter.pipe.ts |   22 +-
 .../edit-data-type/edit-data-type.component.css}   |    8 +-
 .../edit-data-type/edit-data-type.component.html}  |   14 +-
 .../edit-data-type/edit-data-type.component.ts}    |   32 +-
 .../edit-event-property-list.component.css}        |    0
 .../edit-event-property-list.component.html}       |    8 +-
 .../edit-event-property-list.component.ts}         |   13 +-
 .../edit-event-property-primitive.component.css}   |    7 +-
 .../edit-event-property-primitive.component.html   |   44 +
 .../edit-event-property-primitive.component.ts     |   59 +
 .../edit-timestamp-property.component.css}         |    9 +-
 .../edit-timestamp-property.component.html         |   46 +
 .../edit-timestamp-property.component.ts}          |   18 +-
 .../edit-unit-transformation.component.css}        |    0
 .../edit-unit-transformation.component.html        |   49 +
 .../edit-unit-transformation.component.ts          |  137 +
 .../edit-event-property.component.css}             |    0
 .../edit-event-property.component.html}            |   47 +-
 .../edit-event-property.component.ts               |  149 ++
 ui/src/app/connect/filter/timestamp.pipe.ts        |    5 +-
 .../connect/format-component/format.component.html |    4 +-
 .../connect/format-component/format.component.ts   |    8 +-
 .../model/CodeInputStaticProperty.ts}              |   32 +-
 .../app/connect/model/DataProcessorInvocation.ts   |    8 +-
 ui/src/app/connect/model/DataSinkInvocation.ts     |    8 +-
 ...aSinkInvocation.ts => DataSourceDescription.ts} |   18 +-
 ui/src/app/connect/model/DataStreamDescription.ts  |   11 +-
 .../connect/model/InvocableStreamPipesEntity.ts    |   18 +-
 ui/src/app/connect/model/NamedStreamPipesEntity.ts |    2 +
 .../app/connect/model/UnnamedStreamPipesEntity.ts  |    1 -
 .../app/connect/model/grounding/EventGrounding.ts  |   41 +-
 .../grounding/JmsTransportProtocol.ts}             |    3 +-
 .../grounding/KafkaTransportProtocol.ts}           |    3 +-
 .../app/connect/model/grounding/TopicDefinition.ts |   15 +-
 .../app/connect/model/grounding/TransportFormat.ts |   11 +-
 .../connect/model/grounding/TransportProtocol.ts   |   21 +-
 .../UserDefinedOutputStrategy.ts}                  |   23 +-
 .../component/adapter-started-dialog.component.ts  |   63 +-
 .../component/dialog-adapter-started.html          |   31 +-
 .../pipeline-element-runtime-info.component.html   |   47 +
 .../pipeline-element-runtime-info.component.scss}  |    1 -
 .../pipeline-element-runtime-info.component.ts     |  101 +
 .../connect/new-adapter/new-adapter.component.html |   79 +-
 .../new-adapter/new-adapter.component.spec.ts      |   79 -
 .../connect/new-adapter/new-adapter.component.ts   |  124 +-
 .../protocol-component/protocol.component.css      |   80 -
 .../protocol-component/protocol.component.ts       |   58 -
 .../protocol-list.component.ts                     |   60 -
 ui/src/app/connect/rdfmapper/rdfmapper.service.ts  |   61 -
 ui/src/app/connect/rest.service.ts                 |  139 +-
 .../app/connect/schema-editor/data-type.service.ts |   47 +-
 .../event-property-primitive.component.html        |  123 -
 .../event-property-primitive.component.ts          |  183 --
 .../event-property-row.component.ts                |   48 +-
 .../event-property/event-property.component.ts     |  159 --
 .../event-schema/event-schema.component.ts         |   69 +-
 .../schema-editor/model/EventPropertyPrimitive.ts  |    9 +-
 .../app/connect/schema-editor/model/EventSchema.ts |   10 +-
 .../select-protocol.component.html                 |   24 -
 .../select-protocol.component.ts                   |  142 -
 .../select-static-properties.component.html        |   22 -
 .../select-static-properties.component.ts          |   62 -
 .../base/abstract-static-property.ts}              |   49 +-
 .../base/abstract-validated-static-property.ts     |   59 +
 .../filter/display-recommended.pipe.ts}            |   37 +-
 .../input.validator.ts                             |    3 -
 .../static-alternatives.component.html             |   19 +-
 .../static-alternatives.component.ts               |   61 +-
 .../static-any-input/static-any-input.component.ts |    9 +-
 .../static-code-input.component.html}              |   20 +-
 .../static-code-input.component.scss}              |    9 +-
 .../static-code-input.component.ts                 |  106 +
 .../static-collection.component.html               |   38 +-
 .../static-collection.component.ts                 |   56 +-
 .../static-color-picker.component.html             |   19 +-
 .../static-color-picker.component.ts               |   41 +-
 .../static-file-input.component.ts                 |   16 +-
 .../static-free-input.component.html               |   47 +-
 ...ponent.css => static-free-input.component.scss} |    6 +
 .../static-free-input.component.ts                 |  104 +-
 .../static-group/static-group.component.html       |   16 +-
 .../static-group/static-group.component.ts         |   20 +-
 .../static-mapping-nary.component.html             |    7 +-
 .../static-mapping-nary.component.ts               |   45 +-
 .../static-mapping-unary.component.html            |   13 +-
 .../static-mapping-unary.component.ts              |   57 +-
 .../static-mapping/static-mapping.ts               |   38 +-
 .../static-number-input.component.html             |   31 -
 .../static-number-input.component.ts               |   80 -
 .../static-one-of-input.component.html             |   13 +-
 .../static-one-of-input.component.ts               |   21 +-
 .../static-property-util.service.ts                |   86 +-
 .../static-property.component.css                  |   11 +
 .../static-property.component.html                 |  179 +-
 .../static-properties/static-property.component.ts |   70 +-
 ...c-runtime-resolvable-oneof-input.component.html |    6 +-
 ...tic-runtime-resolvable-oneof-input.component.ts |   33 +-
 .../static-secret-input.component.html             |   18 +-
 .../static-secret-input.component.ts               |   45 +-
 .../static-text-input.component.html               |   32 -
 .../static-text-input.component.ts                 |   79 -
 .../static-url-input.component.html                |   31 -
 .../static-url-input/static-url-input.component.ts |   67 -
 ui/src/app/connect/transformation-rule.service.ts  |  189 +-
 .../core-model/datalake/DataExplorerWidgetModel.ts |   52 -
 .../app/core-model/gen/streampipes-model-client.ts |   75 +
 ui/src/app/core-model/gen/streampipes-model.ts     | 2806 ++++++++++++++++++++
 .../datalake/datalake-rest.service.ts              |    2 +-
 .../semantic-type/semantic-type-utils.service.ts   |   18 +-
 ui/src/app/core-ui/core-ui.module.ts               |   17 +-
 .../dialog/base-dialog/base-dialog.component.ts}   |   44 +-
 .../dialog/base-dialog/base-dialog.config.ts}      |   12 +-
 .../dialog/base-dialog/base-dialog.model.ts}       |   46 +-
 .../dialog/base-dialog/base-dialog.service.ts      |  100 +
 .../app/core-ui/dialog/base-dialog/dialog-ref.ts   |   59 +
 .../confirm-dialog/confirm-dialog.component.html}  |   16 +-
 .../confirm-dialog/confirm-dialog.component.scss}  |    7 +-
 .../confirm-dialog/confirm-dialog.component.ts}    |   22 +-
 .../panel-dialog/panel-dialog.component.html}      |   15 +-
 .../panel-dialog/panel-dialog.component.scss}      |   37 +-
 .../dialog/panel-dialog/panel-dialog.component.ts  |   73 +
 .../dialog/panel-dialog/panel-dialog.config.ts}    |   44 +-
 .../standard-dialog.component.html}                |   15 +-
 .../standard-dialog.component.scss}                |   43 +-
 .../standard-dialog/standard-dialog.component.ts}  |   21 +-
 .../standard-dialog/standard-dialog.config.ts      |   45 +-
 .../image/image-viewer/image-viewer.component.ts   |    3 -
 .../components/grid/dashboard-grid.component.ts    |    6 +-
 .../components/panel/dashboard-panel.component.ts  |    8 +-
 .../widget/dashboard-widget.component.ts           |   10 +-
 .../components/widgets/base/base-config.ts         |    2 +-
 .../widgets/base/base-ngx-charts-widget.ts         |    2 -
 .../widgets/base/base-ngx-line-config.ts           |    2 +-
 .../components/widgets/base/base-widget.ts         |    8 +-
 .../components/widgets/gauge/gauge-config.ts       |    2 +-
 .../components/widgets/html/html-config.ts         |    2 +-
 .../components/widgets/image/image-config.ts       |    2 +-
 .../dashboard/components/widgets/map/map-config.ts |    2 +-
 .../components/widgets/number/number-config.ts     |    2 +-
 .../widgets/number/number-widget.component.ts      |    3 +-
 .../components/widgets/pallet/pallet-config.ts     |    2 +-
 .../dashboard/components/widgets/raw/raw-config.ts |    2 +-
 .../components/widgets/table/table-config.ts       |    2 +-
 .../widgets/table/table-widget.component.ts        |    2 +-
 .../widgets/trafficlight/traffic-light-config.ts   |    2 +-
 .../add-visualization-dialog.component.html        |    8 +-
 .../add-visualization-dialog.component.ts          |   60 +-
 .../dashboard/registry/widget-config-builder.ts    |   13 +-
 ui/src/app/dashboard/registry/widget-registry.ts   |    7 +-
 .../dashboard/sdk/collected-schema-requirements.ts |   14 +-
 ui/src/app/dashboard/sdk/ep-requirements.ts        |   32 +-
 .../sdk/extractor/static-property-extractor.ts     |   21 +-
 .../sdk/matching/domain-property-match.ts          |   10 +-
 .../sdk/matching/mapping-property-generator.ts     |    4 +-
 .../sdk/matching/primitive-property-match.ts       |    4 +-
 .../app/dashboard/sdk/matching/property-match.ts   |    8 +-
 ui/src/app/dashboard/sdk/matching/schema-match.ts  |    2 +-
 .../dashboard/sdk/schema-requirements-builder.ts   |   36 +-
 ui/src/app/dashboard/services/dashboard.service.ts |   87 +-
 .../datadownloadDialog/dataDownload.dialog.ts      |   10 +-
 .../data-explorer-dashboard-grid.component.html    |    2 +-
 ...=> data-explorer-dashboard-grid.component.scss} |   18 +-
 .../grid/data-explorer-dashboard-grid.component.ts |   38 +-
 ...data-explorer-dashboard-overview.component.html |  115 +-
 ...ata-explorer-dashboard-overview.component.scss} |   30 +-
 .../data-explorer-dashboard-overview.component.ts  |    2 +-
 .../data-explorer-dashboard-panel.component.html   |   14 +-
 .../data-explorer-dashboard-panel.component.ts     |   32 +-
 .../time-selector/timeRangeSelector.component.html |   72 +-
 ...ponent.css => timeRangeSelector.component.scss} |   27 +-
 .../time-selector/timeRangeSelector.component.ts   |    7 +-
 .../data-explorer-dashboard-widget.component.html  |   14 +-
 ... data-explorer-dashboard-widget.component.scss} |    6 +-
 .../data-explorer-dashboard-widget.component.ts    |   13 +-
 .../components/widgets/base/base-config.ts         |    4 +-
 .../widgets/base/base-data-explorer-widget.ts      |   42 +-
 .../widgets/base/base-ngx-charts-widget.ts         |   75 -
 .../components/widgets/image/image-config.ts       |    6 +-
 .../widgets/image/image-widget.component.css       |    6 +
 .../widgets/image/image-widget.component.html      |    6 -
 .../widgets/image/image-widget.component.ts        |    8 +-
 .../widgets/line-chart/line-chart-config.ts        |    6 +-
 .../line-chart/line-chart-widget.component.css     |   14 +-
 .../line-chart/line-chart-widget.component.html    |  140 +-
 .../line-chart/line-chart-widget.component.ts      |   43 +-
 .../datadownloadDialog/dataDownload.dialog.css     |   56 -
 .../datadownloadDialog/dataDownload.dialog.html    |  100 -
 .../datadownloadDialog/dataDownload.dialog.ts      |  196 --
 .../base/baseVisualisation.component.ts            |  146 -
 .../linechart/lineChart.component.css              |   23 -
 .../linechart/lineChart.component.html             |   54 -
 .../linechart/lineChart.component.ts               |  548 ----
 .../table/table.component.html                     |   66 -
 .../table/table.component.ts                       |   99 -
 .../old-explorer.component.html                    |  289 --
 .../old-explorer-widget/old-explorer.component.ts  |  417 ---
 .../widgets/old-explorer-widget/old-explorer.css   |   85 -
 .../components/widgets/table/table-config.ts       |    7 +-
 .../widgets/table/table-widget.component.html      |   31 +-
 ...t.component.css => table-widget.component.scss} |   13 +-
 .../widgets/table/table-widget.component.ts        |   10 +-
 .../aggregate-configuration.component.html         |    8 +-
 .../aggregate-configuration.component.ts           |    3 +-
 .../group-configuration.component.ts               |    4 +-
 .../load-data-spinner.component.html               |   10 +-
 .../load-data-spinner.component.ts                 |    2 +-
 .../no-data/no-data-in-date-range.component.ts     |    4 +-
 .../select-properties.component.html               |    2 +-
 .../select-properties.component.ts                 |   10 +-
 .../app/data-explorer/data-explorer.component.css  |   62 +
 .../app/data-explorer/data-explorer.component.html |   39 +-
 .../app/data-explorer/data-explorer.component.ts   |   21 +-
 ui/src/app/data-explorer/data-explorer.module.ts   |  117 +-
 ...explorer-add-visualization-dialog.component.css |   16 +
 ...xplorer-add-visualization-dialog.component.html |   39 +-
 ...-explorer-add-visualization-dialog.component.ts |   15 +-
 ...ata-explorer-edit-data-view-dialog.component.ts |    8 +-
 .../models/dataview-dashboard.model.ts             |    5 +
 .../registry/data-explorer-widget-registry.ts      |   11 +-
 .../registry/widget-config-builder.ts              |   10 +-
 .../data-explorer/services/data-lake.service.ts    |    2 +-
 .../services/data-view-data-explorer.service.ts    |   70 +-
 .../services/refresh-dashboard.service.ts          |    4 +-
 .../app/data-explorer/services/resize.service.ts   |    6 +-
 ui/src/app/editor/capitalize.filter.ts             |   39 -
 .../alternative/alternative.component.ts           |   33 -
 .../components/alternative/alternative.tmpl.html   |   30 -
 .../components/any-remote/any-remote.component.ts  |   31 -
 .../components/any-remote/any-remote.controller.ts |  101 -
 .../components/any-remote/any-remote.tmpl.html     |   38 -
 ui/src/app/editor/components/any/any.component.ts  |   30 -
 .../components/code/code-editor.directive.ts       |   91 -
 .../app/editor/components/code/code.component.ts   |   33 -
 ui/src/app/editor/components/code/code.tmpl.html   |   33 -
 .../components/collection/collection.component.ts  |   30 -
 .../components/collection/collection.controller.ts |   51 -
 .../components/collection/collection.tmpl.html     |   60 -
 .../customize/customize-dialog.component.ts        |   34 -
 .../customize/customize-dialog.tmpl.html           |   96 -
 .../customoutput/customoutput.component.ts         |   33 -
 .../customoutput/customoutput.controller.ts        |   57 -
 .../components/customoutput/customoutput.tmpl.html |   49 -
 .../property-selection.component.ts                |   34 -
 .../property-selection.controller.ts               |   46 -
 .../propertyselection/property-selection.tmpl.html |   33 -
 .../domainconcept/domainconcept.component.ts       |   31 -
 .../domainconcept/domainconcept.controller.ts      |   99 -
 .../domainconcept/domainconcept.tmpl.html          |   49 -
 ui/src/app/editor/components/draggable-icon.html   |   25 -
 .../components/fileupload/fileupload.component.ts  |   34 -
 .../components/fileupload/fileupload.controller.ts |   75 -
 .../components/fileupload/fileupload.tmpl.html     |   39 -
 .../components/freetext/freetext.component.ts      |   33 -
 .../components/freetext/freetext.controller.ts     |   96 -
 .../editor/components/freetext/freetext.tmpl.html  |   98 -
 .../app/editor/components/group/group.component.ts |   34 -
 .../editor/components/group/group.controller.ts    |   33 -
 .../mappingnary/mappingnary.component.ts           |   33 -
 .../mappingnary/mappingnary.controller.ts          |   86 -
 .../components/mappingnary/mappingnary.tmpl.html   |   35 -
 .../mappingunary/mappingunary.component.ts         |   33 -
 .../mappingunary/mappingunary.controller.ts        |   65 -
 .../components/mappingunary/mappingunary.tmpl.html |   26 -
 .../matchingproperty/matchingproperty.component.ts |   30 -
 .../matchingproperty.controller.ts                 |   24 -
 .../matchingproperty/matchingproperty.tmpl.html    |   28 -
 .../multivalue/multiple-value-input.component.ts   |   30 -
 .../multivalue/multiple-value-input.controller.ts  |   54 -
 .../multivalue/multiple-value-input.tmpl.html      |   50 -
 .../oneof-remote/oneof-remote.component.ts         |   31 -
 .../oneof-remote/oneof-remote.controller.ts        |  115 -
 .../components/oneof-remote/oneof-remote.tmpl.html |   38 -
 .../app/editor/components/oneof/oneof.component.ts |   30 -
 .../editor/components/oneof/oneof.controller.ts    |   45 -
 ui/src/app/editor/components/oneof/oneof.tmpl.html |   25 -
 .../output-strategy/base/BaseOutputStrategy.ts}    |   32 +-
 .../custom-output-strategy.component.html          |   51 +
 .../custom-output-strategy.component.scss}         |    0
 .../custom-output-strategy.component.ts            |   72 +
 .../output-strategy/output-strategy.component.html |   43 +
 .../output-strategy.component.scss}                |   12 +-
 .../output-strategy/output-strategy.component.ts}  |   37 +-
 .../property-selection.component.html              |   40 +
 .../property-selection.component.scss}             |    3 +
 .../property-selection.component.ts                |   80 +
 .../user-defined-output.component.html             |   64 +
 .../user-defined-output.component.scss}            |    0
 .../user-defined-output.component.ts               |  102 +
 .../pipeline-assembly.component.html               |  111 +
 .../pipeline-assembly.component.scss}              |   12 +-
 .../pipeline-assembly.component.ts                 |  241 +-
 .../pipeline-assembly.controller.ts                |  246 --
 .../pipeline-assembly/pipeline-assembly.tmpl.html  |  118 -
 ... pipeline-element-documentation.component.html} |    4 +-
 .../pipeline-element-documentation.component.scss} |    3 +-
 .../pipeline-element-documentation.component.ts    |   47 +-
 .../pipeline-element-documentation.controller.ts   |   43 -
 .../pipeline-element-icon-stand.component.html     |   71 +
 .../pipeline-element-icon-stand.component.scss}    |   28 +-
 .../pipeline-element-icon-stand.component.ts       |  167 +-
 .../pipeline-element-icon-stand.controller.ts      |  110 -
 .../pipeline-element-icon-stand.tmpl.html          |   87 -
 .../pipeline-element-options.component.css}        |    1 -
 .../pipeline-element-options.component.html        |   68 +
 .../pipeline-element-options.component.ts          |  192 +-
 .../pipeline-element-options.controller.ts         |  151 --
 .../pipeline-element-options.tmpl.html             |   92 -
 .../pipeline-element-recommendation.component.html |   32 +
 ...pipeline-element-recommendation.component.scss} |    1 -
 .../pipeline-element-recommendation.component.ts   |  141 +-
 .../pipeline-element-recommendation.controller.ts  |  101 -
 .../pipeline-element-recommendation.tmpl.html      |   30 -
 .../pipeline-element.component.css}                |    3 +-
 .../pipeline-element.component.html}               |    5 +-
 .../pipeline-element/pipeline-element.component.ts |   90 +-
 .../pipeline-element.controller.ts                 |   77 -
 .../pipeline-element/pipeline-element.tmpl.html    |   22 -
 .../components/pipeline/pipeline.component.css}    |    3 +-
 .../components/pipeline/pipeline.component.html    |   48 +
 .../components/pipeline/pipeline.component.ts      |  398 ++-
 .../components/pipeline/pipeline.controller.ts     |  350 ---
 .../editor/components/pipeline/pipeline.tmpl.html  |   45 -
 ui/src/app/editor/components/popup.html            |   25 -
 .../replaceoutput/replaceoutput.component.ts       |   31 -
 .../replaceoutput/replaceoutput.controller.ts      |   25 -
 .../replaceoutput/replaceoutput.tmpl.html          |   30 -
 .../editor/components/secret/secret.component.ts   |   31 -
 .../editor/components/secret/secret.controller.ts  |   49 -
 .../app/editor/components/secret/secret.tmpl.html  |   28 -
 .../topic/topic-selection-dialog.component.ts      |   32 -
 .../topic/topic-selection-dialog.controller.ts     |   76 -
 .../topic/topic-selection-dialog.tmpl.html         |   42 -
 .../user-defined-output.component.ts               |   33 -
 .../user-defined-output.controller.ts              |   87 -
 .../user-defined-output.tmpl.html                  |   55 -
 .../src/app/editor/constants/editor.constants.ts   |   11 +-
 .../compatible-elements.component.html             |   43 +
 .../compatible-elements.component.scss}            |   26 +-
 .../compatible-elements.component.ts               |   92 +
 .../customize.controller.ts                        |  151 --
 .../customizeElementDialog.tmpl.html               |  161 --
 .../dialog/customize/customize.component.html      |   88 +
 .../dialog/customize/customize.component.scss}     |    1 +
 .../editor/dialog/customize/customize.component.ts |  133 +
 .../editor/dialog/help/help-dialog.controller.ts   |  130 -
 .../app/editor/dialog/help/help-dialog.tmpl.html   |  103 -
 ui/src/app/editor/dialog/help/help.component.html  |   71 +
 .../dialog/help/help.component.scss}               |    1 +
 ui/src/app/editor/dialog/help/help.component.ts    |  114 +
 .../matching-error/matching-error.component.html   |   53 +
 .../matching-error/matching-error.component.scss}  |    1 +
 .../matching-error/matching-error.component.ts}    |   38 +-
 .../matching-error/matching-error.controller.ts    |   45 -
 .../dialog/matching-error/matching-error.tmpl.html |   64 -
 ...sing-elements-for-tutorial-dialog.controller.ts |   38 -
 ...> missing-elements-for-tutorial.component.html} |   33 +-
 .../missing-elements-for-tutorial.component.scss}  |    1 +
 .../missing-elements-for-tutorial.component.ts}    |   23 +-
 .../possible-elements-dialog.controller.ts         |   55 -
 .../possible-elements-dialog.tmpl.html             |   50 -
 .../save-pipeline/save-pipeline.component.html     |   65 +
 .../save-pipeline/save-pipeline.component.scss}    |   18 +-
 .../save-pipeline/save-pipeline.component.ts       |  153 ++
 .../save-pipeline/save-pipeline.controller.ts      |  151 --
 .../save-pipeline/submitPipelineModal.tmpl.html    |   74 -
 .../topic/topic-selection-modal.controller.ts      |   89 -
 .../dialog/topic/topic-selection-modal.tmpl.html   |   54 -
 .../welcome-tour/welcome-tour-dialog.controller.ts |   54 -
 ...ialog.tmpl.html => welcome-tour.component.html} |   39 +-
 .../welcome-tour/welcome-tour.component.scss}      |   25 +-
 .../dialog/welcome-tour/welcome-tour.component.ts} |   37 +-
 ui/src/app/editor/editor.component.html            |   59 +
 .../editor.component.scss}                         |   18 +-
 ui/src/app/editor/editor.component.ts              |  236 ++
 ui/src/app/editor/editor.controller.ts             |  282 --
 ui/src/app/editor/editor.html                      |   72 -
 ui/src/app/editor/editor.module.ts                 |  222 +-
 .../editor/filter/display-recommended.filter.ts    |   48 -
 ui/src/app/editor/filter/element-name.filter.ts    |   41 -
 ui/src/app/editor/filter/select.filter.ts          |   42 -
 ui/src/app/editor/image-bind.directive.ts          |   33 -
 ui/src/app/editor/model/editor.model.ts            |   67 +
 ui/src/app/editor/my-data-bind.directive.ts        |   33 -
 .../services/editor-dialog-manager.service.ts      |   40 +-
 ui/src/app/editor/services/editor.service.ts       |  144 +
 .../services/jsplumb-bridge.service.ts             |    3 +
 .../services/jsplumb-config.service.ts             |    3 +
 .../app/{ => editor}/services/jsplumb.service.ts   |   96 +-
 .../services/object-provider.service.ts            |   89 +-
 .../services/pipeline-editor.service.ts            |   19 +-
 .../pipeline-element-recommendation.service.ts     |   77 +-
 .../services/pipeline-positioning.service.ts       |   36 +-
 .../editor/services/pipeline-validation.service.ts |   25 +-
 ui/src/app/editor/utils/editor.utils.ts            |   97 +
 .../utils/style-sanitizer.ts}                      |   19 +-
 .../text/custom-output-validator.directive.ts      |   38 -
 .../validator/text/text-validator.directive.ts     |   66 -
 .../myelements/dialog/jsonldDialog.controller.ts   |   48 -
 .../app/myelements/dialog/jsonldDialog.tmpl.html   |   43 -
 ui/src/app/myelements/my-elements.controller.ts    |  250 --
 ui/src/app/myelements/my-elements.module.ts        |   25 -
 ui/src/app/myelements/myelements.html              |  108 -
 .../actions/pipeline-actions.component.html        |   71 +
 .../actions/pipeline-actions.component.ts          |   63 +-
 .../actions/pipeline-actions.controller.ts         |   60 -
 .../components/actions/pipeline-actions.tmpl.html  |   82 -
 .../components/edit/quickedit.component.html       |   58 +
 .../components/edit/quickedit.component.ts         |  145 +-
 .../components/edit/quickedit.tmpl.html            |   52 -
 .../pipeline-elements-row.component.html}          |   21 +-
 .../elements/pipeline-elements-row.component.ts    |   54 +-
 .../elements/pipeline-elements-row.controller.ts   |   53 -
 .../elements/pipeline-elements-row.tmpl.html       |   34 -
 ....tmpl.html => pipeline-elements.component.html} |   12 +-
 .../elements/pipeline-elements.component.ts        |   29 +-
 ...w.tmpl.html => pipeline-preview.component.html} |    8 +-
 .../preview/pipeline-preview.component.scss}       |    0
 .../preview/pipeline-preview.component.ts          |   71 +-
 .../preview/pipeline-preview.controller.ts         |   62 -
 ...us.tmpl.html => pipeline-status.component.html} |   28 +-
 .../components/status/pipeline-status.component.ts |   45 +-
 .../status/pipeline-status.controller.ts           |   43 -
 .../pipeline-details.component.html                |   60 +
 .../pipeline-details.component.scss}               |    0
 .../pipeline-details/pipeline-details.component.ts |   63 +
 .../pipeline-details.controller.ts                 |   59 -
 ui/src/app/pipeline-details/pipeline-details.html  |   59 -
 .../pipeline-details/pipeline-details.module.ts    |   73 +-
 .../category-already-in-pipeline.filter.ts         |   26 +-
 .../pipeline-details/pipeline-details.component.ts |   32 -
 .../pipeline-details.controller.ts                 |   65 -
 .../pipeline-details/pipeline-details.tmpl.html    |   97 -
 .../pipeline-overview.component.html               |   90 +
 .../pipeline-overview.component.scss}              |   19 +-
 .../pipeline-overview.component.ts                 |  111 +
 .../dialog/delete-pipeline-dialog.tmpl.html        |   56 -
 .../delete-pipeline-dialog.component.html          |   52 +
 .../delete-pipeline-dialog.component.scss}         |    1 +
 .../delete-pipeline-dialog.component.ts}           |   52 +-
 .../dialog/import-pipeline-dialog.tmpl.html        |   73 -
 .../import-pipeline-dialog.component.html          |   68 +
 .../import-pipeline-dialog.component.scss}         |    1 +
 .../import-pipeline-dialog.component.ts}           |   85 +-
 .../dialog/pipeline-categories-dialog.tmpl.html    |  170 --
 .../pipeline-categories-dialog.component.html      |  146 +
 .../pipeline-categories-dialog.component.scss}     |    1 +
 .../pipeline-categories-dialog.component.ts}       |  104 +-
 .../dialog/pipeline-status-dialog.tmpl.html        |   74 -
 .../pipeline-status-dialog.component.html          |   59 +
 .../pipeline-status-dialog.component.scss}         |   57 +-
 .../pipeline-status-dialog.component.ts}           |   33 +-
 .../dialog/start-all-pipelines-dialog.tmpl.html    |   57 -
 .../start-all-pipelines-dialog.component.html      |   49 +
 .../start-all-pipelines-dialog.component.scss}     |    1 +
 .../start-all-pipelines-dialog.component.ts}       |   92 +-
 ui/src/app/pipelines/pipeline-category.filter.ts   |   29 +-
 ui/src/app/pipelines/pipelines.component.html      |   74 +
 .../pipelines.component.scss}                      |   11 +-
 ui/src/app/pipelines/pipelines.component.ts        |  195 ++
 ui/src/app/pipelines/pipelines.controller.ts       |  247 --
 ui/src/app/pipelines/pipelines.html                |   98 -
 ui/src/app/pipelines/pipelines.module.ts           |   71 +-
 .../services/pipeline-operations.service.ts        |  180 +-
 .../apis/commons.service.ts}                       |   20 +-
 .../apis/pipeline-element-endpoint.service.ts      |   52 +
 .../apis/pipeline-element.service.ts               |   74 +
 .../app/platform-services/apis/pipeline.service.ts |  107 +
 .../contants/platform-services.constants.ts}       |    7 +-
 ui/src/app/platform-services/platform.module.ts    |   25 +-
 .../platform-services/tsonld-serializer.service.ts |   18 +-
 ui/src/app/services/image-checker.service.ts       |    3 +
 ui/src/app/services/property-selector.service.ts   |   23 +-
 ui/src/app/services/rest-api.service.ts            |   55 -
 ui/src/app/services/services.module.ts             |   22 +-
 .../tour/create-pipeline-tour.constants.ts         |   20 +-
 ui/src/app/services/tour/shepherd.service.ts       |    4 +-
 ui/src/app/services/transition.service.ts          |   58 -
 ui/src/scss/main.scss                              |    8 +-
 ui/src/scss/sp/buttons.scss                        |    3 +-
 ui/src/scss/sp/dialog.scss                         |    2 +
 .../sp/forms.scss}                                 |   45 +-
 ui/src/scss/sp/main.scss                           |   38 +-
 ui/src/scss/sp/pipeline-assembly.scss              |   12 -
 ui/src/scss/sp/pipeline-element-options.scss       |    2 +-
 .../sp/sp-dialog.scss}                             |   31 +-
 ui/src/scss/sp/sp-theme.scss                       |   96 +
 .../sp/widgets.scss}                               |   66 +-
 769 files changed, 15432 insertions(+), 18310 deletions(-)