From ce957b50c4678235906fc912abc859ac36f3c8bb Mon Sep 17 00:00:00 2001 From: lorenz <stu203404@mail.uni-kiel.de> Date: Fri, 15 Apr 2022 15:41:55 +0200 Subject: [PATCH] Adapt dependencies of uc1-4 flink + beam + load gen --- .../benchmarks/commons/beam/BeamService.java | 2 +- .../kafka/ActivePowerRecordDeserializer.java | 2 +- .../commons/beam/kafka/EventTimePolicy.java | 2 +- .../kafka/KafkaActivePowerTimestampReader.java | 2 +- .../src/main/groovy/theodolite.beam.gradle | 3 +-- .../src/main/groovy/theodolite.flink.gradle | 4 +--- .../main/groovy/theodolite.load-generator.gradle | 3 +-- theodolite-benchmarks/commons/build.gradle | 4 +++- theodolite-benchmarks/http-bridge/build.gradle | 3 +-- .../httpbridge/EnvVarHttpBridgeFactory.java | 2 +- .../kstreams-commons/build.gradle | 3 +-- .../load-generator-commons/build.gradle | 3 +-- .../EnvVarLoadGeneratorFactory.java | 2 +- .../loadgenerator/KafkaRecordSender.java | 2 +- .../loadgenerator/TitanKafkaSenderFactory.java | 2 +- .../loadgenerator/TitanPubSubSenderFactory.java | 2 +- .../loadgenerator/TitanRecordGenerator.java | 2 +- .../loadgenerator/HttpRecordSenderTest.java | 2 +- .../loadgenerator/TitanRecordGeneratorTest.java | 2 +- .../benchmarks/uc1/beam/ConverterAdapter.java | 2 +- .../benchmarks/uc1/beam/GenericSink.java | 2 +- .../benchmarks/uc1/beam/PipelineFactory.java | 2 +- .../benchmarks/uc1/beam/SinkFactory.java | 2 +- .../theodolite/benchmarks/uc1/beam/SinkType.java | 2 +- .../uc1/beam/firestore/DocumentMapper.java | 2 +- .../uc1/beam/firestore/FirestoreSink.java | 2 +- .../benchmarks/uc1/flink/ConverterAdapter.java | 2 +- .../uc1/flink/HistoryServiceFlinkJob.java | 4 ++-- .../benchmarks/uc2/beam/PipelineFactory.java | 2 +- .../benchmarks/uc2/beam/StatsAggregation.java | 2 +- .../uc2/flink/HistoryServiceFlinkJob.java | 4 ++-- .../uc2/flink/StatsAggregateFunction.java | 2 +- .../benchmarks/uc3/beam/HourOfDayKeySerde.java | 8 ++++---- .../benchmarks/uc3/beam/MapTimeFormat.java | 2 +- .../benchmarks/uc3/beam/PipelineFactory.java | 2 +- .../benchmarks/uc3/beam/StatsAggregation.java | 2 +- .../uc3/flink/HistoryServiceFlinkJob.java | 4 ++-- .../uc3/flink/StatsAggregateFunction.java | 2 +- .../uc3/flink/util/HourOfDayKeySerde.java | 8 ++++---- .../uc3/flink/util/HourOfDayRecordFactory.java | 2 +- ...gregatedActivePowerRecordEventTimePolicy.java | 2 +- .../benchmarks/uc4/beam/AggregatedToActive.java | 4 ++-- .../benchmarks/uc4/beam/DuplicateAsFlatMap.java | 2 +- .../benchmarks/uc4/beam/FilterEvents.java | 2 +- .../benchmarks/uc4/beam/FilterNullValues.java | 2 +- .../benchmarks/uc4/beam/GenerateParentsFn.java | 8 ++++---- .../benchmarks/uc4/beam/PipelineFactory.java | 6 +++--- .../benchmarks/uc4/beam/RecordAggregation.java | 4 ++-- .../benchmarks/uc4/beam/SetIdForAggregated.java | 2 +- .../benchmarks/uc4/beam/SetKeyToGroup.java | 2 +- .../AggregatedActivePowerRecordCoder.java | 2 +- .../AggregatedActivePowerRecordDeserializer.java | 2 +- .../AggregatedActivePowerRecordSerializer.java | 2 +- .../uc4/beam/serialization/EventCoder.java | 4 ++-- .../beam/serialization/EventDeserializer.java | 2 +- .../beam/serialization/SensorParentKeySerde.java | 8 ++++---- .../uc4/flink/AggregationServiceFlinkJob.java | 16 ++++++++-------- .../uc4/flink/ChildParentsFlatMapFunction.java | 6 +++--- .../flink/JoinAndDuplicateCoFlatMapFunction.java | 2 +- .../RecordAggregationProcessWindowFunction.java | 4 ++-- .../util/ImmutableSensorRegistrySerializer.java | 2 +- .../uc4/loadgenerator/ConfigPublisher.java | 4 ++-- .../uc4/loadgenerator/LoadGenerator.java | 4 ++-- .../uc4/loadgenerator/SensorRegistryBuilder.java | 6 +++--- .../loadgenerator/SensorRegistryBuilderTest.java | 8 ++++---- 65 files changed, 104 insertions(+), 109 deletions(-) diff --git a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/BeamService.java b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/BeamService.java index 0165fa644..bf4bb9397 100644 --- a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/BeamService.java +++ b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/BeamService.java @@ -10,7 +10,7 @@ import org.apache.beam.sdk.options.PipelineOptionsFactory; import org.apache.commons.configuration2.Configuration; import org.slf4j.Logger; import org.slf4j.LoggerFactory; -import titan.ccp.common.configuration.ServiceConfigurations; +import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; /** * A general Apache Beam-based microservice. It is configured by Beam pipeline, a Beam runner and diff --git a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/ActivePowerRecordDeserializer.java b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/ActivePowerRecordDeserializer.java index 0c8d3a4a8..7f0f20c46 100644 --- a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/ActivePowerRecordDeserializer.java +++ b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/ActivePowerRecordDeserializer.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.commons.beam.kafka; import io.confluent.kafka.streams.serdes.avro.SpecificAvroDeserializer; import org.apache.kafka.common.serialization.Deserializer; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A Kafka {@link Deserializer} for typed Schema Registry {@link ActivePowerRecord}. diff --git a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/EventTimePolicy.java b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/EventTimePolicy.java index 62e563415..f4cd67f24 100644 --- a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/EventTimePolicy.java +++ b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/EventTimePolicy.java @@ -5,7 +5,7 @@ import org.apache.beam.sdk.io.kafka.KafkaRecord; import org.apache.beam.sdk.io.kafka.TimestampPolicy; import org.apache.beam.sdk.transforms.windowing.BoundedWindow; import org.joda.time.Instant; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * TimeStampPolicy to use event time based on the timestamp of the record value. diff --git a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/KafkaActivePowerTimestampReader.java b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/KafkaActivePowerTimestampReader.java index e22d5c8ee..d7d25ae91 100644 --- a/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/KafkaActivePowerTimestampReader.java +++ b/theodolite-benchmarks/beam-commons/src/main/java/rocks/theodolite/benchmarks/commons/beam/kafka/KafkaActivePowerTimestampReader.java @@ -8,7 +8,7 @@ import org.apache.beam.sdk.values.KV; import org.apache.beam.sdk.values.PBegin; import org.apache.beam.sdk.values.PCollection; import org.apache.kafka.common.serialization.StringDeserializer; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Simple {@link PTransform} that reads from Kafka using {@link KafkaIO} with event time. diff --git a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.beam.gradle b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.beam.gradle index 5849bd932..7783baaa2 100644 --- a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.beam.gradle +++ b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.beam.gradle @@ -22,8 +22,7 @@ def apacheBeamVersion = '2.35.0' dependencies { // These dependencies are used internally, and not exposed to consumers on their own compile classpath. - implementation('org.industrial-devops:titan-ccp-common:0.1.0-SNAPSHOT') { changing = true } - implementation('org.industrial-devops:titan-ccp-common-kafka:0.1.0-SNAPSHOT') { changing = true } + implementation project(':commons') implementation 'com.google.guava:guava:24.1-jre' implementation 'org.slf4j:slf4j-simple:1.7.25' implementation project(':beam-commons') diff --git a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.flink.gradle b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.flink.gradle index 7671e6022..5665de9d8 100644 --- a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.flink.gradle +++ b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.flink.gradle @@ -35,9 +35,7 @@ repositories { } dependencies { - // Special version required because of https://issues.apache.org/jira/browse/FLINK-13703 - implementation('org.industrial-devops:titan-ccp-common:0.1.0-flink-ready-SNAPSHOT') { changing = true } - implementation('org.industrial-devops:titan-ccp-common-kafka:0.1.0-SNAPSHOT') { changing = true } + implementation project(':commons') implementation 'org.apache.kafka:kafka-clients:2.2.0' implementation 'com.google.guava:guava:30.1-jre' diff --git a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.load-generator.gradle b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.load-generator.gradle index fb4fd89d1..b4927d53d 100644 --- a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.load-generator.gradle +++ b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.load-generator.gradle @@ -20,8 +20,7 @@ repositories { dependencies { // These dependencies are used internally, and not exposed to consumers on their own compile classpath. - implementation('org.industrial-devops:titan-ccp-common:0.1.0-SNAPSHOT') { changing = true } - implementation('org.industrial-devops:titan-ccp-common-kafka:0.1.0-SNAPSHOT') { changing = true } + implementation project(':commons') implementation 'org.slf4j:slf4j-simple:1.7.25' // These dependencies are used for the workload-generator-commmon diff --git a/theodolite-benchmarks/commons/build.gradle b/theodolite-benchmarks/commons/build.gradle index 67860c1ac..b12eaf4e1 100644 --- a/theodolite-benchmarks/commons/build.gradle +++ b/theodolite-benchmarks/commons/build.gradle @@ -22,6 +22,7 @@ dependencies { implementation 'org.apache.kafka:kafka-clients:2.4.0' api 'org.apache.commons:commons-configuration2:2.0' api "org.apache.avro:avro:1.11.0" + api 'org.apache.kafka:kafka-streams:2.4.0' // needed in flink uc3 // These dependencies are used internally, and not exposed to consumers on their own compile classpath. implementation 'commons-beanutils:commons-beanutils:1.9.2' // necessary for commons-configuration2 @@ -53,7 +54,8 @@ sourceSets { //// Local avro creation avro { fieldVisibility = "PRIVATE" - createSetters = false + // Setters required for flink because of https://issues.apache.org/jira/browse/FLINK-13703 + createSetters = true } task("generateAvroProtocol", type: com.github.davidmc24.gradle.plugin.avro.GenerateAvroProtocolTask) { diff --git a/theodolite-benchmarks/http-bridge/build.gradle b/theodolite-benchmarks/http-bridge/build.gradle index fa98d9fdd..7714f9947 100644 --- a/theodolite-benchmarks/http-bridge/build.gradle +++ b/theodolite-benchmarks/http-bridge/build.gradle @@ -17,8 +17,7 @@ repositories { } dependencies { - implementation('org.industrial-devops:titan-ccp-common:0.1.0-SNAPSHOT') { changing = true } - implementation('org.industrial-devops:titan-ccp-common-kafka:0.1.0-SNAPSHOT') { changing = true } + implementation project(':commons') implementation project(':load-generator-commons') implementation 'io.javalin:javalin:4.3.0' diff --git a/theodolite-benchmarks/http-bridge/src/main/java/rocks/theodolite/benchmarks/httpbridge/EnvVarHttpBridgeFactory.java b/theodolite-benchmarks/http-bridge/src/main/java/rocks/theodolite/benchmarks/httpbridge/EnvVarHttpBridgeFactory.java index d3c172ac8..25b39b30c 100644 --- a/theodolite-benchmarks/http-bridge/src/main/java/rocks/theodolite/benchmarks/httpbridge/EnvVarHttpBridgeFactory.java +++ b/theodolite-benchmarks/http-bridge/src/main/java/rocks/theodolite/benchmarks/httpbridge/EnvVarHttpBridgeFactory.java @@ -5,7 +5,7 @@ import java.util.Objects; import java.util.Optional; import rocks.theodolite.benchmarks.loadgenerator.ConfigurationKeys; import rocks.theodolite.benchmarks.loadgenerator.TitanKafkaSenderFactory; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; class EnvVarHttpBridgeFactory { diff --git a/theodolite-benchmarks/kstreams-commons/build.gradle b/theodolite-benchmarks/kstreams-commons/build.gradle index 167a75327..e443e3af1 100644 --- a/theodolite-benchmarks/kstreams-commons/build.gradle +++ b/theodolite-benchmarks/kstreams-commons/build.gradle @@ -14,9 +14,8 @@ repositories { dependencies { // These dependencies are used internally, and not exposed to consumers on their own compile classpath. + implementation project(':commons') // implementation 'org.slf4j:slf4j-simple:1.7.25' - implementation('org.industrial-devops:titan-ccp-common:0.1.0-SNAPSHOT') { changing = true } - implementation('org.industrial-devops:titan-ccp-common-kafka:0.1.0-SNAPSHOT') { changing = true } implementation 'org.apache.kafka:kafka-streams:3.1.0' // Use JUnit test framework diff --git a/theodolite-benchmarks/load-generator-commons/build.gradle b/theodolite-benchmarks/load-generator-commons/build.gradle index 62542eeab..082fb8eb9 100644 --- a/theodolite-benchmarks/load-generator-commons/build.gradle +++ b/theodolite-benchmarks/load-generator-commons/build.gradle @@ -18,8 +18,7 @@ dependencies { implementation 'org.slf4j:slf4j-simple:1.7.25' implementation 'com.google.guava:guava:30.1-jre' implementation 'com.google.code.gson:gson:2.8.2' - implementation('org.industrial-devops:titan-ccp-common:0.1.0-SNAPSHOT') { changing = true } - implementation('org.industrial-devops:titan-ccp-common-kafka:0.1.0-SNAPSHOT') { changing = true } + implementation project(':commons') implementation 'org.apache.kafka:kafka-streams:2.6.0' // TODO required? implementation platform('com.google.cloud:libraries-bom:24.2.0') implementation 'com.google.protobuf:protobuf-java-util' diff --git a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/EnvVarLoadGeneratorFactory.java b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/EnvVarLoadGeneratorFactory.java index ae9a6d422..ff3905e82 100644 --- a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/EnvVarLoadGeneratorFactory.java +++ b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/EnvVarLoadGeneratorFactory.java @@ -7,7 +7,7 @@ import java.util.Properties; import org.apache.kafka.clients.producer.ProducerConfig; import org.slf4j.Logger; import org.slf4j.LoggerFactory; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; class EnvVarLoadGeneratorFactory { diff --git a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/KafkaRecordSender.java b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/KafkaRecordSender.java index 56b1946ad..914d28817 100644 --- a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/KafkaRecordSender.java +++ b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/KafkaRecordSender.java @@ -8,7 +8,7 @@ import org.apache.kafka.clients.producer.ProducerConfig; import org.apache.kafka.clients.producer.ProducerRecord; import org.apache.kafka.common.serialization.Serializer; import org.apache.kafka.common.serialization.StringSerializer; -import titan.ccp.common.kafka.avro.SchemaRegistryAvroSerdeFactory; +import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; /** * Sends records to Kafka. diff --git a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanKafkaSenderFactory.java b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanKafkaSenderFactory.java index ee7d41651..7f0a1289e 100644 --- a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanKafkaSenderFactory.java +++ b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanKafkaSenderFactory.java @@ -1,7 +1,7 @@ package rocks.theodolite.benchmarks.loadgenerator; import java.util.Properties; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A factory for creating {@link KafkaRecordSender}s that sends Titan {@link ActivePowerRecord}s. diff --git a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanPubSubSenderFactory.java b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanPubSubSenderFactory.java index 569d98fb9..41a76a62a 100644 --- a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanPubSubSenderFactory.java +++ b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanPubSubSenderFactory.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.loadgenerator; import java.io.IOException; import java.nio.ByteBuffer; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A factory for creating {@link PubSubRecordSender}s that sends Titan {@link ActivePowerRecord}s. diff --git a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGenerator.java b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGenerator.java index 34b17db42..ba4d6d125 100644 --- a/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGenerator.java +++ b/theodolite-benchmarks/load-generator-commons/src/main/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGenerator.java @@ -1,7 +1,7 @@ package rocks.theodolite.benchmarks.loadgenerator; import java.time.Clock; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A factory for creating {@link RecordGenerator}s that creates Titan {@link ActivePowerRecord}s. diff --git a/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/HttpRecordSenderTest.java b/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/HttpRecordSenderTest.java index 731dda6c7..cbb390633 100644 --- a/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/HttpRecordSenderTest.java +++ b/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/HttpRecordSenderTest.java @@ -14,7 +14,7 @@ import java.net.URI; import org.junit.Before; import org.junit.Rule; import org.junit.Test; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; public class HttpRecordSenderTest { diff --git a/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGeneratorTest.java b/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGeneratorTest.java index eb7c7f2a4..d1d66829e 100644 --- a/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGeneratorTest.java +++ b/theodolite-benchmarks/load-generator-commons/src/test/java/rocks/theodolite/benchmarks/loadgenerator/TitanRecordGeneratorTest.java @@ -7,7 +7,7 @@ import java.time.ZoneId; import java.time.ZoneOffset; import org.junit.Assert; import org.junit.Test; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; public class TitanRecordGeneratorTest { diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/ConverterAdapter.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/ConverterAdapter.java index 08834a472..fb3bd8055 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/ConverterAdapter.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/ConverterAdapter.java @@ -3,7 +3,7 @@ package rocks.theodolite.benchmarks.uc1.beam; import org.apache.beam.sdk.transforms.SimpleFunction; import org.apache.beam.sdk.values.TypeDescriptor; import rocks.theodolite.benchmarks.uc1.commons.RecordConverter; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * {@link SimpleFunction} which wraps a {@link RecordConverter} to be used with Beam. diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/GenericSink.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/GenericSink.java index 04eae7998..fe33450ea 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/GenericSink.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/GenericSink.java @@ -5,7 +5,7 @@ import org.apache.beam.sdk.transforms.PTransform; import org.apache.beam.sdk.transforms.ParDo; import org.apache.beam.sdk.values.PCollection; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A {@link PTransform} for a generic {@link DatabaseAdapter}. diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/PipelineFactory.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/PipelineFactory.java index d95d9b334..4cdd0cfc6 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/PipelineFactory.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/PipelineFactory.java @@ -10,7 +10,7 @@ import org.apache.commons.configuration2.Configuration; import rocks.theodolite.benchmarks.commons.beam.AbstractPipelineFactory; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaActivePowerTimestampReader; import rocks.theodolite.benchmarks.uc1.beam.firestore.FirestoreOptionsExpander; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * {@link AbstractPipelineFactory} for UC1. diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkFactory.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkFactory.java index d4854293b..a45b4bc3e 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkFactory.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkFactory.java @@ -3,7 +3,7 @@ package rocks.theodolite.benchmarks.uc1.beam; import org.apache.beam.sdk.transforms.PTransform; import org.apache.beam.sdk.values.PCollection; import org.apache.commons.configuration2.Configuration; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Interface for a class that creates sinks (i.e., {@link PTransform}s that map and store diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkType.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkType.java index da836815e..a1c957041 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkType.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/SinkType.java @@ -6,7 +6,7 @@ import org.apache.beam.sdk.values.PCollection; import org.apache.commons.configuration2.Configuration; import rocks.theodolite.benchmarks.uc1.beam.firestore.FirestoreSink; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Supported Sink types, i.e., {@link PTransform} for converting and storing diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/DocumentMapper.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/DocumentMapper.java index 1abf84725..b72bedce2 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/DocumentMapper.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/DocumentMapper.java @@ -4,7 +4,7 @@ import com.google.firestore.v1.Document; import com.google.firestore.v1.Value; import java.io.IOException; import org.apache.beam.sdk.transforms.SimpleFunction; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; final class DocumentMapper extends SimpleFunction<ActivePowerRecord, Document> { diff --git a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/FirestoreSink.java b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/FirestoreSink.java index dfe3f240b..ba6542f4a 100644 --- a/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/FirestoreSink.java +++ b/theodolite-benchmarks/uc1-beam/src/main/java/rocks/theodolite/benchmarks/uc1/beam/firestore/FirestoreSink.java @@ -7,7 +7,7 @@ import org.apache.beam.sdk.transforms.MapElements; import org.apache.beam.sdk.transforms.PTransform; import org.apache.beam.sdk.values.PCollection; import org.apache.commons.configuration2.Configuration; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A {@link PTransform} mapping {@link ActivePowerRecord}s to {@link Document}s, followed by storing diff --git a/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/ConverterAdapter.java b/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/ConverterAdapter.java index 064b8afbb..05bd1432b 100644 --- a/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/ConverterAdapter.java +++ b/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/ConverterAdapter.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc1.flink; import org.apache.flink.api.common.functions.MapFunction; import rocks.theodolite.benchmarks.uc1.commons.RecordConverter; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * {@link MapFunction} which wraps a {@link RecordConverter} to be used with Flink. diff --git a/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/HistoryServiceFlinkJob.java b/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/HistoryServiceFlinkJob.java index d674effac..dce779382 100644 --- a/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/HistoryServiceFlinkJob.java +++ b/theodolite-benchmarks/uc1-flink/src/main/java/rocks/theodolite/benchmarks/uc1/flink/HistoryServiceFlinkJob.java @@ -10,8 +10,8 @@ import org.slf4j.LoggerFactory; import rocks.theodolite.benchmarks.commons.flink.KafkaConnectorFactory; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; -import titan.ccp.common.configuration.ServiceConfigurations; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * The History microservice implemented as a Flink job. diff --git a/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/PipelineFactory.java b/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/PipelineFactory.java index 375b2a6cb..868ebfa79 100644 --- a/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/PipelineFactory.java +++ b/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/PipelineFactory.java @@ -22,7 +22,7 @@ import rocks.theodolite.benchmarks.commons.beam.AbstractPipelineFactory; import rocks.theodolite.benchmarks.commons.beam.ConfigurationKeys; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaActivePowerTimestampReader; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaWriterTransformation; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * {@link AbstractPipelineFactory} for UC2. diff --git a/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/StatsAggregation.java b/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/StatsAggregation.java index a8956ee4b..aeb614fd0 100644 --- a/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/StatsAggregation.java +++ b/theodolite-benchmarks/uc2-beam/src/main/java/rocks/theodolite/benchmarks/uc2/beam/StatsAggregation.java @@ -6,7 +6,7 @@ import java.io.Serializable; import org.apache.beam.sdk.coders.AvroCoder; import org.apache.beam.sdk.coders.DefaultCoder; import org.apache.beam.sdk.transforms.Combine.CombineFn; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Aggregation Class for ActivePowerRecords. Creates a StatsAccumulator based on the ValueInW. diff --git a/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/HistoryServiceFlinkJob.java b/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/HistoryServiceFlinkJob.java index 7e67be897..ace81d5e3 100644 --- a/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/HistoryServiceFlinkJob.java +++ b/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/HistoryServiceFlinkJob.java @@ -16,8 +16,8 @@ import org.slf4j.LoggerFactory; import rocks.theodolite.benchmarks.commons.flink.KafkaConnectorFactory; import rocks.theodolite.benchmarks.commons.flink.StateBackends; import rocks.theodolite.benchmarks.commons.flink.serialization.StatsSerializer; -import titan.ccp.common.configuration.ServiceConfigurations; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** diff --git a/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/StatsAggregateFunction.java b/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/StatsAggregateFunction.java index b2a9e5f53..a43d9b4ef 100644 --- a/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/StatsAggregateFunction.java +++ b/theodolite-benchmarks/uc2-flink/src/main/java/rocks/theodolite/benchmarks/uc2/flink/StatsAggregateFunction.java @@ -4,7 +4,7 @@ import com.google.common.math.Stats; import com.google.common.math.StatsAccumulator; import org.apache.flink.api.common.functions.AggregateFunction; import rocks.theodolite.benchmarks.uc2.flink.util.StatsFactory; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Statistical aggregation of {@link ActivePowerRecord}s using {@link Stats}. diff --git a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/HourOfDayKeySerde.java b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/HourOfDayKeySerde.java index 1c09d7d50..8632572f0 100644 --- a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/HourOfDayKeySerde.java +++ b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/HourOfDayKeySerde.java @@ -1,10 +1,10 @@ package rocks.theodolite.benchmarks.uc3.beam; import org.apache.kafka.common.serialization.Serde; -import titan.ccp.common.kafka.simpleserdes.BufferSerde; -import titan.ccp.common.kafka.simpleserdes.ReadBuffer; -import titan.ccp.common.kafka.simpleserdes.SimpleSerdes; -import titan.ccp.common.kafka.simpleserdes.WriteBuffer; +import rocks.theodolite.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.commons.kafka.simpleserdes.WriteBuffer; /** * {@link BufferSerde} for a {@link HourOfDayKey}. Use the {@link #create()} method to create a new diff --git a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/MapTimeFormat.java b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/MapTimeFormat.java index 3c0d7acdb..f183878a0 100644 --- a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/MapTimeFormat.java +++ b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/MapTimeFormat.java @@ -5,7 +5,7 @@ import java.time.LocalDateTime; import java.time.ZoneId; import org.apache.beam.sdk.transforms.SimpleFunction; import org.apache.beam.sdk.values.KV; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Changes the time format to us Europe/Paris time. diff --git a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/PipelineFactory.java b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/PipelineFactory.java index 9c766e412..c8b0220bf 100644 --- a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/PipelineFactory.java +++ b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/PipelineFactory.java @@ -23,7 +23,7 @@ import rocks.theodolite.benchmarks.commons.beam.AbstractPipelineFactory; import rocks.theodolite.benchmarks.commons.beam.ConfigurationKeys; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaActivePowerTimestampReader; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaWriterTransformation; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * {@link AbstractPipelineFactory} for UC3. diff --git a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/StatsAggregation.java b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/StatsAggregation.java index e479c0ab5..1e2130846 100644 --- a/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/StatsAggregation.java +++ b/theodolite-benchmarks/uc3-beam/src/main/java/rocks/theodolite/benchmarks/uc3/beam/StatsAggregation.java @@ -6,7 +6,7 @@ import java.io.Serializable; import org.apache.beam.sdk.coders.AvroCoder; import org.apache.beam.sdk.coders.DefaultCoder; import org.apache.beam.sdk.transforms.Combine.CombineFn; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** diff --git a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/HistoryServiceFlinkJob.java b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/HistoryServiceFlinkJob.java index 4cf7ed080..f630b4428 100644 --- a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/HistoryServiceFlinkJob.java +++ b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/HistoryServiceFlinkJob.java @@ -24,8 +24,8 @@ import rocks.theodolite.benchmarks.uc3.flink.util.HourOfDayKey; import rocks.theodolite.benchmarks.uc3.flink.util.HourOfDayKeyFactory; import rocks.theodolite.benchmarks.uc3.flink.util.HourOfDayKeySerde; import rocks.theodolite.benchmarks.uc3.flink.util.StatsKeyFactory; -import titan.ccp.common.configuration.ServiceConfigurations; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * The History microservice implemented as a Flink job. diff --git a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/StatsAggregateFunction.java b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/StatsAggregateFunction.java index 38d277dac..f58bda804 100644 --- a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/StatsAggregateFunction.java +++ b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/StatsAggregateFunction.java @@ -4,7 +4,7 @@ import com.google.common.math.Stats; import com.google.common.math.StatsAccumulator; import org.apache.flink.api.common.functions.AggregateFunction; import rocks.theodolite.benchmarks.uc3.flink.util.StatsFactory; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Statistical aggregation of {@link ActivePowerRecord}s using {@link Stats}. diff --git a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayKeySerde.java b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayKeySerde.java index 2c5bd40fe..f9756bdaa 100644 --- a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayKeySerde.java +++ b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayKeySerde.java @@ -6,10 +6,10 @@ import com.esotericsoftware.kryo.io.Input; import com.esotericsoftware.kryo.io.Output; import java.io.Serializable; import org.apache.kafka.common.serialization.Serde; -import titan.ccp.common.kafka.simpleserdes.BufferSerde; -import titan.ccp.common.kafka.simpleserdes.ReadBuffer; -import titan.ccp.common.kafka.simpleserdes.SimpleSerdes; -import titan.ccp.common.kafka.simpleserdes.WriteBuffer; +import rocks.theodolite.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.commons.kafka.simpleserdes.WriteBuffer; /** * {@link BufferSerde} for a {@link HourOfDayKey}. Use the {@link #create()} method to create a new diff --git a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayRecordFactory.java b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayRecordFactory.java index 5c52a446e..69aaa25f0 100644 --- a/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayRecordFactory.java +++ b/theodolite-benchmarks/uc3-flink/src/main/java/rocks/theodolite/benchmarks/uc3/flink/util/HourOfDayRecordFactory.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc3.flink.util; import com.google.common.math.Stats; import org.apache.kafka.streams.kstream.Windowed; -import titan.ccp.model.records.HourOfDayActivePowerRecord; +import rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord; /** * {@link StatsRecordFactory} to create an {@link HourOfDayActivePowerRecord}. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedActivePowerRecordEventTimePolicy.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedActivePowerRecordEventTimePolicy.java index 3af4957aa..d55c3c78b 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedActivePowerRecordEventTimePolicy.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedActivePowerRecordEventTimePolicy.java @@ -5,7 +5,7 @@ import org.apache.beam.sdk.io.kafka.KafkaRecord; import org.apache.beam.sdk.io.kafka.TimestampPolicy; import org.apache.beam.sdk.transforms.windowing.BoundedWindow; import org.joda.time.Instant; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * TimeStampPolicy to use event time based on the timestamp of the record value. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedToActive.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedToActive.java index 63f914dca..cf34ce816 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedToActive.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/AggregatedToActive.java @@ -2,8 +2,8 @@ package rocks.theodolite.benchmarks.uc4.beam; import org.apache.beam.sdk.transforms.SimpleFunction; import org.apache.beam.sdk.values.KV; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * Converts AggregatedActivePowerRecord to ActivePowerRecord. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/DuplicateAsFlatMap.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/DuplicateAsFlatMap.java index 1b430c99b..bc3fbdc02 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/DuplicateAsFlatMap.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/DuplicateAsFlatMap.java @@ -10,7 +10,7 @@ import org.apache.beam.sdk.state.ValueState; import org.apache.beam.sdk.transforms.DoFn; import org.apache.beam.sdk.values.KV; import org.apache.beam.sdk.values.PCollectionView; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterEvents.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterEvents.java index 6a96d7270..1325f9f45 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterEvents.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterEvents.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.beam; import org.apache.beam.sdk.transforms.SerializableFunction; import org.apache.beam.sdk.values.KV; -import titan.ccp.configuration.events.Event; +import rocks.theodolite.commons.configuration.events.Event; /** * Filters for {@code Event.SENSOR_REGISTRY_CHANGED} and {@code Event.SENSOR_REGISTRY_STATUS} diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterNullValues.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterNullValues.java index 9aa48d7b8..858262bf4 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterNullValues.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/FilterNullValues.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.beam; import org.apache.beam.sdk.transforms.SerializableFunction; import org.apache.beam.sdk.values.KV; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Filters {@code null} Values. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/GenerateParentsFn.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/GenerateParentsFn.java index e6f01c3d5..226f0fdb7 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/GenerateParentsFn.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/GenerateParentsFn.java @@ -8,10 +8,10 @@ import java.util.stream.Collectors; import java.util.stream.Stream; import org.apache.beam.sdk.transforms.DoFn; import org.apache.beam.sdk.values.KV; -import titan.ccp.configuration.events.Event; -import titan.ccp.model.sensorregistry.AggregatedSensor; -import titan.ccp.model.sensorregistry.Sensor; -import titan.ccp.model.sensorregistry.SensorRegistry; +import rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.commons.model.sensorregistry.Sensor; +import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * DoFn class to generate a child-parent pair for every sensor in the hierarchy. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/PipelineFactory.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/PipelineFactory.java index 42d12d820..69ab5c5bd 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/PipelineFactory.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/PipelineFactory.java @@ -46,9 +46,9 @@ import rocks.theodolite.benchmarks.uc4.beam.serialization.AggregatedActivePowerR import rocks.theodolite.benchmarks.uc4.beam.serialization.EventCoder; import rocks.theodolite.benchmarks.uc4.beam.serialization.EventDeserializer; import rocks.theodolite.benchmarks.uc4.beam.serialization.SensorParentKeyCoder; -import titan.ccp.configuration.events.Event; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * {@link AbstractPipelineFactory} for UC4. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/RecordAggregation.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/RecordAggregation.java index 6fbf6ff3f..2e36901cf 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/RecordAggregation.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/RecordAggregation.java @@ -4,8 +4,8 @@ import java.io.Serializable; import org.apache.beam.sdk.coders.AvroCoder; import org.apache.beam.sdk.coders.DefaultCoder; import org.apache.beam.sdk.transforms.Combine.CombineFn; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetIdForAggregated.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetIdForAggregated.java index 23ebb6d01..2fb648e05 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetIdForAggregated.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetIdForAggregated.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.beam; import org.apache.beam.sdk.transforms.SimpleFunction; import org.apache.beam.sdk.values.KV; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * Sets the identifier for new {@link AggregatedActivePowerRecord}. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetKeyToGroup.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetKeyToGroup.java index 3ffba1282..ea90ae32d 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetKeyToGroup.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/SetKeyToGroup.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.beam; import org.apache.beam.sdk.transforms.SimpleFunction; import org.apache.beam.sdk.values.KV; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Set the Key for a group of {@code ActivePowerRecords} to their Parent. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordCoder.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordCoder.java index f460d42de..d44e47407 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordCoder.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordCoder.java @@ -8,7 +8,7 @@ import java.util.List; import org.apache.beam.sdk.coders.AvroCoder; import org.apache.beam.sdk.coders.Coder; import org.apache.beam.sdk.coders.CoderException; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * {@link Coder} for an {@link AggregatedActivePowerRecord}. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordDeserializer.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordDeserializer.java index 2c481f8e6..2f345328a 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordDeserializer.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordDeserializer.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.beam.serialization; import io.confluent.kafka.streams.serdes.avro.SpecificAvroDeserializer; import org.apache.kafka.common.serialization.Deserializer; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * {@link Deserializer} for an {@link AggregatedActivePowerRecord}. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordSerializer.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordSerializer.java index 073c3d0f9..5dff392cd 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordSerializer.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/AggregatedActivePowerRecordSerializer.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.beam.serialization; import io.confluent.kafka.streams.serdes.avro.SpecificAvroSerializer; import org.apache.kafka.common.serialization.Serializer; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * {@link Serializer} for an {@link AggregatedActivePowerRecord}. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventCoder.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventCoder.java index b96398398..a8d7b37d9 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventCoder.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventCoder.java @@ -10,8 +10,8 @@ import java.util.List; import org.apache.beam.sdk.coders.Coder; import org.apache.beam.sdk.coders.CoderException; import org.apache.kafka.common.serialization.Serde; -import titan.ccp.configuration.events.Event; -import titan.ccp.configuration.events.EventSerde; +import rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.commons.configuration.events.EventSerde; /** * Wrapper Class that encapsulates a Event Serde in a org.apache.beam.sdk.coders.Coder. diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventDeserializer.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventDeserializer.java index ae9c480e1..b57177d2e 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventDeserializer.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/EventDeserializer.java @@ -3,7 +3,7 @@ package rocks.theodolite.benchmarks.uc4.beam.serialization; import java.util.Map; import org.apache.kafka.common.serialization.ByteBufferDeserializer; import org.apache.kafka.common.serialization.Deserializer; -import titan.ccp.configuration.events.Event; +import rocks.theodolite.commons.configuration.events.Event; /** * Deserializer for Events(SensorRegistry changes). diff --git a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/SensorParentKeySerde.java b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/SensorParentKeySerde.java index 64242b3fd..b5c197c9b 100644 --- a/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/SensorParentKeySerde.java +++ b/theodolite-benchmarks/uc4-beam/src/main/java/rocks/theodolite/benchmarks/uc4/beam/serialization/SensorParentKeySerde.java @@ -2,10 +2,10 @@ package rocks.theodolite.benchmarks.uc4.beam.serialization; import org.apache.kafka.common.serialization.Serde; import rocks.theodolite.benchmarks.uc4.beam.SensorParentKey; -import titan.ccp.common.kafka.simpleserdes.BufferSerde; -import titan.ccp.common.kafka.simpleserdes.ReadBuffer; -import titan.ccp.common.kafka.simpleserdes.SimpleSerdes; -import titan.ccp.common.kafka.simpleserdes.WriteBuffer; +import rocks.theodolite.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.commons.kafka.simpleserdes.WriteBuffer; /** * {@link Serde} factory for {@link SensorParentKey}. diff --git a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/AggregationServiceFlinkJob.java b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/AggregationServiceFlinkJob.java index 726a7f590..76ac8b3a0 100644 --- a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/AggregationServiceFlinkJob.java +++ b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/AggregationServiceFlinkJob.java @@ -26,14 +26,14 @@ import rocks.theodolite.benchmarks.uc4.flink.util.ImmutableSensorRegistrySeriali import rocks.theodolite.benchmarks.uc4.flink.util.ImmutableSetSerializer; import rocks.theodolite.benchmarks.uc4.flink.util.SensorParentKey; import rocks.theodolite.benchmarks.uc4.flink.util.SensorParentKeySerializer; -import titan.ccp.common.configuration.ServiceConfigurations; -import titan.ccp.common.kafka.avro.SchemaRegistryAvroSerdeFactory; -import titan.ccp.configuration.events.Event; -import titan.ccp.configuration.events.EventSerde; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; -import titan.ccp.model.sensorregistry.ImmutableSensorRegistry; -import titan.ccp.model.sensorregistry.SensorRegistry; +import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.commons.configuration.events.EventSerde; +import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; +import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * The Aggregation microservice implemented as a Flink job. diff --git a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/ChildParentsFlatMapFunction.java b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/ChildParentsFlatMapFunction.java index c439df1e4..d1ef7258a 100644 --- a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/ChildParentsFlatMapFunction.java +++ b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/ChildParentsFlatMapFunction.java @@ -13,9 +13,9 @@ import org.apache.flink.api.common.typeinfo.TypeInformation; import org.apache.flink.api.java.tuple.Tuple2; import org.apache.flink.configuration.Configuration; import org.apache.flink.util.Collector; -import titan.ccp.model.sensorregistry.AggregatedSensor; -import titan.ccp.model.sensorregistry.Sensor; -import titan.ccp.model.sensorregistry.SensorRegistry; +import rocks.theodolite.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.commons.model.sensorregistry.Sensor; +import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * Transforms a {@link SensorRegistry} into key value pairs of Sensor identifiers and their parents' diff --git a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/JoinAndDuplicateCoFlatMapFunction.java b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/JoinAndDuplicateCoFlatMapFunction.java index 624327a69..f5edbd8a3 100644 --- a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/JoinAndDuplicateCoFlatMapFunction.java +++ b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/JoinAndDuplicateCoFlatMapFunction.java @@ -10,7 +10,7 @@ import org.apache.flink.configuration.Configuration; import org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction; import org.apache.flink.util.Collector; import rocks.theodolite.benchmarks.uc4.flink.util.SensorParentKey; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * A {@link RichCoFlatMapFunction} which joins each incoming {@link ActivePowerRecord} with its diff --git a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/RecordAggregationProcessWindowFunction.java b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/RecordAggregationProcessWindowFunction.java index 29e1ea322..7c42d8f54 100644 --- a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/RecordAggregationProcessWindowFunction.java +++ b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/RecordAggregationProcessWindowFunction.java @@ -12,8 +12,8 @@ import org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction; import org.apache.flink.streaming.api.windowing.windows.TimeWindow; import org.apache.flink.util.Collector; import rocks.theodolite.benchmarks.uc4.flink.util.SensorParentKey; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; /** * A {@link ProcessWindowFunction} which performs the windowed aggregation of all diff --git a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/util/ImmutableSensorRegistrySerializer.java b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/util/ImmutableSensorRegistrySerializer.java index 54d882690..e235e9185 100644 --- a/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/util/ImmutableSensorRegistrySerializer.java +++ b/theodolite-benchmarks/uc4-flink/src/main/java/rocks/theodolite/benchmarks/uc4/flink/util/ImmutableSensorRegistrySerializer.java @@ -5,7 +5,7 @@ import com.esotericsoftware.kryo.Serializer; import com.esotericsoftware.kryo.io.Input; import com.esotericsoftware.kryo.io.Output; import java.io.Serializable; -import titan.ccp.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.commons.model.sensorregistry.ImmutableSensorRegistry; /** * A {@link Serializer} for {@link ImmutableSensorRegistry}s. diff --git a/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/ConfigPublisher.java b/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/ConfigPublisher.java index 98f470b0d..c7601ef3b 100644 --- a/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/ConfigPublisher.java +++ b/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/ConfigPublisher.java @@ -7,8 +7,8 @@ import org.apache.kafka.clients.producer.Producer; import org.apache.kafka.clients.producer.ProducerConfig; import org.apache.kafka.clients.producer.ProducerRecord; import org.apache.kafka.common.serialization.StringSerializer; -import titan.ccp.configuration.events.Event; -import titan.ccp.configuration.events.EventSerde; +import rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.commons.configuration.events.EventSerde; /** * Class to publish a configuration to Kafka. diff --git a/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/LoadGenerator.java b/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/LoadGenerator.java index 2077de2d9..79f4f21b0 100644 --- a/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/LoadGenerator.java +++ b/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/LoadGenerator.java @@ -4,8 +4,8 @@ import java.util.Objects; import org.slf4j.Logger; import org.slf4j.LoggerFactory; import rocks.theodolite.benchmarks.loadgenerator.KeySpace; -import titan.ccp.configuration.events.Event; -import titan.ccp.model.sensorregistry.SensorRegistry; +import rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * Load generator for Theodolite use case UC4. diff --git a/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilder.java b/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilder.java index c69dffb60..b8b89a71a 100644 --- a/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilder.java +++ b/theodolite-benchmarks/uc4-load-generator/src/main/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilder.java @@ -1,8 +1,8 @@ package rocks.theodolite.benchmarks.uc4.loadgenerator; -import titan.ccp.model.sensorregistry.MutableAggregatedSensor; -import titan.ccp.model.sensorregistry.MutableSensorRegistry; -import titan.ccp.model.sensorregistry.SensorRegistry; +import rocks.theodolite.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.commons.model.sensorregistry.MutableSensorRegistry; +import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * Builder for creating a nested {@link SensorRegistry} with {@code numNestedGroups} levels and diff --git a/theodolite-benchmarks/uc4-load-generator/src/test/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilderTest.java b/theodolite-benchmarks/uc4-load-generator/src/test/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilderTest.java index a169eddb1..8c695f6e5 100644 --- a/theodolite-benchmarks/uc4-load-generator/src/test/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilderTest.java +++ b/theodolite-benchmarks/uc4-load-generator/src/test/java/rocks/theodolite/benchmarks/uc4/loadgenerator/SensorRegistryBuilderTest.java @@ -5,10 +5,10 @@ import java.util.Set; import java.util.stream.Collectors; import org.junit.Assert; import org.junit.Test; -import titan.ccp.model.sensorregistry.AggregatedSensor; -import titan.ccp.model.sensorregistry.MachineSensor; -import titan.ccp.model.sensorregistry.Sensor; -import titan.ccp.model.sensorregistry.SensorRegistry; +import rocks.theodolite.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.commons.model.sensorregistry.MachineSensor; +import rocks.theodolite.commons.model.sensorregistry.Sensor; +import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; public class SensorRegistryBuilderTest { -- GitLab