From 844112746890ad30c1c33019c78357756f2ae7fb Mon Sep 17 00:00:00 2001 From: =?UTF-8?q?S=C3=B6ren=20Henning?= <soeren.henning@email.uni-kiel.de> Date: Thu, 9 Jun 2022 14:35:31 +0200 Subject: [PATCH] Align package structure --- .../benchmarks/commons/beam/BeamService.java | 2 +- .../kafka/ActivePowerRecordDeserializer.java | 3 +- .../commons/beam/kafka/EventTimePolicy.java | 2 +- .../KafkaActivePowerTimestampReader.java | 2 +- .../groovy/theodolite.hazelcastjet.gradle | 5 +- theodolite-benchmarks/commons/build.gradle | 4 +- .../model/records/ActivePowerRecord.avsc | 2 +- .../records/AggregatedActivePowerRecord.avsc | 2 +- .../records/DayOfWeekActivePowerRecord.avsc | 2 +- .../records/HourOfDayActivePowerRecord.avsc | 2 +- .../records/HourOfWeekActivePowerRecord.avsc | 2 +- .../records/MonthOfYearActivePowerRecord.avsc | 2 +- .../model/records/YearActivePowerRecord.avsc | 2 +- .../model/records/ActivePowerRecord.java | 38 +++++------ .../records/AggregatedActivePowerRecord.java | 46 ++++++------- .../records/DayOfWeekActivePowerRecord.java | 62 ++++++++--------- .../records/HourOfDayActivePowerRecord.java | 62 ++++++++--------- .../records/HourOfWeekActivePowerRecord.java | 66 +++++++++---------- .../records/MonthOfYearActivePowerRecord.java | 62 ++++++++--------- .../model/records/YearActivePowerRecord.java | 62 ++++++++--------- .../commons/src/main/avro/ActivePower.avdl | 2 +- .../src/main/avro/AggregatedActivePower.avdl | 2 +- .../src/main/avro/StatsActivePower.avdl | 2 +- ...NameResolvingEnvironmentConfiguration.java | 2 +- .../configuration/ServiceConfigurations.java | 2 +- .../commons/configuration/events/Event.java | 4 +- .../configuration/events/EventSerde.java | 2 +- .../avro/SchemaRegistryAvroSerdeFactory.java | 2 +- .../kafka/simpleserdes/BufferConstants.java | 2 +- .../simpleserdes/BufferDeserializer.java | 2 +- .../kafka/simpleserdes/BufferSerde.java | 2 +- .../kafka/simpleserdes/BufferSerializer.java | 2 +- .../kafka/simpleserdes/ReadBuffer.java | 2 +- .../simpleserdes/SimpleDeserializer.java | 2 +- .../kafka/simpleserdes/SimpleSerdes.java | 2 +- .../kafka/simpleserdes/SimpleSerializer.java | 2 +- .../kafka/simpleserdes/WriteBuffer.java | 2 +- .../model/sensorregistry/AbstractSensor.java | 2 +- .../sensorregistry/AggregatedSensor.java | 2 +- .../ImmutableSensorRegistry.java | 12 ++-- .../model/sensorregistry/MachineSensor.java | 2 +- .../sensorregistry/MachineSensorImpl.java | 2 +- .../MutableAggregatedSensor.java | 2 +- .../sensorregistry/MutableSensorRegistry.java | 10 +-- .../commons/model/sensorregistry/Sensor.java | 2 +- .../model/sensorregistry/SensorRegistry.java | 2 +- .../AggregatedSensorSerializer.java | 6 +- .../MachineSensorSerializer.java | 6 +- .../SensorRegistryDeserializer.java | 14 ++-- .../SensorRegistrySerializer.java | 6 +- ...ResolvingEnvironmentConfigurationTest.java | 4 +- .../model/sensorregistry/ExampleSensors.java | 8 ++- .../ImmutableSensorRegistryTest.java | 6 +- .../MaschineSensorImplExposer.java | 5 +- .../MutableSensorRegistryTest.java | 6 +- .../SensorRegistryDeserializerTest.java | 11 ++-- .../SensorRegistrySerializerTest.java | 12 ++-- .../httpbridge/EnvVarHttpBridgeFactory.java | 2 +- .../EnvVarLoadGeneratorFactory.java | 2 +- .../loadgenerator/KafkaRecordSender.java | 2 +- .../TitanKafkaSenderFactory.java | 2 +- .../TitanPubSubSenderFactory.java | 2 +- .../loadgenerator/TitanRecordGenerator.java | 2 +- .../loadgenerator/HttpRecordSenderTest.java | 2 +- .../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 +- .../benchmarks/uc1/beam/SinkType.java | 2 +- .../uc1/beam/firestore/DocumentMapper.java | 2 +- .../uc1/beam/firestore/FirestoreSink.java | 2 +- .../uc1/commons/DatabaseAdapter.java | 2 +- .../uc1/commons/RecordConverter.java | 2 +- .../uc1/commons/logger/JsonConverter.java | 2 +- .../uc1/flink/ConverterAdapter.java | 2 +- .../uc1/flink/HistoryServiceFlinkJob.java | 4 +- .../uc1/hazelcastjet/Uc1PipelineBuilder.java | 8 +-- .../uc1/hazelcast/Uc1PipelineTest.java | 39 ++++++----- .../uc1/kstreams/HistoryService.java | 2 +- .../uc1/kstreams/TopologyBuilder.java | 4 +- .../uc1/kstreams/Uc1KafkaStreamsBuilder.java | 2 +- .../benchmarks/uc2/beam/PipelineFactory.java | 2 +- .../benchmarks/uc2/beam/StatsAggregation.java | 2 +- .../uc2/flink/HistoryServiceFlinkJob.java | 4 +- .../uc2/flink/StatsAggregateFunction.java | 2 +- .../uc2/hazelcastjet/Uc2PipelineBuilder.java | 9 +-- .../uc2/hazelcastjet/Uc2PipelineTest.java | 19 +++--- .../uc2/kstreams/HistoryService.java | 2 +- .../uc2/kstreams/TopologyBuilder.java | 4 +- .../uc2/kstreams/Uc2KafkaStreamsBuilder.java | 2 +- .../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 +-- .../flink/util/HourOfDayRecordFactory.java | 2 +- .../uc3/hazelcastjet/Uc3PipelineBuilder.java | 2 +- .../uc3/hazelcastjet/Uc3PipelineTest.java | 42 ++++++------ .../uc3/kstreams/HistoryService.java | 2 +- .../uc3/kstreams/HourOfDayKeySerde.java | 8 +-- .../uc3/kstreams/HourOfDayRecordFactory.java | 2 +- .../uc3/kstreams/TopologyBuilder.java | 4 +- .../uc3/kstreams/Uc3KafkaStreamsBuilder.java | 2 +- ...gatedActivePowerRecordEventTimePolicy.java | 2 +- .../uc4/beam/AggregatedToActive.java | 4 +- .../uc4/beam/DuplicateAsFlatMap.java | 2 +- .../benchmarks/uc4/beam/FilterEvents.java | 2 +- .../benchmarks/uc4/beam/FilterNullValues.java | 2 +- .../uc4/beam/GenerateParentsFn.java | 8 +-- .../benchmarks/uc4/beam/PipelineFactory.java | 6 +- .../uc4/beam/RecordAggregation.java | 4 +- .../uc4/beam/SetIdForAggregated.java | 2 +- .../benchmarks/uc4/beam/SetKeyToGroup.java | 2 +- .../AggregatedActivePowerRecordCoder.java | 2 +- ...gregatedActivePowerRecordDeserializer.java | 2 +- ...AggregatedActivePowerRecordSerializer.java | 2 +- .../uc4/beam/serialization/EventCoder.java | 4 +- .../beam/serialization/EventDeserializer.java | 2 +- .../serialization/SensorParentKeySerde.java | 8 +-- .../uc4/flink/AggregationServiceFlinkJob.java | 16 ++--- .../flink/ChildParentsFlatMapFunction.java | 6 +- .../JoinAndDuplicateCoFlatMapFunction.java | 2 +- ...ecordAggregationProcessWindowFunction.java | 4 +- .../ImmutableSensorRegistrySerializer.java | 2 +- .../hazelcastjet/Uc4HazelcastJetFactory.java | 8 +-- .../uc4/hazelcastjet/Uc4PipelineBuilder.java | 53 +++++++-------- ...ggregatedActivePowerRecordAccumulator.java | 32 ++++----- .../uc4specifics/ChildParentsTransformer.java | 9 +-- .../uc4specifics/EventDeserializer.java | 4 +- .../ImmutableSensorRegistryUc4Serializer.java | 2 +- .../hazelcastjet/uc4specifics/ValueGroup.java | 3 +- .../uc4/hazelcastjet/Uc4PipelineTest.java | 38 +++++------ .../uc4/kstreams/AggregationService.java | 2 +- .../uc4/kstreams/ChildParentsTransformer.java | 8 +-- .../ChildParentsTransformerSupplier.java | 4 +- .../uc4/kstreams/JointFlatTransformer.java | 2 +- .../JointFlatTransformerSupplier.java | 2 +- .../uc4/kstreams/JointRecordParents.java | 2 +- .../uc4/kstreams/OptionalParentsSerde.java | 8 +-- .../benchmarks/uc4/kstreams/ParentsSerde.java | 8 +-- .../uc4/kstreams/RecordAggregator.java | 4 +- .../uc4/kstreams/SensorParentKeySerde.java | 8 +-- .../uc4/kstreams/TopologyBuilder.java | 12 ++-- .../uc4/kstreams/Uc4KafkaStreamsBuilder.java | 2 +- .../uc4/loadgenerator/ConfigPublisher.java | 4 +- .../uc4/loadgenerator/LoadGenerator.java | 4 +- .../loadgenerator/SensorRegistryBuilder.java | 6 +- .../SensorRegistryBuilderTest.java | 8 +-- 151 files changed, 584 insertions(+), 554 deletions(-) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/ActivePowerRecord.avsc (80%) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/AggregatedActivePowerRecord.avsc (86%) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/DayOfWeekActivePowerRecord.avsc (88%) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/HourOfDayActivePowerRecord.avsc (88%) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/HourOfWeekActivePowerRecord.avsc (89%) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/MonthOfYearActivePowerRecord.avsc (89%) rename theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/{ => benchmarks}/commons/model/records/YearActivePowerRecord.avsc (88%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/ActivePowerRecord.java (85%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/AggregatedActivePowerRecord.java (85%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/DayOfWeekActivePowerRecord.java (86%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/HourOfDayActivePowerRecord.java (86%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/HourOfWeekActivePowerRecord.java (86%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/MonthOfYearActivePowerRecord.java (86%) rename theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/{ => benchmarks}/commons/model/records/YearActivePowerRecord.java (86%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java (93%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/commons/configuration/ServiceConfigurations.java (98%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/configuration/events/Event.java (61%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/configuration/events/EventSerde.java (97%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java (95%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/BufferConstants.java (84%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/BufferDeserializer.java (78%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/BufferSerde.java (81%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/BufferSerializer.java (78%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/ReadBuffer.java (95%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/SimpleDeserializer.java (93%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/SimpleSerdes.java (91%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/SimpleSerializer.java (93%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/kafka/simpleserdes/WriteBuffer.java (96%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/AbstractSensor.java (86%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/AggregatedSensor.java (93%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/ImmutableSensorRegistry.java (88%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/MachineSensor.java (86%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/MachineSensorImpl.java (88%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/MutableAggregatedSensor.java (94%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/MutableSensorRegistry.java (83%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/Sensor.java (72%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/SensorRegistry.java (92%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java (82%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/serialization/MachineSensorSerializer.java (81%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java (89%) rename theodolite-benchmarks/commons/src/main/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java (76%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java (94%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/ExampleSensors.java (72%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/ImmutableSensorRegistryTest.java (93%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/MaschineSensorImplExposer.java (57%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/MutableSensorRegistryTest.java (93%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java (93%) rename theodolite-benchmarks/commons/src/test/java/rocks/theodolite/{ => benchmarks}/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java (80%) 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 bf4bb9397..4897f4171 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 rocks.theodolite.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.benchmarks.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 7f0f20c46..8ab579d0c 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,8 @@ package rocks.theodolite.benchmarks.commons.beam.kafka; import io.confluent.kafka.streams.serdes.avro.SpecificAvroDeserializer; import org.apache.kafka.common.serialization.Deserializer; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 f4cd67f24..a63b5f493 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 d7d25ae91..31cd3e6be 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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.hazelcastjet.gradle b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.hazelcastjet.gradle index b092c97cf..0bade8fdd 100644 --- a/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.hazelcastjet.gradle +++ b/theodolite-benchmarks/buildSrc/src/main/groovy/theodolite.hazelcastjet.gradle @@ -17,13 +17,12 @@ 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 'com.google.guava:guava:24.1-jre' implementation 'org.slf4j:slf4j-api:1.7.30' implementation 'org.slf4j:slf4j-simple:1.7.30' - implementation 'io.confluent:kafka-avro-serializer:5.3.0' implementation 'com.hazelcast.jet:hazelcast-jet:4.5' diff --git a/theodolite-benchmarks/commons/build.gradle b/theodolite-benchmarks/commons/build.gradle index b12eaf4e1..2b00b6619 100644 --- a/theodolite-benchmarks/commons/build.gradle +++ b/theodolite-benchmarks/commons/build.gradle @@ -19,7 +19,6 @@ repositories { dependencies { // These dependencies is exported to consumers, that is to say found on their compile classpath. - 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 @@ -29,6 +28,7 @@ dependencies { implementation 'com.google.code.gson:gson:2.8.2' implementation 'com.google.guava:guava:24.1-jre' implementation 'org.slf4j:slf4j-api:1.7.25' + implementation 'org.apache.kafka:kafka-clients:2.4.0' implementation ('io.confluent:kafka-streams-avro-serde:5.3.2') { // Kafka client is already included from Kafka Streams in version 2.4.0 exclude group: 'org.apache.kafka', module: 'kafka-clients' @@ -51,7 +51,7 @@ sourceSets { } -//// Local avro creation +// Local avro creation avro { fieldVisibility = "PRIVATE" // Setters required for flink because of https://issues.apache.org/jira/browse/FLINK-13703 diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/ActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/ActivePowerRecord.avsc similarity index 80% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/ActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/ActivePowerRecord.avsc index 334ff29af..91f116863 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/ActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/ActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "ActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string", diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/AggregatedActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/AggregatedActivePowerRecord.avsc similarity index 86% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/AggregatedActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/AggregatedActivePowerRecord.avsc index 4f5762fb1..336476e84 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/AggregatedActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/AggregatedActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "AggregatedActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string", diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/DayOfWeekActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/DayOfWeekActivePowerRecord.avsc similarity index 88% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/DayOfWeekActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/DayOfWeekActivePowerRecord.avsc index e879a4df8..c029937dd 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/DayOfWeekActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/DayOfWeekActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "DayOfWeekActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string" diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/HourOfDayActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/HourOfDayActivePowerRecord.avsc similarity index 88% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/HourOfDayActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/HourOfDayActivePowerRecord.avsc index 266a7cf9d..3ad6d6ade 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/HourOfDayActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/HourOfDayActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "HourOfDayActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string" diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/HourOfWeekActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/HourOfWeekActivePowerRecord.avsc similarity index 89% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/HourOfWeekActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/HourOfWeekActivePowerRecord.avsc index 325b1f527..74739f5bd 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/HourOfWeekActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/HourOfWeekActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "HourOfWeekActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string" diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/MonthOfYearActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/MonthOfYearActivePowerRecord.avsc similarity index 89% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/MonthOfYearActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/MonthOfYearActivePowerRecord.avsc index daf964283..70dd7eda5 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/MonthOfYearActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/MonthOfYearActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "MonthOfYearActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string" diff --git a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/YearActivePowerRecord.avsc b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/YearActivePowerRecord.avsc similarity index 88% rename from theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/YearActivePowerRecord.avsc rename to theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/YearActivePowerRecord.avsc index 12b071e70..2bfc06b66 100644 --- a/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/commons/model/records/YearActivePowerRecord.avsc +++ b/theodolite-benchmarks/commons/src-gen/main/avro/rocks/theodolite/benchmarks/commons/model/records/YearActivePowerRecord.avsc @@ -1,7 +1,7 @@ { "type" : "record", "name" : "YearActivePowerRecord", - "namespace" : "rocks.theodolite.commons.model.records", + "namespace" : "rocks.theodolite.benchmarks.commons.model.records", "fields" : [ { "name" : "identifier", "type" : "string" diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/ActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/ActivePowerRecord.java similarity index 85% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/ActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/ActivePowerRecord.java index f5df31185..27e0f3907 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/ActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/ActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = 5490311872603136978L; + private static final long serialVersionUID = -5809432381123606133L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"ActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"},\"doc\":\"*\"},{\"name\":\"timestamp\",\"type\":\"long\",\"doc\":\"*\"},{\"name\":\"valueInW\",\"type\":\"double\",\"doc\":\"*\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"ActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"},\"doc\":\"*\"},{\"name\":\"timestamp\",\"type\":\"long\",\"doc\":\"*\"},{\"name\":\"valueInW\",\"type\":\"double\",\"doc\":\"*\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -180,8 +180,8 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * Creates a new ActivePowerRecord RecordBuilder. * @return A new ActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.ActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.ActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder(); } /** @@ -189,11 +189,11 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * @param other The existing builder to copy. * @return A new ActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.ActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.ActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.ActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.ActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder(other); } } @@ -202,11 +202,11 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * @param other The existing instance to copy. * @return A new ActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.ActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.ActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.ActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.ActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder(other); } } @@ -233,7 +233,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.ActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -253,7 +253,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * Creates a Builder by copying an existing ActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.ActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -285,7 +285,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.ActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -307,7 +307,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * * * @return This builder. */ - public rocks.theodolite.commons.model.records.ActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -329,7 +329,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * @param value The value of 'timestamp'. * @return This builder. */ - public rocks.theodolite.commons.model.records.ActivePowerRecord.Builder setTimestamp(long value) { + public rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder setTimestamp(long value) { validate(fields()[1], value); this.timestamp = value; fieldSetFlags()[1] = true; @@ -351,7 +351,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * * * @return This builder. */ - public rocks.theodolite.commons.model.records.ActivePowerRecord.Builder clearTimestamp() { + public rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder clearTimestamp() { fieldSetFlags()[1] = false; return this; } @@ -372,7 +372,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * @param value The value of 'valueInW'. * @return This builder. */ - public rocks.theodolite.commons.model.records.ActivePowerRecord.Builder setValueInW(double value) { + public rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder setValueInW(double value) { validate(fields()[2], value); this.valueInW = value; fieldSetFlags()[2] = true; @@ -394,7 +394,7 @@ public class ActivePowerRecord extends org.apache.avro.specific.SpecificRecordBa * * * @return This builder. */ - public rocks.theodolite.commons.model.records.ActivePowerRecord.Builder clearValueInW() { + public rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord.Builder clearValueInW() { fieldSetFlags()[2] = false; return this; } diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/AggregatedActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/AggregatedActivePowerRecord.java similarity index 85% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/AggregatedActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/AggregatedActivePowerRecord.java index ab7d4d143..7aa6e0b5f 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/AggregatedActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/AggregatedActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class AggregatedActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = -8754457068762464277L; + private static final long serialVersionUID = 334342381382209426L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"AggregatedActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"},\"doc\":\"*\"},{\"name\":\"timestamp\",\"type\":\"long\",\"doc\":\"*\"},{\"name\":\"count\",\"type\":\"long\",\"doc\":\"*\"},{\"name\":\"sumInW\",\"type\":\"double\",\"doc\":\"*\"},{\"name\":\"averageInW\",\"type\":\"double\",\"doc\":\"*\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"AggregatedActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"},\"doc\":\"*\"},{\"name\":\"timestamp\",\"type\":\"long\",\"doc\":\"*\"},{\"name\":\"count\",\"type\":\"long\",\"doc\":\"*\"},{\"name\":\"sumInW\",\"type\":\"double\",\"doc\":\"*\"},{\"name\":\"averageInW\",\"type\":\"double\",\"doc\":\"*\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -228,8 +228,8 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * Creates a new AggregatedActivePowerRecord RecordBuilder. * @return A new AggregatedActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder(); } /** @@ -237,11 +237,11 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param other The existing builder to copy. * @return A new AggregatedActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder(other); } } @@ -250,11 +250,11 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param other The existing instance to copy. * @return A new AggregatedActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.AggregatedActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder(other); } } @@ -285,7 +285,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -313,7 +313,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * Creates a Builder by copying an existing AggregatedActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.AggregatedActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -353,7 +353,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -375,7 +375,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * * * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -397,7 +397,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'timestamp'. * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder setTimestamp(long value) { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder setTimestamp(long value) { validate(fields()[1], value); this.timestamp = value; fieldSetFlags()[1] = true; @@ -419,7 +419,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * * * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder clearTimestamp() { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder clearTimestamp() { fieldSetFlags()[1] = false; return this; } @@ -440,7 +440,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'count'. * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder setCount(long value) { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder setCount(long value) { validate(fields()[2], value); this.count = value; fieldSetFlags()[2] = true; @@ -462,7 +462,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * * * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder clearCount() { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder clearCount() { fieldSetFlags()[2] = false; return this; } @@ -483,7 +483,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'sumInW'. * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder setSumInW(double value) { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder setSumInW(double value) { validate(fields()[3], value); this.sumInW = value; fieldSetFlags()[3] = true; @@ -505,7 +505,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * * * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder clearSumInW() { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder clearSumInW() { fieldSetFlags()[3] = false; return this; } @@ -526,7 +526,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'averageInW'. * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder setAverageInW(double value) { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder setAverageInW(double value) { validate(fields()[4], value); this.averageInW = value; fieldSetFlags()[4] = true; @@ -548,7 +548,7 @@ public class AggregatedActivePowerRecord extends org.apache.avro.specific.Specif * * * @return This builder. */ - public rocks.theodolite.commons.model.records.AggregatedActivePowerRecord.Builder clearAverageInW() { + public rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord.Builder clearAverageInW() { fieldSetFlags()[4] = false; return this; } diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/DayOfWeekActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/DayOfWeekActivePowerRecord.java similarity index 86% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/DayOfWeekActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/DayOfWeekActivePowerRecord.java index c53c3192f..6e6917a63 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/DayOfWeekActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/DayOfWeekActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = 4537540003856933738L; + private static final long serialVersionUID = 874988617222069934L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"DayOfWeekActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"dayOfWeek\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"DayOfWeekActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"dayOfWeek\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -306,8 +306,8 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Creates a new DayOfWeekActivePowerRecord RecordBuilder. * @return A new DayOfWeekActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder(); } /** @@ -315,11 +315,11 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param other The existing builder to copy. * @return A new DayOfWeekActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder(other); } } @@ -328,11 +328,11 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param other The existing instance to copy. * @return A new DayOfWeekActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder(other); } } @@ -362,7 +362,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -406,7 +406,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Creates a Builder by copying an existing DayOfWeekActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -460,7 +460,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -480,7 +480,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'identifier' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -500,7 +500,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'dayOfWeek'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setDayOfWeek(int value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setDayOfWeek(int value) { validate(fields()[1], value); this.dayOfWeek = value; fieldSetFlags()[1] = true; @@ -520,7 +520,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'dayOfWeek' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearDayOfWeek() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearDayOfWeek() { fieldSetFlags()[1] = false; return this; } @@ -539,7 +539,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'periodStart'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setPeriodStart(long value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setPeriodStart(long value) { validate(fields()[2], value); this.periodStart = value; fieldSetFlags()[2] = true; @@ -559,7 +559,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'periodStart' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearPeriodStart() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearPeriodStart() { fieldSetFlags()[2] = false; return this; } @@ -578,7 +578,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'periodEnd'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setPeriodEnd(long value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setPeriodEnd(long value) { validate(fields()[3], value); this.periodEnd = value; fieldSetFlags()[3] = true; @@ -598,7 +598,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'periodEnd' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearPeriodEnd() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearPeriodEnd() { fieldSetFlags()[3] = false; return this; } @@ -617,7 +617,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'count'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setCount(long value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setCount(long value) { validate(fields()[4], value); this.count = value; fieldSetFlags()[4] = true; @@ -637,7 +637,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'count' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearCount() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearCount() { fieldSetFlags()[4] = false; return this; } @@ -656,7 +656,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'mean'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setMean(double value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setMean(double value) { validate(fields()[5], value); this.mean = value; fieldSetFlags()[5] = true; @@ -676,7 +676,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'mean' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearMean() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearMean() { fieldSetFlags()[5] = false; return this; } @@ -695,7 +695,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'populationVariance'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setPopulationVariance(double value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setPopulationVariance(double value) { validate(fields()[6], value); this.populationVariance = value; fieldSetFlags()[6] = true; @@ -715,7 +715,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'populationVariance' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearPopulationVariance() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearPopulationVariance() { fieldSetFlags()[6] = false; return this; } @@ -734,7 +734,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'min'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setMin(double value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setMin(double value) { validate(fields()[7], value); this.min = value; fieldSetFlags()[7] = true; @@ -754,7 +754,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'min' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearMin() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearMin() { fieldSetFlags()[7] = false; return this; } @@ -773,7 +773,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'max'. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder setMax(double value) { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder setMax(double value) { validate(fields()[8], value); this.max = value; fieldSetFlags()[8] = true; @@ -793,7 +793,7 @@ public class DayOfWeekActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'max' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.DayOfWeekActivePowerRecord.Builder clearMax() { + public rocks.theodolite.benchmarks.commons.model.records.DayOfWeekActivePowerRecord.Builder clearMax() { fieldSetFlags()[8] = false; return this; } diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/HourOfDayActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/HourOfDayActivePowerRecord.java similarity index 86% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/HourOfDayActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/HourOfDayActivePowerRecord.java index 154109665..491a91f4d 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/HourOfDayActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/HourOfDayActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class HourOfDayActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = 7743335456275043826L; + private static final long serialVersionUID = 6460936513507715126L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"HourOfDayActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"hourOfDay\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"HourOfDayActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"hourOfDay\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -306,8 +306,8 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Creates a new HourOfDayActivePowerRecord RecordBuilder. * @return A new HourOfDayActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder(); } /** @@ -315,11 +315,11 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param other The existing builder to copy. * @return A new HourOfDayActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder(other); } } @@ -328,11 +328,11 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param other The existing instance to copy. * @return A new HourOfDayActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder(other); } } @@ -362,7 +362,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -406,7 +406,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Creates a Builder by copying an existing HourOfDayActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -460,7 +460,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -480,7 +480,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'identifier' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -500,7 +500,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'hourOfDay'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setHourOfDay(int value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setHourOfDay(int value) { validate(fields()[1], value); this.hourOfDay = value; fieldSetFlags()[1] = true; @@ -520,7 +520,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'hourOfDay' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearHourOfDay() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearHourOfDay() { fieldSetFlags()[1] = false; return this; } @@ -539,7 +539,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'periodStart'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setPeriodStart(long value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setPeriodStart(long value) { validate(fields()[2], value); this.periodStart = value; fieldSetFlags()[2] = true; @@ -559,7 +559,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'periodStart' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearPeriodStart() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearPeriodStart() { fieldSetFlags()[2] = false; return this; } @@ -578,7 +578,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'periodEnd'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setPeriodEnd(long value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setPeriodEnd(long value) { validate(fields()[3], value); this.periodEnd = value; fieldSetFlags()[3] = true; @@ -598,7 +598,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'periodEnd' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearPeriodEnd() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearPeriodEnd() { fieldSetFlags()[3] = false; return this; } @@ -617,7 +617,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'count'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setCount(long value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setCount(long value) { validate(fields()[4], value); this.count = value; fieldSetFlags()[4] = true; @@ -637,7 +637,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'count' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearCount() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearCount() { fieldSetFlags()[4] = false; return this; } @@ -656,7 +656,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'mean'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setMean(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setMean(double value) { validate(fields()[5], value); this.mean = value; fieldSetFlags()[5] = true; @@ -676,7 +676,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'mean' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearMean() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearMean() { fieldSetFlags()[5] = false; return this; } @@ -695,7 +695,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'populationVariance'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setPopulationVariance(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setPopulationVariance(double value) { validate(fields()[6], value); this.populationVariance = value; fieldSetFlags()[6] = true; @@ -715,7 +715,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'populationVariance' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearPopulationVariance() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearPopulationVariance() { fieldSetFlags()[6] = false; return this; } @@ -734,7 +734,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'min'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setMin(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setMin(double value) { validate(fields()[7], value); this.min = value; fieldSetFlags()[7] = true; @@ -754,7 +754,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'min' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearMin() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearMin() { fieldSetFlags()[7] = false; return this; } @@ -773,7 +773,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * @param value The value of 'max'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder setMax(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder setMax(double value) { validate(fields()[8], value); this.max = value; fieldSetFlags()[8] = true; @@ -793,7 +793,7 @@ public class HourOfDayActivePowerRecord extends org.apache.avro.specific.Specifi * Clears the value of the 'max' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord.Builder clearMax() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord.Builder clearMax() { fieldSetFlags()[8] = false; return this; } diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/HourOfWeekActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/HourOfWeekActivePowerRecord.java similarity index 86% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/HourOfWeekActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/HourOfWeekActivePowerRecord.java index 6bb063d21..112e1f7bc 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/HourOfWeekActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/HourOfWeekActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = 2784889086011309745L; + private static final long serialVersionUID = -2060891996492175489L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"HourOfWeekActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"dayOfWeek\",\"type\":\"int\"},{\"name\":\"hourOfDay\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"HourOfWeekActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"dayOfWeek\",\"type\":\"int\"},{\"name\":\"hourOfDay\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -328,8 +328,8 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Creates a new HourOfWeekActivePowerRecord RecordBuilder. * @return A new HourOfWeekActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder(); } /** @@ -337,11 +337,11 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param other The existing builder to copy. * @return A new HourOfWeekActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder(other); } } @@ -350,11 +350,11 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param other The existing instance to copy. * @return A new HourOfWeekActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder(other); } } @@ -385,7 +385,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -433,7 +433,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Creates a Builder by copying an existing HourOfWeekActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -491,7 +491,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -511,7 +511,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'identifier' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -531,7 +531,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'dayOfWeek'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setDayOfWeek(int value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setDayOfWeek(int value) { validate(fields()[1], value); this.dayOfWeek = value; fieldSetFlags()[1] = true; @@ -551,7 +551,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'dayOfWeek' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearDayOfWeek() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearDayOfWeek() { fieldSetFlags()[1] = false; return this; } @@ -570,7 +570,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'hourOfDay'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setHourOfDay(int value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setHourOfDay(int value) { validate(fields()[2], value); this.hourOfDay = value; fieldSetFlags()[2] = true; @@ -590,7 +590,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'hourOfDay' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearHourOfDay() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearHourOfDay() { fieldSetFlags()[2] = false; return this; } @@ -609,7 +609,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'periodStart'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setPeriodStart(long value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setPeriodStart(long value) { validate(fields()[3], value); this.periodStart = value; fieldSetFlags()[3] = true; @@ -629,7 +629,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'periodStart' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearPeriodStart() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearPeriodStart() { fieldSetFlags()[3] = false; return this; } @@ -648,7 +648,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'periodEnd'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setPeriodEnd(long value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setPeriodEnd(long value) { validate(fields()[4], value); this.periodEnd = value; fieldSetFlags()[4] = true; @@ -668,7 +668,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'periodEnd' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearPeriodEnd() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearPeriodEnd() { fieldSetFlags()[4] = false; return this; } @@ -687,7 +687,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'count'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setCount(long value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setCount(long value) { validate(fields()[5], value); this.count = value; fieldSetFlags()[5] = true; @@ -707,7 +707,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'count' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearCount() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearCount() { fieldSetFlags()[5] = false; return this; } @@ -726,7 +726,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'mean'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setMean(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setMean(double value) { validate(fields()[6], value); this.mean = value; fieldSetFlags()[6] = true; @@ -746,7 +746,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'mean' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearMean() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearMean() { fieldSetFlags()[6] = false; return this; } @@ -765,7 +765,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'populationVariance'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setPopulationVariance(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setPopulationVariance(double value) { validate(fields()[7], value); this.populationVariance = value; fieldSetFlags()[7] = true; @@ -785,7 +785,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'populationVariance' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearPopulationVariance() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearPopulationVariance() { fieldSetFlags()[7] = false; return this; } @@ -804,7 +804,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'min'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setMin(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setMin(double value) { validate(fields()[8], value); this.min = value; fieldSetFlags()[8] = true; @@ -824,7 +824,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'min' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearMin() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearMin() { fieldSetFlags()[8] = false; return this; } @@ -843,7 +843,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * @param value The value of 'max'. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder setMax(double value) { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder setMax(double value) { validate(fields()[9], value); this.max = value; fieldSetFlags()[9] = true; @@ -863,7 +863,7 @@ public class HourOfWeekActivePowerRecord extends org.apache.avro.specific.Specif * Clears the value of the 'max' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.HourOfWeekActivePowerRecord.Builder clearMax() { + public rocks.theodolite.benchmarks.commons.model.records.HourOfWeekActivePowerRecord.Builder clearMax() { fieldSetFlags()[9] = false; return this; } diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/MonthOfYearActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/MonthOfYearActivePowerRecord.java similarity index 86% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/MonthOfYearActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/MonthOfYearActivePowerRecord.java index a76f31c0d..4c1cd52fe 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/MonthOfYearActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/MonthOfYearActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = -7083099557783425969L; + private static final long serialVersionUID = -6007754522109150657L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"MonthOfYearActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"monthOfYear\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"MonthOfYearActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"monthOfYear\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -306,8 +306,8 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Creates a new MonthOfYearActivePowerRecord RecordBuilder. * @return A new MonthOfYearActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder(); } /** @@ -315,11 +315,11 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param other The existing builder to copy. * @return A new MonthOfYearActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder(other); } } @@ -328,11 +328,11 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param other The existing instance to copy. * @return A new MonthOfYearActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder(other); } } @@ -362,7 +362,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -406,7 +406,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Creates a Builder by copying an existing MonthOfYearActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -460,7 +460,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -480,7 +480,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'identifier' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -500,7 +500,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'monthOfYear'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setMonthOfYear(int value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setMonthOfYear(int value) { validate(fields()[1], value); this.monthOfYear = value; fieldSetFlags()[1] = true; @@ -520,7 +520,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'monthOfYear' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMonthOfYear() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMonthOfYear() { fieldSetFlags()[1] = false; return this; } @@ -539,7 +539,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'periodStart'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setPeriodStart(long value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setPeriodStart(long value) { validate(fields()[2], value); this.periodStart = value; fieldSetFlags()[2] = true; @@ -559,7 +559,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'periodStart' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearPeriodStart() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearPeriodStart() { fieldSetFlags()[2] = false; return this; } @@ -578,7 +578,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'periodEnd'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setPeriodEnd(long value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setPeriodEnd(long value) { validate(fields()[3], value); this.periodEnd = value; fieldSetFlags()[3] = true; @@ -598,7 +598,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'periodEnd' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearPeriodEnd() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearPeriodEnd() { fieldSetFlags()[3] = false; return this; } @@ -617,7 +617,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'count'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setCount(long value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setCount(long value) { validate(fields()[4], value); this.count = value; fieldSetFlags()[4] = true; @@ -637,7 +637,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'count' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearCount() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearCount() { fieldSetFlags()[4] = false; return this; } @@ -656,7 +656,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'mean'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setMean(double value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setMean(double value) { validate(fields()[5], value); this.mean = value; fieldSetFlags()[5] = true; @@ -676,7 +676,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'mean' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMean() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMean() { fieldSetFlags()[5] = false; return this; } @@ -695,7 +695,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'populationVariance'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setPopulationVariance(double value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setPopulationVariance(double value) { validate(fields()[6], value); this.populationVariance = value; fieldSetFlags()[6] = true; @@ -715,7 +715,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'populationVariance' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearPopulationVariance() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearPopulationVariance() { fieldSetFlags()[6] = false; return this; } @@ -734,7 +734,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'min'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setMin(double value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setMin(double value) { validate(fields()[7], value); this.min = value; fieldSetFlags()[7] = true; @@ -754,7 +754,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'min' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMin() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMin() { fieldSetFlags()[7] = false; return this; } @@ -773,7 +773,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * @param value The value of 'max'. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder setMax(double value) { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder setMax(double value) { validate(fields()[8], value); this.max = value; fieldSetFlags()[8] = true; @@ -793,7 +793,7 @@ public class MonthOfYearActivePowerRecord extends org.apache.avro.specific.Speci * Clears the value of the 'max' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMax() { + public rocks.theodolite.benchmarks.commons.model.records.MonthOfYearActivePowerRecord.Builder clearMax() { fieldSetFlags()[8] = false; return this; } diff --git a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/YearActivePowerRecord.java b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/YearActivePowerRecord.java similarity index 86% rename from theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/YearActivePowerRecord.java rename to theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/YearActivePowerRecord.java index 448d1ba5a..0471c8255 100644 --- a/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/commons/model/records/YearActivePowerRecord.java +++ b/theodolite-benchmarks/commons/src-gen/main/java/rocks/theodolite/benchmarks/commons/model/records/YearActivePowerRecord.java @@ -3,7 +3,7 @@ * * DO NOT EDIT DIRECTLY */ -package rocks.theodolite.commons.model.records; +package rocks.theodolite.benchmarks.commons.model.records; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; @@ -14,10 +14,10 @@ import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class YearActivePowerRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { - private static final long serialVersionUID = -7591848668729692169L; + private static final long serialVersionUID = 1269303032337461873L; - public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"YearActivePowerRecord\",\"namespace\":\"rocks.theodolite.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"year\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); + public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"YearActivePowerRecord\",\"namespace\":\"rocks.theodolite.benchmarks.commons.model.records\",\"fields\":[{\"name\":\"identifier\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"year\",\"type\":\"int\"},{\"name\":\"periodStart\",\"type\":\"long\"},{\"name\":\"periodEnd\",\"type\":\"long\"},{\"name\":\"count\",\"type\":\"long\"},{\"name\":\"mean\",\"type\":\"double\"},{\"name\":\"populationVariance\",\"type\":\"double\"},{\"name\":\"min\",\"type\":\"double\"},{\"name\":\"max\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); @@ -306,8 +306,8 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Creates a new YearActivePowerRecord RecordBuilder. * @return A new YearActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder newBuilder() { - return new rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder(); + public static rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder newBuilder() { + return new rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder(); } /** @@ -315,11 +315,11 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param other The existing builder to copy. * @return A new YearActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder other) { + public static rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder other) { if (other == null) { - return new rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder(other); } } @@ -328,11 +328,11 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param other The existing instance to copy. * @return A new YearActivePowerRecord RecordBuilder */ - public static rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder newBuilder(rocks.theodolite.commons.model.records.YearActivePowerRecord other) { + public static rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder newBuilder(rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord other) { if (other == null) { - return new rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder(); + return new rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder(); } else { - return new rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder(other); + return new rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder(other); } } @@ -362,7 +362,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ - private Builder(rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -406,7 +406,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Creates a Builder by copying an existing YearActivePowerRecord instance * @param other The existing instance to copy. */ - private Builder(rocks.theodolite.commons.model.records.YearActivePowerRecord other) { + private Builder(rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.identifier)) { this.identifier = data().deepCopy(fields()[0].schema(), other.identifier); @@ -460,7 +460,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'identifier'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setIdentifier(java.lang.String value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setIdentifier(java.lang.String value) { validate(fields()[0], value); this.identifier = value; fieldSetFlags()[0] = true; @@ -480,7 +480,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'identifier' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearIdentifier() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearIdentifier() { identifier = null; fieldSetFlags()[0] = false; return this; @@ -500,7 +500,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'year'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setYear(int value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setYear(int value) { validate(fields()[1], value); this.year = value; fieldSetFlags()[1] = true; @@ -520,7 +520,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'year' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearYear() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearYear() { fieldSetFlags()[1] = false; return this; } @@ -539,7 +539,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'periodStart'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setPeriodStart(long value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setPeriodStart(long value) { validate(fields()[2], value); this.periodStart = value; fieldSetFlags()[2] = true; @@ -559,7 +559,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'periodStart' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearPeriodStart() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearPeriodStart() { fieldSetFlags()[2] = false; return this; } @@ -578,7 +578,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'periodEnd'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setPeriodEnd(long value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setPeriodEnd(long value) { validate(fields()[3], value); this.periodEnd = value; fieldSetFlags()[3] = true; @@ -598,7 +598,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'periodEnd' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearPeriodEnd() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearPeriodEnd() { fieldSetFlags()[3] = false; return this; } @@ -617,7 +617,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'count'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setCount(long value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setCount(long value) { validate(fields()[4], value); this.count = value; fieldSetFlags()[4] = true; @@ -637,7 +637,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'count' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearCount() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearCount() { fieldSetFlags()[4] = false; return this; } @@ -656,7 +656,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'mean'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setMean(double value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setMean(double value) { validate(fields()[5], value); this.mean = value; fieldSetFlags()[5] = true; @@ -676,7 +676,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'mean' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearMean() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearMean() { fieldSetFlags()[5] = false; return this; } @@ -695,7 +695,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'populationVariance'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setPopulationVariance(double value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setPopulationVariance(double value) { validate(fields()[6], value); this.populationVariance = value; fieldSetFlags()[6] = true; @@ -715,7 +715,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'populationVariance' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearPopulationVariance() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearPopulationVariance() { fieldSetFlags()[6] = false; return this; } @@ -734,7 +734,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'min'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setMin(double value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setMin(double value) { validate(fields()[7], value); this.min = value; fieldSetFlags()[7] = true; @@ -754,7 +754,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'min' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearMin() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearMin() { fieldSetFlags()[7] = false; return this; } @@ -773,7 +773,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * @param value The value of 'max'. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder setMax(double value) { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder setMax(double value) { validate(fields()[8], value); this.max = value; fieldSetFlags()[8] = true; @@ -793,7 +793,7 @@ public class YearActivePowerRecord extends org.apache.avro.specific.SpecificReco * Clears the value of the 'max' field. * @return This builder. */ - public rocks.theodolite.commons.model.records.YearActivePowerRecord.Builder clearMax() { + public rocks.theodolite.benchmarks.commons.model.records.YearActivePowerRecord.Builder clearMax() { fieldSetFlags()[8] = false; return this; } diff --git a/theodolite-benchmarks/commons/src/main/avro/ActivePower.avdl b/theodolite-benchmarks/commons/src/main/avro/ActivePower.avdl index 482a98c8c..6ee82d6be 100644 --- a/theodolite-benchmarks/commons/src/main/avro/ActivePower.avdl +++ b/theodolite-benchmarks/commons/src/main/avro/ActivePower.avdl @@ -1,4 +1,4 @@ -@namespace("rocks.theodolite.commons.model.records") +@namespace("rocks.theodolite.benchmarks.commons.model.records") protocol ActivePower { record ActivePowerRecord { diff --git a/theodolite-benchmarks/commons/src/main/avro/AggregatedActivePower.avdl b/theodolite-benchmarks/commons/src/main/avro/AggregatedActivePower.avdl index 23bacac57..571f30f32 100644 --- a/theodolite-benchmarks/commons/src/main/avro/AggregatedActivePower.avdl +++ b/theodolite-benchmarks/commons/src/main/avro/AggregatedActivePower.avdl @@ -1,4 +1,4 @@ -@namespace("rocks.theodolite.commons.model.records") +@namespace("rocks.theodolite.benchmarks.commons.model.records") protocol AggregatedActivePower { record AggregatedActivePowerRecord { diff --git a/theodolite-benchmarks/commons/src/main/avro/StatsActivePower.avdl b/theodolite-benchmarks/commons/src/main/avro/StatsActivePower.avdl index 3facc848e..9f4c63606 100644 --- a/theodolite-benchmarks/commons/src/main/avro/StatsActivePower.avdl +++ b/theodolite-benchmarks/commons/src/main/avro/StatsActivePower.avdl @@ -1,4 +1,4 @@ -@namespace("rocks.theodolite.commons.model.records") +@namespace("rocks.theodolite.benchmarks.commons.model.records") protocol StatsActivePower { record HourOfDayActivePowerRecord { diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java similarity index 93% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java index 6c5c3b6fa..fb29d078d 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/commons/configuration/NameResolvingEnvironmentConfiguration.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.commons.configuration; +package rocks.theodolite.benchmarks.commons.commons.configuration; import java.util.Locale; import org.apache.commons.configuration2.EnvironmentConfiguration; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/commons/configuration/ServiceConfigurations.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/commons/configuration/ServiceConfigurations.java similarity index 98% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/commons/configuration/ServiceConfigurations.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/commons/configuration/ServiceConfigurations.java index 26d5e9f92..6ad070369 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/commons/configuration/ServiceConfigurations.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/commons/configuration/ServiceConfigurations.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.commons.configuration; +package rocks.theodolite.benchmarks.commons.commons.configuration; import com.google.common.io.Resources; import java.nio.file.Files; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/configuration/events/Event.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/configuration/events/Event.java similarity index 61% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/configuration/events/Event.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/configuration/events/Event.java index 916514308..895b3401c 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/configuration/events/Event.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/configuration/events/Event.java @@ -1,6 +1,6 @@ -package rocks.theodolite.commons.configuration.events; +package rocks.theodolite.benchmarks.commons.configuration.events; -import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; /** * Events that could occur when modifying a {@link SensorRegistry}. Currently only a general change diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/configuration/events/EventSerde.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/configuration/events/EventSerde.java similarity index 97% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/configuration/events/EventSerde.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/configuration/events/EventSerde.java index 65c030756..50a3faad6 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/configuration/events/EventSerde.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/configuration/events/EventSerde.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.configuration.events; +package rocks.theodolite.benchmarks.commons.configuration.events; import java.nio.ByteBuffer; import java.util.Map; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java similarity index 95% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java index 1ba798c3a..9f3d5721e 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/avro/SchemaRegistryAvroSerdeFactory.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.avro; +package rocks.theodolite.benchmarks.commons.kafka.avro; import io.confluent.kafka.serializers.AbstractKafkaAvroSerDeConfig; import io.confluent.kafka.streams.serdes.avro.SpecificAvroSerde; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferConstants.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferConstants.java similarity index 84% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferConstants.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferConstants.java index 7c1a43212..b29c05359 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferConstants.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferConstants.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; import java.nio.charset.Charset; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferDeserializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferDeserializer.java similarity index 78% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferDeserializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferDeserializer.java index 03055c4fa..88fba611b 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferDeserializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferDeserializer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; /** * Deserializer to deserialize a {@link ReadBuffer} to an object. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferSerde.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferSerde.java similarity index 81% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferSerde.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferSerde.java index 77c517bdf..e14f03e2b 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferSerde.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferSerde.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; /** * Combine {@link BufferSerializer} and {@link BufferDeserializer} into one type. This allows diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferSerializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferSerializer.java similarity index 78% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferSerializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferSerializer.java index 9ea1cb107..9c7353a64 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/BufferSerializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/BufferSerializer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; /** * Serializer to serialize an object to a {@link WriteBuffer}. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/ReadBuffer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/ReadBuffer.java similarity index 95% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/ReadBuffer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/ReadBuffer.java index ff96d69d7..cf0e7af93 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/ReadBuffer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/ReadBuffer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; import java.nio.ByteBuffer; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleDeserializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleDeserializer.java similarity index 93% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleDeserializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleDeserializer.java index 804c806c9..d3d2b6756 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleDeserializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleDeserializer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; import java.util.Map; import org.apache.kafka.common.serialization.Deserializer; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleSerdes.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleSerdes.java similarity index 91% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleSerdes.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleSerdes.java index 19346e5e7..ae1c0530f 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleSerdes.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleSerdes.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; import org.apache.kafka.common.serialization.Serde; import org.apache.kafka.common.serialization.Serdes; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleSerializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleSerializer.java similarity index 93% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleSerializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleSerializer.java index a6b8f5ce4..4ed3d91f7 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/SimpleSerializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/SimpleSerializer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; import java.util.Map; import org.apache.kafka.common.serialization.Serializer; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/WriteBuffer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/WriteBuffer.java similarity index 96% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/WriteBuffer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/WriteBuffer.java index 25ffe9859..144b125f0 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/kafka/simpleserdes/WriteBuffer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/kafka/simpleserdes/WriteBuffer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.kafka.simpleserdes; +package rocks.theodolite.benchmarks.commons.kafka.simpleserdes; import java.nio.ByteBuffer; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/AbstractSensor.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/AbstractSensor.java similarity index 86% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/AbstractSensor.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/AbstractSensor.java index f495cd574..3dad538bb 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/AbstractSensor.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/AbstractSensor.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.Optional; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/AggregatedSensor.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/AggregatedSensor.java similarity index 93% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/AggregatedSensor.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/AggregatedSensor.java index dc2fe2c72..fa8717ded 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/AggregatedSensor.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/AggregatedSensor.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.ArrayList; import java.util.Collection; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/ImmutableSensorRegistry.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ImmutableSensorRegistry.java similarity index 88% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/ImmutableSensorRegistry.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ImmutableSensorRegistry.java index a9bf03403..7cbd1264f 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/ImmutableSensorRegistry.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ImmutableSensorRegistry.java @@ -1,17 +1,19 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import com.google.common.collect.ImmutableList; import com.google.common.collect.ImmutableList.Builder; import com.google.common.collect.ImmutableMap; import com.google.gson.Gson; import com.google.gson.GsonBuilder; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.AggregatedSensorSerializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.MachineSensorSerializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.SensorRegistryDeserializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.SensorRegistrySerializer; + import java.util.Collection; import java.util.Objects; import java.util.Optional; -import rocks.theodolite.commons.model.sensorregistry.serialization.AggregatedSensorSerializer; -import rocks.theodolite.commons.model.sensorregistry.serialization.MachineSensorSerializer; -import rocks.theodolite.commons.model.sensorregistry.serialization.SensorRegistryDeserializer; -import rocks.theodolite.commons.model.sensorregistry.serialization.SensorRegistrySerializer; /** * Implementation of a {@link SensorRegistry} that is immutable. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MachineSensor.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MachineSensor.java similarity index 86% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MachineSensor.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MachineSensor.java index 158f172e9..cdb4b535b 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MachineSensor.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MachineSensor.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.ArrayList; import java.util.List; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MachineSensorImpl.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MachineSensorImpl.java similarity index 88% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MachineSensorImpl.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MachineSensorImpl.java index 0d30263b6..191664bfd 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MachineSensorImpl.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MachineSensorImpl.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.Objects; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MutableAggregatedSensor.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableAggregatedSensor.java similarity index 94% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MutableAggregatedSensor.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableAggregatedSensor.java index 1eb683b4c..c0b5e42c8 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MutableAggregatedSensor.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableAggregatedSensor.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.ArrayList; import java.util.Collection; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MutableSensorRegistry.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableSensorRegistry.java similarity index 83% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MutableSensorRegistry.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableSensorRegistry.java index 1096ccba9..dd54928f0 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/MutableSensorRegistry.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableSensorRegistry.java @@ -1,16 +1,18 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import com.google.gson.Gson; import com.google.gson.GsonBuilder; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.AggregatedSensorSerializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.MachineSensorSerializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.SensorRegistrySerializer; + import java.util.Collection; import java.util.Collections; import java.util.HashMap; import java.util.Map; import java.util.Objects; import java.util.Optional; -import rocks.theodolite.commons.model.sensorregistry.serialization.AggregatedSensorSerializer; -import rocks.theodolite.commons.model.sensorregistry.serialization.MachineSensorSerializer; -import rocks.theodolite.commons.model.sensorregistry.serialization.SensorRegistrySerializer; /** * A {@link SensorRegistry} to which sensors can be added. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/Sensor.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/Sensor.java similarity index 72% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/Sensor.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/Sensor.java index 8c2614427..b22cc81d3 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/Sensor.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/Sensor.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.Optional; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/SensorRegistry.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/SensorRegistry.java similarity index 92% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/SensorRegistry.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/SensorRegistry.java index df1852879..e079f5c12 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/SensorRegistry.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/SensorRegistry.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.Collection; import java.util.Optional; diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java similarity index 82% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java index 65aa30174..7989a097d 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/AggregatedSensorSerializer.java @@ -1,11 +1,13 @@ -package rocks.theodolite.commons.model.sensorregistry.serialization; +package rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization; import com.google.gson.JsonElement; import com.google.gson.JsonObject; import com.google.gson.JsonSerializationContext; import com.google.gson.JsonSerializer; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; + import java.lang.reflect.Type; -import rocks.theodolite.commons.model.sensorregistry.AggregatedSensor; /** * {@link JsonSerializer} for {@link AggregatedSensor}s. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/MachineSensorSerializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/MachineSensorSerializer.java similarity index 81% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/MachineSensorSerializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/MachineSensorSerializer.java index 8bdba5e3b..3b842dfa7 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/MachineSensorSerializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/MachineSensorSerializer.java @@ -1,11 +1,13 @@ -package rocks.theodolite.commons.model.sensorregistry.serialization; +package rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization; import com.google.gson.JsonElement; import com.google.gson.JsonObject; import com.google.gson.JsonSerializationContext; import com.google.gson.JsonSerializer; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensor; + import java.lang.reflect.Type; -import rocks.theodolite.commons.model.sensorregistry.MachineSensor; /** * {@link JsonSerializer} for {@link MachineSensor}s. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java similarity index 89% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java index df976f560..99f05abd4 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistryDeserializer.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry.serialization; +package rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization; import com.google.gson.JsonArray; import com.google.gson.JsonDeserializationContext; @@ -6,12 +6,14 @@ import com.google.gson.JsonDeserializer; import com.google.gson.JsonElement; import com.google.gson.JsonObject; import com.google.gson.JsonPrimitive; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; + import java.lang.reflect.Type; -import rocks.theodolite.commons.model.sensorregistry.AggregatedSensor; -import rocks.theodolite.commons.model.sensorregistry.ImmutableSensorRegistry; -import rocks.theodolite.commons.model.sensorregistry.MutableAggregatedSensor; -import rocks.theodolite.commons.model.sensorregistry.MutableSensorRegistry; -import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * {@link JsonDeserializer} for {@link AggregatedSensor}s. diff --git a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java similarity index 76% rename from theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java rename to theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java index 9d829b160..4c5658f7c 100644 --- a/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java +++ b/theodolite-benchmarks/commons/src/main/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistrySerializer.java @@ -1,10 +1,12 @@ -package rocks.theodolite.commons.model.sensorregistry.serialization; +package rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization; import com.google.gson.JsonElement; import com.google.gson.JsonSerializationContext; import com.google.gson.JsonSerializer; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; + import java.lang.reflect.Type; -import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; /** * {@link JsonSerializer} for {@link SensorRegistry}s. diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java similarity index 94% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java index b7e31d292..c53112255 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/common/configuration/NameResolvingEnvironmentConfigurationTest.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.common.configuration; +package rocks.theodolite.benchmarks.commons.common.configuration; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertNull; @@ -8,7 +8,7 @@ import org.junit.Rule; import org.junit.Test; import org.junit.contrib.java.lang.system.EnvironmentVariables; -import rocks.theodolite.commons.commons.configuration.NameResolvingEnvironmentConfiguration; +import rocks.theodolite.benchmarks.commons.commons.configuration.NameResolvingEnvironmentConfiguration; public class NameResolvingEnvironmentConfigurationTest { diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/ExampleSensors.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ExampleSensors.java similarity index 72% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/ExampleSensors.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ExampleSensors.java index a0705877f..9c0dff921 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/ExampleSensors.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ExampleSensors.java @@ -1,8 +1,14 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import java.util.List; import java.util.stream.Collectors; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; + public final class ExampleSensors { private static final SensorRegistry REGISTRY; diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/ImmutableSensorRegistryTest.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ImmutableSensorRegistryTest.java similarity index 93% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/ImmutableSensorRegistryTest.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ImmutableSensorRegistryTest.java index 1857d1b19..ed561f621 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/ImmutableSensorRegistryTest.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/ImmutableSensorRegistryTest.java @@ -1,9 +1,13 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import static org.junit.Assert.assertFalse; import static org.junit.Assert.assertTrue; import org.junit.Test; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; + public class ImmutableSensorRegistryTest { @Test diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/MaschineSensorImplExposer.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MaschineSensorImplExposer.java similarity index 57% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/MaschineSensorImplExposer.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MaschineSensorImplExposer.java index e650f40e5..310a87e59 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/MaschineSensorImplExposer.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MaschineSensorImplExposer.java @@ -1,4 +1,7 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensorImpl; /** * Helper class to allow tests in other packages access {@link MachineSensorImpl} class objects. diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/MutableSensorRegistryTest.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableSensorRegistryTest.java similarity index 93% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/MutableSensorRegistryTest.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableSensorRegistryTest.java index dbfe59696..3e4032c1a 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/MutableSensorRegistryTest.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/MutableSensorRegistryTest.java @@ -1,10 +1,14 @@ -package rocks.theodolite.commons.model.sensorregistry; +package rocks.theodolite.benchmarks.commons.model.sensorregistry; import static org.junit.Assert.assertFalse; import static org.junit.Assert.assertTrue; import java.util.Optional; import org.junit.Test; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; + public class MutableSensorRegistryTest { @Test diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java similarity index 93% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java index 52dc7eb96..a9821eb90 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistryDeserializerTest.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry.serialization; +package rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertNull; @@ -16,10 +16,11 @@ import com.google.common.collect.Lists; import com.google.gson.Gson; import com.google.gson.GsonBuilder; -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; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.Sensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.SensorRegistryDeserializer; public class SensorRegistryDeserializerTest { diff --git a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java similarity index 80% rename from theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java rename to theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java index 2662abb7e..c2413b571 100644 --- a/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java +++ b/theodolite-benchmarks/commons/src/test/java/rocks/theodolite/benchmarks/commons/model/sensorregistry/serialization/SensorRegistrySerializerTest.java @@ -1,4 +1,4 @@ -package rocks.theodolite.commons.model.sensorregistry.serialization; +package rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization; import static org.junit.Assert.assertEquals; import com.google.gson.Gson; @@ -6,9 +6,13 @@ import com.google.gson.GsonBuilder; import org.junit.After; import org.junit.Before; import org.junit.Test; -import rocks.theodolite.commons.model.sensorregistry.MaschineSensorImplExposer; -import rocks.theodolite.commons.model.sensorregistry.MutableAggregatedSensor; -import rocks.theodolite.commons.model.sensorregistry.MutableSensorRegistry; + +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MaschineSensorImplExposer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.AggregatedSensorSerializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.MachineSensorSerializer; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.serialization.SensorRegistrySerializer; public class SensorRegistrySerializerTest { 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 25b39b30c..2d49f05ee 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 @@ -3,9 +3,9 @@ package rocks.theodolite.benchmarks.httpbridge; import java.util.List; import java.util.Objects; import java.util.Optional; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.loadgenerator.ConfigurationKeys; import rocks.theodolite.benchmarks.loadgenerator.TitanKafkaSenderFactory; -import rocks.theodolite.commons.model.records.ActivePowerRecord; class EnvVarHttpBridgeFactory { 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 ff3905e82..5d5f3c0c6 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 914d28817..0593e8501 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 rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; +import rocks.theodolite.benchmarks.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 7f0a1289e..02a46952d 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 41a76a62a..c35503334 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 ba4d6d125..41ee632fc 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 cbb390633..74e107116 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 d1d66829e..7ef2ae419 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 fb3bd8055..b32d0cb82 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 @@ -2,8 +2,8 @@ package rocks.theodolite.benchmarks.uc1.beam; import org.apache.beam.sdk.transforms.SimpleFunction; import org.apache.beam.sdk.values.TypeDescriptor; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.RecordConverter; -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 fe33450ea..e42b7dea8 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 @@ -4,8 +4,8 @@ import org.apache.beam.sdk.transforms.MapElements; 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.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; -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 4cdd0cfc6..74271aca0 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 @@ -9,8 +9,8 @@ import org.apache.beam.sdk.transforms.Values; 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.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.beam.firestore.FirestoreOptionsExpander; -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 a45b4bc3e..73b95bb22 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 a1c957041..60eaabfdd 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 @@ -4,9 +4,9 @@ import java.util.stream.Stream; import org.apache.beam.sdk.transforms.PTransform; import org.apache.beam.sdk.values.PCollection; import org.apache.commons.configuration2.Configuration; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.beam.firestore.FirestoreSink; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; -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 b72bedce2..6d23c9296 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 ba6542f4a..100bb6205 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * A {@link PTransform} mapping {@link ActivePowerRecord}s to {@link Document}s, followed by storing diff --git a/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/DatabaseAdapter.java b/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/DatabaseAdapter.java index ca981b40f..99e59a6e6 100644 --- a/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/DatabaseAdapter.java +++ b/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/DatabaseAdapter.java @@ -1,7 +1,7 @@ package rocks.theodolite.benchmarks.uc1.commons; import java.util.Objects; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * A database adapter consisting of a {@link RecordConverter} and a {@link DatabaseWriter}. diff --git a/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/RecordConverter.java b/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/RecordConverter.java index d7979e80d..a728e9d6b 100644 --- a/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/RecordConverter.java +++ b/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/RecordConverter.java @@ -1,6 +1,6 @@ package rocks.theodolite.benchmarks.uc1.commons; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * Converts an {@link ActivePowerRecord} to the type required by a database. diff --git a/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/logger/JsonConverter.java b/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/logger/JsonConverter.java index 11511d4f3..a59f02687 100644 --- a/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/logger/JsonConverter.java +++ b/theodolite-benchmarks/uc1-commons/src/main/java/rocks/theodolite/benchmarks/uc1/commons/logger/JsonConverter.java @@ -2,8 +2,8 @@ package rocks.theodolite.benchmarks.uc1.commons.logger; import com.google.gson.Gson; import java.io.Serializable; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.RecordConverter; -import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * {@link RecordConverter} that converts {@link ActivePowerRecord}s to JSON strings. 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 05bd1432b..8380cdc09 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 @@ -1,8 +1,8 @@ package rocks.theodolite.benchmarks.uc1.flink; import org.apache.flink.api.common.functions.MapFunction; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.RecordConverter; -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 dce779382..83936d748 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 @@ -7,11 +7,11 @@ import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment; import org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; import rocks.theodolite.benchmarks.commons.flink.KafkaConnectorFactory; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; -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/uc1-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc1/hazelcastjet/Uc1PipelineBuilder.java b/theodolite-benchmarks/uc1-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc1/hazelcastjet/Uc1PipelineBuilder.java index c02ea1e7e..865a3e78c 100644 --- a/theodolite-benchmarks/uc1-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc1/hazelcastjet/Uc1PipelineBuilder.java +++ b/theodolite-benchmarks/uc1-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc1/hazelcastjet/Uc1PipelineBuilder.java @@ -1,7 +1,6 @@ package rocks.theodolite.benchmarks.uc1.hazelcastjet; import static com.hazelcast.jet.pipeline.SinkBuilder.sinkBuilder; - import com.hazelcast.jet.kafka.KafkaSources; import com.hazelcast.jet.pipeline.Pipeline; import com.hazelcast.jet.pipeline.Sink; @@ -9,10 +8,11 @@ import com.hazelcast.jet.pipeline.StreamSource; import com.hazelcast.jet.pipeline.StreamStage; import java.util.Map.Entry; import java.util.Properties; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; import rocks.theodolite.benchmarks.uc1.commons.DatabaseWriter; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; -import titan.ccp.model.records.ActivePowerRecord; + /** * Builder to build a HazelcastJet Pipeline for UC1 which can be used for stream processing using @@ -47,8 +47,8 @@ public class Uc1PipelineBuilder { final DatabaseWriter<String> writer = this.databaseAdapter.getDatabaseWriter(); final Sink<String> sink = sinkBuilder( "Sink into database", x -> writer) - .<String>receiveFn(DatabaseWriter::write) - .build(); + .<String>receiveFn(DatabaseWriter::write) + .build(); uc1TopologyProduct.writeTo(sink); diff --git a/theodolite-benchmarks/uc1-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc1/hazelcast/Uc1PipelineTest.java b/theodolite-benchmarks/uc1-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc1/hazelcast/Uc1PipelineTest.java index 525327ddb..8ffde0487 100644 --- a/theodolite-benchmarks/uc1-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc1/hazelcast/Uc1PipelineTest.java +++ b/theodolite-benchmarks/uc1-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc1/hazelcast/Uc1PipelineTest.java @@ -1,5 +1,7 @@ package rocks.theodolite.benchmarks.uc1.hazelcast; +import static com.hazelcast.jet.pipeline.SinkBuilder.sinkBuilder; +import static com.hazelcast.logging.Logger.getLogger; import com.hazelcast.jet.Jet; import com.hazelcast.jet.JetInstance; import com.hazelcast.jet.config.JetConfig; @@ -12,24 +14,21 @@ import com.hazelcast.jet.pipeline.test.AssertionCompletedException; import com.hazelcast.jet.pipeline.test.Assertions; import com.hazelcast.jet.pipeline.test.TestSources; import com.hazelcast.jet.test.SerialTest; +import com.hazelcast.logging.ILogger; import java.util.Map; import java.util.Map.Entry; import java.util.concurrent.CompletionException; -import com.hazelcast.logging.ILogger; import org.junit.After; import org.junit.Assert; import org.junit.Before; import org.junit.Test; import org.junit.experimental.categories.Category; import org.slf4j.Logger; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; import rocks.theodolite.benchmarks.uc1.commons.DatabaseWriter; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; import rocks.theodolite.benchmarks.uc1.hazelcastjet.Uc1PipelineBuilder; -import titan.ccp.model.records.ActivePowerRecord; - -import static com.hazelcast.jet.pipeline.SinkBuilder.sinkBuilder; -import static com.hazelcast.logging.Logger.getLogger; /** * Test methods for the Hazelcast Jet Implementation of UC1. @@ -44,7 +43,7 @@ public class Uc1PipelineTest extends JetTestSupport { // Standart Logger private static final Logger LOGGER = org.slf4j.LoggerFactory.getLogger(Uc1PipelineTest.class); // HazelcastJet Logger - private static final ILogger logger = getLogger(Uc1PipelineTest.class); + private static final ILogger logger = getLogger(Uc1PipelineTest.class); private final DatabaseAdapter<String> databaseAdapter = LogWriterFactory.forJson(); @@ -55,7 +54,7 @@ public class Uc1PipelineTest extends JetTestSupport { @Before public void buildUc1Pipeline() { - this.logger.info("Hazelcast Logger"); + Uc1PipelineTest.logger.info("Hazelcast Logger"); LOGGER.info("Standard Logger"); @@ -67,9 +66,9 @@ public class Uc1PipelineTest extends JetTestSupport { // Create mock jet instance with configuration final String testClusterName = randomName(); final JetConfig testJetConfig = new JetConfig(); -// testJetConfig.setProperty( "hazelcast.logging.type", "slf4j" ); + // testJetConfig.setProperty( "hazelcast.logging.type", "slf4j" ); testJetConfig.getHazelcastConfig().setClusterName(testClusterName); - this.testInstance = createJetMember(testJetConfig); + this.testInstance = this.createJetMember(testJetConfig); // Create a test source @@ -92,17 +91,17 @@ public class Uc1PipelineTest extends JetTestSupport { final DatabaseWriter<String> adapter = this.databaseAdapter.getDatabaseWriter(); final Sink<String> sink = sinkBuilder( "database-sink", x -> adapter) - .<String>receiveFn(DatabaseWriter::write) - .build(); + .<String>receiveFn(DatabaseWriter::write) + .build(); -// Map Stage, can be used instead of sink -// StreamStage<String> log = uc1Topology.map(s -> { -// LOGGER.info(s); -// return s; -// }); -// log.writeTo(sink); + // Map Stage, can be used instead of sink + // StreamStage<String> log = uc1Topology.map(s -> { + // LOGGER.info(s); + // return s; + // }); + // log.writeTo(sink); - //apply sink + // apply sink this.uc1Topology.writeTo(sink); } @@ -121,8 +120,8 @@ public class Uc1PipelineTest extends JetTestSupport { // Assertion this.uc1Topology.apply(Assertions.assertCollectedEventually(assertTimeoutSeconds, collection -> { - //print the newest Record -// LOGGER.info(collection.get(collection.size()-1)); + // print the newest Record + // LOGGER.info(collection.get(collection.size()-1)); // Run pipeline until 5th item Assert.assertTrue("Not enough data arrived in the end", diff --git a/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/HistoryService.java b/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/HistoryService.java index a93e225c3..dd792ac8a 100644 --- a/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/HistoryService.java +++ b/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/HistoryService.java @@ -3,7 +3,7 @@ package rocks.theodolite.benchmarks.uc1.kstreams; import java.util.concurrent.CompletableFuture; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.KafkaStreams; -import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; /** * A microservice that manages the history and, therefore, stores and aggregates incoming diff --git a/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/TopologyBuilder.java b/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/TopologyBuilder.java index 7bf354df9..efbf77406 100644 --- a/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/TopologyBuilder.java +++ b/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/TopologyBuilder.java @@ -5,10 +5,10 @@ import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.streams.StreamsBuilder; import org.apache.kafka.streams.Topology; import org.apache.kafka.streams.kstream.Consumed; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc1.commons.DatabaseAdapter; import rocks.theodolite.benchmarks.uc1.commons.logger.LogWriterFactory; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; -import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Builds Kafka Stream Topology for the History microservice. diff --git a/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/Uc1KafkaStreamsBuilder.java b/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/Uc1KafkaStreamsBuilder.java index 5370de258..05d6a5845 100644 --- a/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/Uc1KafkaStreamsBuilder.java +++ b/theodolite-benchmarks/uc1-kstreams/src/main/java/rocks/theodolite/benchmarks/uc1/kstreams/Uc1KafkaStreamsBuilder.java @@ -4,8 +4,8 @@ import java.util.Objects; import java.util.Properties; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.Topology; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; import rocks.theodolite.benchmarks.commons.kstreams.KafkaStreamsBuilder; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; /** * Builder for the Kafka Streams configuration. 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 868ebfa79..decbcae1c 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 aeb614fd0..cf320bf18 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 ace81d5e3..30d608153 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 @@ -13,11 +13,11 @@ import org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer; import org.apache.kafka.common.serialization.Serdes; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; import rocks.theodolite.benchmarks.commons.flink.KafkaConnectorFactory; import rocks.theodolite.benchmarks.commons.flink.StateBackends; import rocks.theodolite.benchmarks.commons.flink.serialization.StatsSerializer; -import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 a43d9b4ef..ca5c9b2ae 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 @@ -3,8 +3,8 @@ package rocks.theodolite.benchmarks.uc2.flink; import com.google.common.math.Stats; import com.google.common.math.StatsAccumulator; import org.apache.flink.api.common.functions.AggregateFunction; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc2.flink.util.StatsFactory; -import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Statistical aggregation of {@link ActivePowerRecord}s using {@link Stats}. diff --git a/theodolite-benchmarks/uc2-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineBuilder.java b/theodolite-benchmarks/uc2-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineBuilder.java index 73377de61..dbbcae0a5 100644 --- a/theodolite-benchmarks/uc2-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineBuilder.java +++ b/theodolite-benchmarks/uc2-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineBuilder.java @@ -14,8 +14,10 @@ import com.hazelcast.jet.pipeline.WindowDefinition; import java.util.Map; import java.util.Map.Entry; import java.util.Properties; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc2.hazelcastjet.uc2specifics.StatsAccumulatorSupplier; -import titan.ccp.model.records.ActivePowerRecord; + + /** * Builder to build a HazelcastJet Pipeline for UC2 which can be used for stream processing using @@ -108,8 +110,7 @@ public class Uc2PipelineBuilder { * @return An AggregateOperation used by Hazelcast Jet in a streaming stage which aggregates * ActivePowerRecord Objects into Stats Objects. */ - public AggregateOperation1<Entry<String, ActivePowerRecord>, - StatsAccumulator, Stats> uc2AggregateOperation() { + public AggregateOperation1<Entry<String, ActivePowerRecord>, StatsAccumulator, Stats> uc2AggregateOperation() { // Aggregate Operation to Create a Stats Object from Entry<String,ActivePowerRecord> items using // the Statsaccumulator. return AggregateOperation @@ -129,7 +130,7 @@ public class Uc2PipelineBuilder { .andExportFinish( (accumulator) -> { return accumulator.snapshot(); - }); + }); } } diff --git a/theodolite-benchmarks/uc2-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineTest.java b/theodolite-benchmarks/uc2-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineTest.java index ff72b9558..0a579c8d4 100644 --- a/theodolite-benchmarks/uc2-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineTest.java +++ b/theodolite-benchmarks/uc2-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc2/hazelcastjet/Uc2PipelineTest.java @@ -19,7 +19,7 @@ import org.junit.Assert; import org.junit.Before; import org.junit.Test; import org.junit.experimental.categories.Category; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * Test methods for the Hazelcast Jet Implementation of UC2. @@ -39,10 +39,10 @@ public class Uc2PipelineTest extends JetTestSupport { public void buildUc2Pipeline() { // Setup Configuration - int testItemsPerSecond = 1; - String testSensorName = "TEST-SENSOR"; - Double testValueInW = 10.0; - int testWindowInMs = 5000; + final int testItemsPerSecond = 1; + final String testSensorName = "TEST-SENSOR"; + final Double testValueInW = 10.0; + final int testWindowInMs = 5000; // Create mock jet instance with configuration final String testClusterName = randomName(); @@ -61,7 +61,7 @@ public class Uc2PipelineTest extends JetTestSupport { }); // Create pipeline to test - Uc2PipelineBuilder pipelineBuilder = new Uc2PipelineBuilder(); + final Uc2PipelineBuilder pipelineBuilder = new Uc2PipelineBuilder(); this.testPipeline = Pipeline.create(); this.uc2Topology = pipelineBuilder.extendUc2Topology(this.testPipeline, testSource, testWindowInMs); @@ -75,14 +75,15 @@ public class Uc2PipelineTest extends JetTestSupport { public void testOutput() { // Assertion Configuration - int timeout = 14; - String expectedOutput = "Stats{count=5, mean=10.0, populationStandardDeviation=0.0, min=10.0, max=10.0}"; + final int timeout = 14; + final String expectedOutput = + "Stats{count=5, mean=10.0, populationStandardDeviation=0.0, min=10.0, max=10.0}"; // Assertion this.uc2Topology.apply(Assertions.assertCollectedEventually(timeout, collection -> Assert.assertTrue( "Not the right amount items in Stats Object!", - collection.get(collection.size()-1).getValue().equals(expectedOutput)))); + collection.get(collection.size() - 1).getValue().equals(expectedOutput)))); // Run the test! try { diff --git a/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/HistoryService.java b/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/HistoryService.java index 4121c11a7..4afc2d91e 100644 --- a/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/HistoryService.java +++ b/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/HistoryService.java @@ -5,8 +5,8 @@ import java.util.Objects; import java.util.concurrent.CompletableFuture; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.KafkaStreams; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; import rocks.theodolite.benchmarks.commons.kstreams.ConfigurationKeys; -import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; /** * A microservice that manages the history and, therefore, stores and aggregates incoming diff --git a/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/TopologyBuilder.java b/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/TopologyBuilder.java index 9bff13595..cd1d8cd92 100644 --- a/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/TopologyBuilder.java +++ b/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/TopologyBuilder.java @@ -13,10 +13,10 @@ import org.apache.kafka.streams.kstream.Produced; import org.apache.kafka.streams.kstream.TimeWindows; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; import rocks.theodolite.benchmarks.commons.kstreams.GenericSerde; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc2.kstreams.util.StatsFactory; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; -import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Builds Kafka Stream Topology for the History microservice. diff --git a/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/Uc2KafkaStreamsBuilder.java b/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/Uc2KafkaStreamsBuilder.java index e76ef3e26..d9d4a23ec 100644 --- a/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/Uc2KafkaStreamsBuilder.java +++ b/theodolite-benchmarks/uc2-kstreams/src/main/java/rocks/theodolite/benchmarks/uc2/kstreams/Uc2KafkaStreamsBuilder.java @@ -5,8 +5,8 @@ import java.util.Objects; import java.util.Properties; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.Topology; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; import rocks.theodolite.benchmarks.commons.kstreams.KafkaStreamsBuilder; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; /** * Builder for the Kafka Streams configuration. 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 8632572f0..8bc32ccc2 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 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; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.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 f183878a0..0cad03814 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 c8b0220bf..f6587be4c 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 1e2130846..4fca536ba 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 f630b4428..4554d505c 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 @@ -17,15 +17,15 @@ import org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer; import org.apache.kafka.common.serialization.Serdes; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; import rocks.theodolite.benchmarks.commons.flink.KafkaConnectorFactory; import rocks.theodolite.benchmarks.commons.flink.StateBackends; import rocks.theodolite.benchmarks.commons.flink.serialization.StatsSerializer; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; 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 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 f58bda804..83951a422 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 @@ -3,8 +3,8 @@ package rocks.theodolite.benchmarks.uc3.flink; import com.google.common.math.Stats; import com.google.common.math.StatsAccumulator; import org.apache.flink.api.common.functions.AggregateFunction; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc3.flink.util.StatsFactory; -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 f9756bdaa..5b08fcad2 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 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; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.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 69aaa25f0..420179a08 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 rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord; /** * {@link StatsRecordFactory} to create an {@link HourOfDayActivePowerRecord}. diff --git a/theodolite-benchmarks/uc3-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineBuilder.java b/theodolite-benchmarks/uc3-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineBuilder.java index c8427de60..e651d44fd 100644 --- a/theodolite-benchmarks/uc3-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineBuilder.java +++ b/theodolite-benchmarks/uc3-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineBuilder.java @@ -15,10 +15,10 @@ import java.util.Map.Entry; import java.util.Properties; import java.util.TimeZone; import java.util.concurrent.TimeUnit; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc3.hazelcastjet.uc3specifics.HourOfDayKey; import rocks.theodolite.benchmarks.uc3.hazelcastjet.uc3specifics.HoursOfDayKeyFactory; import rocks.theodolite.benchmarks.uc3.hazelcastjet.uc3specifics.StatsKeyFactory; -import titan.ccp.model.records.ActivePowerRecord; /** * Builder to build a HazelcastJet Pipeline for UC3 which can be used for stream processing using diff --git a/theodolite-benchmarks/uc3-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineTest.java b/theodolite-benchmarks/uc3-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineTest.java index 3df4f4642..969ff27d1 100644 --- a/theodolite-benchmarks/uc3-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineTest.java +++ b/theodolite-benchmarks/uc3-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc3/hazelcastjet/Uc3PipelineTest.java @@ -14,20 +14,18 @@ import com.hazelcast.jet.pipeline.test.TestSources; import com.hazelcast.jet.test.SerialTest; import java.time.Instant; import java.time.LocalDateTime; -import java.util.ArrayList; import java.util.Map; -import java.util.TimeZone; import java.util.Map.Entry; +import java.util.TimeZone; import java.util.concurrent.CompletionException; import org.junit.After; import org.junit.Assert; import org.junit.Before; import org.junit.Test; import org.junit.experimental.categories.Category; -import rocks.theodolite.benchmarks.uc3.hazelcastjet.Uc3PipelineBuilder; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc3.hazelcastjet.uc3specifics.HourOfDayKey; import rocks.theodolite.benchmarks.uc3.hazelcastjet.uc3specifics.HourOfDayKeySerializer; -import titan.ccp.model.records.ActivePowerRecord; /** * Test methods for the Hazelcast Jet Implementation of UC3. @@ -49,13 +47,13 @@ public class Uc3PipelineTest extends JetTestSupport { public void buildUc3Pipeline() { // Setup Configuration - int testItemsPerSecond = 1; - String testSensorName = "TEST-SENSOR"; - Double testValueInW = 10.0; - int testHopSizeInSec = 1; - int testWindowSizeInSec = 50; + final int testItemsPerSecond = 1; + final String testSensorName = "TEST-SENSOR"; + final Double testValueInW = 10.0; + final int testHopSizeInSec = 1; + final int testWindowSizeInSec = 50; // Used to check hourOfDay - long mockTimestamp = 1632741651; + final long mockTimestamp = 1632741651; // Create mock jet instance with configuration @@ -75,9 +73,9 @@ public class Uc3PipelineTest extends JetTestSupport { }); // Create pipeline to test - Uc3PipelineBuilder pipelineBuilder = new Uc3PipelineBuilder(); + final Uc3PipelineBuilder pipelineBuilder = new Uc3PipelineBuilder(); this.testPipeline = Pipeline.create(); - this.uc3Topology = pipelineBuilder.extendUc3Topology(testPipeline, testSource, + this.uc3Topology = pipelineBuilder.extendUc3Topology(this.testPipeline, testSource, testHopSizeInSec, testWindowSizeInSec); } @@ -88,11 +86,11 @@ public class Uc3PipelineTest extends JetTestSupport { public void testOutput() { // Assertion Configuration - int timeout = 10; - String testSensorName = "TEST-SENSOR"; - Double testValueInW = 10.0; + final int timeout = 10; + final String testSensorName = "TEST-SENSOR"; + final Double testValueInW = 10.0; // Used to check hourOfDay - long mockTimestamp = 1632741651; + final long mockTimestamp = 1632741651; // Assertion this.uc3Topology.apply(Assertions.assertCollectedEventually(timeout, @@ -105,17 +103,15 @@ public class Uc3PipelineTest extends JetTestSupport { boolean allOkay = true; if (collection != null) { System.out.println("DEBUG: CHECK 2 || Collection Size: " + collection.size()); - for (int i = 0; i < collection.size(); i++) { + for (final Entry<String, String> currentEntry : collection) { // Build hour of day - long timestamp = mockTimestamp; - int expectedHour = LocalDateTime.ofInstant(Instant.ofEpochMilli(timestamp), + final long timestamp = mockTimestamp; + final int expectedHour = LocalDateTime.ofInstant(Instant.ofEpochMilli(timestamp), TimeZone.getDefault().toZoneId()).getHour(); - // Compare expected output with generated output - Entry<String, String> currentEntry = collection.get(i); - String expectedKey = testSensorName + ";" + expectedHour; - String expectedValue = testValueInW.toString(); + final String expectedKey = testSensorName + ";" + expectedHour; + final String expectedValue = testValueInW.toString(); // DEBUG System.out.println( diff --git a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HistoryService.java b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HistoryService.java index be42b0a22..8776fcda3 100644 --- a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HistoryService.java +++ b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HistoryService.java @@ -4,8 +4,8 @@ import java.time.Duration; import java.util.concurrent.CompletableFuture; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.KafkaStreams; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; import rocks.theodolite.benchmarks.commons.kstreams.ConfigurationKeys; -import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; /** * A microservice that manages the history and, therefore, stores and aggregates incoming diff --git a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayKeySerde.java b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayKeySerde.java index d8319a452..e2a3b03e1 100644 --- a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayKeySerde.java +++ b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayKeySerde.java @@ -1,10 +1,10 @@ package rocks.theodolite.benchmarks.uc3.kstreams; import org.apache.kafka.common.serialization.Serde; -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; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.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-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayRecordFactory.java b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayRecordFactory.java index 6ceaf55c4..4d2e2d5b5 100644 --- a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayRecordFactory.java +++ b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/HourOfDayRecordFactory.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc3.kstreams; import com.google.common.math.Stats; import org.apache.kafka.streams.kstream.Windowed; -import rocks.theodolite.commons.model.records.HourOfDayActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.HourOfDayActivePowerRecord; /** * {@link StatsRecordFactory} to create an {@link HourOfDayActivePowerRecord}. diff --git a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/TopologyBuilder.java b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/TopologyBuilder.java index 99e6ecf72..f2825ca81 100644 --- a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/TopologyBuilder.java +++ b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/TopologyBuilder.java @@ -16,10 +16,10 @@ import org.apache.kafka.streams.kstream.Grouped; import org.apache.kafka.streams.kstream.Materialized; import org.apache.kafka.streams.kstream.Produced; import org.apache.kafka.streams.kstream.TimeWindows; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; import rocks.theodolite.benchmarks.commons.kstreams.GenericSerde; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc3.kstreams.util.StatsFactory; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; -import rocks.theodolite.commons.model.records.ActivePowerRecord; /** * Builds Kafka Stream Topology for the History microservice. diff --git a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/Uc3KafkaStreamsBuilder.java b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/Uc3KafkaStreamsBuilder.java index 015bafd6c..e05b30f75 100644 --- a/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/Uc3KafkaStreamsBuilder.java +++ b/theodolite-benchmarks/uc3-kstreams/src/main/java/rocks/theodolite/benchmarks/uc3/kstreams/Uc3KafkaStreamsBuilder.java @@ -5,8 +5,8 @@ import java.util.Objects; import java.util.Properties; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.Topology; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; import rocks.theodolite.benchmarks.commons.kstreams.KafkaStreamsBuilder; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; /** * Builder for the Kafka Streams configuration. 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 d55c3c78b..1a2f99cd8 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 rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.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 cf34ce816..4d1c2241e 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 rocks.theodolite.commons.model.records.ActivePowerRecord; -import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 bc3fbdc02..1c4071f4a 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 1325f9f45..59818e18b 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 rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.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 858262bf4..903204363 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 226f0fdb7..a020d3273 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 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; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.Sensor; +import rocks.theodolite.benchmarks.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 69ab5c5bd..955f71015 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 @@ -40,15 +40,15 @@ import rocks.theodolite.benchmarks.commons.beam.ConfigurationKeys; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaActivePowerTimestampReader; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaGenericReader; import rocks.theodolite.benchmarks.commons.beam.kafka.KafkaWriterTransformation; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; import rocks.theodolite.benchmarks.uc4.beam.serialization.AggregatedActivePowerRecordCoder; import rocks.theodolite.benchmarks.uc4.beam.serialization.AggregatedActivePowerRecordDeserializer; import rocks.theodolite.benchmarks.uc4.beam.serialization.AggregatedActivePowerRecordSerializer; 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 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 2e36901cf..e853e0b6e 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 rocks.theodolite.commons.model.records.ActivePowerRecord; -import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 2fb648e05..a616a9667 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 rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.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 ea90ae32d..8477e987c 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 rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.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 d44e47407..759b8baab 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 rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.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 2f345328a..1083103f7 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 rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.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 5dff392cd..2c742ca65 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 rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.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 a8d7b37d9..2d555ef12 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 rocks.theodolite.commons.configuration.events.Event; -import rocks.theodolite.commons.configuration.events.EventSerde; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.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 b57177d2e..9399a4260 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 rocks.theodolite.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.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 b5c197c9b..9c8d1eff6 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 @@ -1,11 +1,11 @@ package rocks.theodolite.benchmarks.uc4.beam.serialization; import org.apache.kafka.common.serialization.Serde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.WriteBuffer; import rocks.theodolite.benchmarks.uc4.beam.SensorParentKey; -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 76ac8b3a0..fd6d073bb 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 @@ -19,21 +19,21 @@ import org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer; import org.apache.kafka.common.serialization.Serdes; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.configuration.events.EventSerde; import rocks.theodolite.benchmarks.commons.flink.KafkaConnectorFactory; import rocks.theodolite.benchmarks.commons.flink.StateBackends; import rocks.theodolite.benchmarks.commons.flink.TupleType; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; import rocks.theodolite.benchmarks.uc4.flink.util.ImmutableSensorRegistrySerializer; 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 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 d1ef7258a..77391393d 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 rocks.theodolite.commons.model.sensorregistry.AggregatedSensor; -import rocks.theodolite.commons.model.sensorregistry.Sensor; -import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.Sensor; +import rocks.theodolite.benchmarks.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 f5edbd8a3..0171e4b0b 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 @@ -9,8 +9,8 @@ import org.apache.flink.api.java.tuple.Tuple2; 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.commons.model.records.ActivePowerRecord; import rocks.theodolite.benchmarks.uc4.flink.util.SensorParentKey; -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 7c42d8f54..6dff6edaf 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 @@ -11,9 +11,9 @@ import org.apache.flink.configuration.Configuration; 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.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; import rocks.theodolite.benchmarks.uc4.flink.util.SensorParentKey; -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 e235e9185..c491adc47 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 rocks.theodolite.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; /** * A {@link Serializer} for {@link ImmutableSensorRegistry}s. diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4HazelcastJetFactory.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4HazelcastJetFactory.java index 9b6aa7126..693f36bb2 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4HazelcastJetFactory.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4HazelcastJetFactory.java @@ -13,13 +13,13 @@ import org.slf4j.Logger; import rocks.theodolite.benchmarks.commons.hazelcastjet.ConfigurationKeys; import rocks.theodolite.benchmarks.commons.hazelcastjet.JetInstanceBuilder; import rocks.theodolite.benchmarks.commons.hazelcastjet.KafkaPropertiesBuilder; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.EventDeserializer; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ImmutableSensorRegistryUc4Serializer; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.SensorGroupKey; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.SensorGroupKeySerializer; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ValueGroup; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ValueGroupSerializer; -import titan.ccp.model.sensorregistry.ImmutableSensorRegistry; /** * A Hazelcast Jet factory which can build a Hazelcast Jet Instance and Pipeline for the UC4 @@ -197,9 +197,9 @@ public class Uc4HazelcastJetFactory { * @return The Uc4HazelcastJetBuilder factory with set kafkaReadPropertiesForPipeline. */ public Uc4HazelcastJetFactory setReadPropertiesFromEnv(// NOPMD - final String bootstrapServersDefault, - final String schemaRegistryUrlDefault, - final String jobName) { + final String bootstrapServersDefault, + final String schemaRegistryUrlDefault, + final String jobName) { // Use KafkaPropertiesBuilder to build a properties object used for kafka final KafkaPropertiesBuilder propsBuilder = new KafkaPropertiesBuilder(); diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineBuilder.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineBuilder.java index 2efb8250c..a3dd654b4 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineBuilder.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineBuilder.java @@ -25,14 +25,14 @@ import java.util.Properties; import java.util.Set; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.AggregatedActivePowerRecordAccumulator; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ChildParentsTransformer; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.SensorGroupKey; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ValueGroup; -import titan.ccp.configuration.events.Event; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; -import titan.ccp.model.sensorregistry.SensorRegistry; /** * Builder to build a HazelcastJet Pipeline for UC4 which can be used for stream processing using @@ -117,9 +117,9 @@ public class Uc4PipelineBuilder { * * <p> * UC4 takes {@code ActivePowerRecord} events from sensors and a {@code SensorRegistry} with maps - * from keys to groups to map values to their according groups. A feedback stream allows for - * group keys to be mapped to values and eventually to be mapped to other top level groups defines - * by the {@code SensorRegistry}. + * from keys to groups to map values to their according groups. A feedback stream allows for group + * keys to be mapped to values and eventually to be mapped to other top level groups defines by + * the {@code SensorRegistry}. * </p> * * <p> @@ -180,10 +180,10 @@ public class Uc4PipelineBuilder { ////////////////////////////////// // (2) UC4 Merge Input with aggregation stream - final StreamStageWithKey<Entry<String, ActivePowerRecord>, String> - mergedInputAndAggregations = inputStream - .merge(aggregations) - .groupingKey(Entry::getKey); + final StreamStageWithKey<Entry<String, ActivePowerRecord>, String> mergedInputAndAggregations = + inputStream + .merge(aggregations) + .groupingKey(Entry::getKey); ////////////////////////////////// // (3) UC4 Join Configuration and Merges Input/Aggregation Stream @@ -235,28 +235,25 @@ public class Uc4PipelineBuilder { ////////////////////////////////// // (5) UC4 Last Value Map // Table with tumbling window differentiation [ (sensorKey,Group) , value ],Time - final StageWithWindow<Entry<SensorGroupKey, ActivePowerRecord>> - windowedLastValues = dupliAsFlatmappedStage - .window(WindowDefinition.tumbling(windowSize)); + final StageWithWindow<Entry<SensorGroupKey, ActivePowerRecord>> windowedLastValues = + dupliAsFlatmappedStage + .window(WindowDefinition.tumbling(windowSize)); - final AggregateOperation1<Entry<SensorGroupKey, ActivePowerRecord>, - AggregatedActivePowerRecordAccumulator, AggregatedActivePowerRecord> aggrOp = + final AggregateOperation1<Entry<SensorGroupKey, ActivePowerRecord>, AggregatedActivePowerRecordAccumulator, AggregatedActivePowerRecord> aggrOp = AggregateOperation - .withCreate(AggregatedActivePowerRecordAccumulator::new) - .<Entry<SensorGroupKey, ActivePowerRecord>>andAccumulate((acc, rec) -> { - acc.setId(rec.getKey().getGroup()); - acc.addInputs(rec.getValue()); - }) - .andCombine((acc, acc2) -> - acc.addInputs(acc2.getId(), acc2.getSumInW(), acc2.getCount(), acc.getTimestamp())) - .andDeduct((acc, acc2) -> acc.removeInputs(acc2.getSumInW(), acc2.getCount())) - .andExportFinish(acc -> - new AggregatedActivePowerRecord(acc.getId(), + .withCreate(AggregatedActivePowerRecordAccumulator::new) + .<Entry<SensorGroupKey, ActivePowerRecord>>andAccumulate((acc, rec) -> { + acc.setId(rec.getKey().getGroup()); + acc.addInputs(rec.getValue()); + }) + .andCombine((acc, acc2) -> acc.addInputs(acc2.getId(), acc2.getSumInW(), + acc2.getCount(), acc.getTimestamp())) + .andDeduct((acc, acc2) -> acc.removeInputs(acc2.getSumInW(), acc2.getCount())) + .andExportFinish(acc -> new AggregatedActivePowerRecord(acc.getId(), acc.getTimestamp(), acc.getCount(), acc.getSumInW(), - acc.getAverageInW()) - ); + acc.getAverageInW())); // write aggregation back to kafka diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/AggregatedActivePowerRecordAccumulator.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/AggregatedActivePowerRecordAccumulator.java index 3166f16cd..14934fbe3 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/AggregatedActivePowerRecordAccumulator.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/AggregatedActivePowerRecordAccumulator.java @@ -1,6 +1,6 @@ package rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * Accumulator class for AggregatedActivePowerRecords. @@ -25,10 +25,10 @@ public class AggregatedActivePowerRecordAccumulator { * Creates an AggregationObject. */ public AggregatedActivePowerRecordAccumulator(final String id, - final long timestamp, - final long count, - final double sumInW, - final double averageInW) { + final long timestamp, + final long count, + final double sumInW, + final double averageInW) { this.id = id; this.timestamp = timestamp; this.count = count; @@ -50,16 +50,16 @@ public class AggregatedActivePowerRecordAccumulator { this.count += 1; this.sumInW += record.getValueInW(); this.timestamp = record.getTimestamp(); - this.averageInW = sumInW / count; + this.averageInW = this.sumInW / this.count; } /** * Adds the records from another aggregator. */ public void addInputs(final String id, - final double sumInW, - final long count, - final long timestamp) { + final double sumInW, + final long count, + final long timestamp) { this.id = this.id == null ? id : this.id; this.sumInW += sumInW; this.count += count; @@ -68,8 +68,8 @@ public class AggregatedActivePowerRecordAccumulator { } /** - * Removes the values of another aggreagator. - * Not a complete reset since the old timestamp is lost. + * Removes the values of another aggreagator. Not a complete reset since the old timestamp is + * lost. */ public void removeInputs(final double sumInW, final long count) { this.sumInW -= sumInW; @@ -79,22 +79,22 @@ public class AggregatedActivePowerRecordAccumulator { } public long getCount() { - return count; + return this.count; } public double getSumInW() { - return sumInW; + return this.sumInW; } public double getAverageInW() { - return averageInW; + return this.averageInW; } public String getId() { - return id; + return this.id; } public long getTimestamp() { - return timestamp; + return this.timestamp; } } diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ChildParentsTransformer.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ChildParentsTransformer.java index ad3b2294c..3ba604270 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ChildParentsTransformer.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ChildParentsTransformer.java @@ -10,10 +10,11 @@ import org.apache.kafka.streams.kstream.Transformer; import org.apache.kafka.streams.processor.ProcessorContext; import org.apache.kafka.streams.state.KeyValueIterator; import org.apache.kafka.streams.state.KeyValueStore; -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.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.Sensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; + /** * Transforms a {@link SensorRegistry} into key value pairs of Sensor identifiers and their parents' diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/EventDeserializer.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/EventDeserializer.java index c8d06b497..ebdc9de86 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/EventDeserializer.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/EventDeserializer.java @@ -2,8 +2,8 @@ package rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics; import java.util.Map; import org.apache.kafka.common.serialization.Deserializer; -import titan.ccp.configuration.events.Event; -import titan.ccp.configuration.events.EventSerde; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.configuration.events.EventSerde; /** * Deserializer for Event Objects. diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ImmutableSensorRegistryUc4Serializer.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ImmutableSensorRegistryUc4Serializer.java index 53d22f7f1..84e007dde 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ImmutableSensorRegistryUc4Serializer.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ImmutableSensorRegistryUc4Serializer.java @@ -4,7 +4,7 @@ import com.hazelcast.nio.ObjectDataInput; import com.hazelcast.nio.ObjectDataOutput; import com.hazelcast.nio.serialization.StreamSerializer; import java.io.IOException; -import titan.ccp.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; /** * {@link StreamSerializer} for Hazelcast Jet to serialize and deserialize an diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ValueGroup.java b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ValueGroup.java index 893efcf74..b5f5fc7cb 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ValueGroup.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/main/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/uc4specifics/ValueGroup.java @@ -2,7 +2,8 @@ package rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics; import java.util.Objects; import java.util.Set; -import titan.ccp.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; + /** * Structure: (valueInW, Set(Groups)). diff --git a/theodolite-benchmarks/uc4-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineTest.java b/theodolite-benchmarks/uc4-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineTest.java index b74c2874b..569f06105 100644 --- a/theodolite-benchmarks/uc4-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineTest.java +++ b/theodolite-benchmarks/uc4-hazelcastjet/src/test/java/rocks/theodolite/benchmarks/uc4/hazelcastjet/Uc4PipelineTest.java @@ -22,19 +22,19 @@ import org.junit.Assert; import org.junit.Before; import org.junit.Test; import org.junit.experimental.categories.Category; -import rocks.theodolite.benchmarks.uc4.hazelcastjet.Uc4PipelineBuilder; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.ImmutableSensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ImmutableSensorRegistryUc4Serializer; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.SensorGroupKey; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.SensorGroupKeySerializer; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ValueGroup; import rocks.theodolite.benchmarks.uc4.hazelcastjet.uc4specifics.ValueGroupSerializer; -import titan.ccp.configuration.events.Event; -import titan.ccp.model.records.ActivePowerRecord; -import titan.ccp.model.records.AggregatedActivePowerRecord; -import titan.ccp.model.sensorregistry.ImmutableSensorRegistry; -import titan.ccp.model.sensorregistry.MachineSensor; -import titan.ccp.model.sensorregistry.MutableAggregatedSensor; -import titan.ccp.model.sensorregistry.MutableSensorRegistry; + @Category(SerialTest.class) public class Uc4PipelineTest extends JetTestSupport { @@ -75,7 +75,7 @@ public class Uc4PipelineTest extends JetTestSupport { final StreamSource<Entry<String, AggregatedActivePowerRecord>> testAggregationSource = TestSources.itemStream(testItemsPerSecond, (timestamp, item) -> { - AggregatedActivePowerRecord test = + final AggregatedActivePowerRecord test = new AggregatedActivePowerRecord(testSensorName, System.currentTimeMillis(), 1L, @@ -100,7 +100,7 @@ public class Uc4PipelineTest extends JetTestSupport { // Topology: // level2Group -> level1Group -> testSensor - + // Create Registry final MutableSensorRegistry testRegistry = new MutableSensorRegistry(testLevel2GroupName); // Add Sensors @@ -118,7 +118,7 @@ public class Uc4PipelineTest extends JetTestSupport { // Create pipeline to test final Uc4PipelineBuilder pipelineBuilder = new Uc4PipelineBuilder(); this.testPipeline = Pipeline.create(); - this.uc4Topology = pipelineBuilder.extendUc4Topology(testPipeline, + this.uc4Topology = pipelineBuilder.extendUc4Topology(this.testPipeline, testInputSource, testAggregationSource, testConfigSource, testWindowSize); this.uc4Topology.writeTo(Sinks.logger()); @@ -130,8 +130,8 @@ public class Uc4PipelineTest extends JetTestSupport { @Test public void testOutput() { -// System.out.println("DEBUG DEBUG DEBUG || ENTERED TEST 1"); - + // System.out.println("DEBUG DEBUG DEBUG || ENTERED TEST 1"); + // Assertion Configuration final int timeout = 20; final String testSensorName = "TEST-SENSOR"; @@ -141,7 +141,7 @@ public class Uc4PipelineTest extends JetTestSupport { // Assertion - this.uc4Topology.apply(Assertions.assertCollectedEventually(timeout, + this.uc4Topology.apply(Assertions.assertCollectedEventually(timeout, collection -> { System.out.println("DEBUG || ENTERED ASSERTION COLLECTED EVENTUALLY"); @@ -168,11 +168,11 @@ public class Uc4PipelineTest extends JetTestSupport { testLevel1contained = true; } - if(Objects.equals(key, testLevel2GroupName)){ + if (Objects.equals(key, testLevel2GroupName)) { testLevel2contained = true; } - if (testValueInW != agg.getAverageInW()){ + if (testValueInW != agg.getAverageInW()) { averageEqTest = false; } @@ -191,10 +191,10 @@ public class Uc4PipelineTest extends JetTestSupport { System.out.println("avOk: " + avOk); Assert.assertTrue("Assertion did not complete!", allOkay); - + })); - try{ + try { final JobConfig jobConfig = new JobConfig() .registerSerializer(ValueGroup.class, ValueGroupSerializer.class) @@ -209,7 +209,7 @@ public class Uc4PipelineTest extends JetTestSupport { "Job was expected to complete with AssertionCompletedException, but completed with: " + e.getCause(), errorMsg.contains(AssertionCompletedException.class.getName())); - } catch (Exception e){ + } catch (final Exception e) { System.out.println("ERRORORORO TEST BROKEN !!!!"); System.out.println(e); } diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/AggregationService.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/AggregationService.java index eebeb9d39..26ea02957 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/AggregationService.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/AggregationService.java @@ -4,8 +4,8 @@ import java.time.Duration; import java.util.concurrent.CompletableFuture; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.KafkaStreams; +import rocks.theodolite.benchmarks.commons.commons.configuration.ServiceConfigurations; import rocks.theodolite.benchmarks.commons.kstreams.ConfigurationKeys; -import rocks.theodolite.commons.commons.configuration.ServiceConfigurations; /** * A microservice that manages the history and, therefore, stores and aggregates incoming diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformer.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformer.java index 74aabf80e..d311ff009 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformer.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformer.java @@ -10,10 +10,10 @@ import org.apache.kafka.streams.kstream.Transformer; import org.apache.kafka.streams.processor.ProcessorContext; import org.apache.kafka.streams.state.KeyValueIterator; import org.apache.kafka.streams.state.KeyValueStore; -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; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.Sensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; /** * Transforms a {@link SensorRegistry} into key value pairs of Sensor identifiers and their parents' diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformerSupplier.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformerSupplier.java index cdd4c5b4a..734989af6 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformerSupplier.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ChildParentsTransformerSupplier.java @@ -10,8 +10,8 @@ import org.apache.kafka.streams.kstream.TransformerSupplier; import org.apache.kafka.streams.state.KeyValueStore; import org.apache.kafka.streams.state.StoreBuilder; import org.apache.kafka.streams.state.Stores; -import rocks.theodolite.commons.configuration.events.Event; -import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; /** * Supplier class for a {@link ChildParentsTransformer}. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformer.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformer.java index 6459c2385..06cbe1f40 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformer.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformer.java @@ -9,7 +9,7 @@ import org.apache.kafka.streams.KeyValue; import org.apache.kafka.streams.kstream.Transformer; import org.apache.kafka.streams.processor.ProcessorContext; import org.apache.kafka.streams.state.KeyValueStore; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * Transforms the join result of an {@link ActivePowerRecord} and the corresponding sensor parents diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformerSupplier.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformerSupplier.java index 91a298f73..67efca067 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformerSupplier.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointFlatTransformerSupplier.java @@ -9,7 +9,7 @@ import org.apache.kafka.streams.kstream.TransformerSupplier; import org.apache.kafka.streams.state.KeyValueStore; import org.apache.kafka.streams.state.StoreBuilder; import org.apache.kafka.streams.state.Stores; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * Supplier class for {@link JointFlatTransformerSupplier}. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointRecordParents.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointRecordParents.java index 4399f57fd..85b3a8175 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointRecordParents.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/JointRecordParents.java @@ -2,7 +2,7 @@ package rocks.theodolite.benchmarks.uc4.kstreams; import java.util.Objects; import java.util.Set; -import rocks.theodolite.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; /** * A joined pair of an {@link ActivePowerRecord} and its associated parents. Both the record and the diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/OptionalParentsSerde.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/OptionalParentsSerde.java index 5c2b4dad2..e5ff9c676 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/OptionalParentsSerde.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/OptionalParentsSerde.java @@ -4,10 +4,10 @@ import java.util.HashSet; import java.util.Optional; import java.util.Set; import org.apache.kafka.common.serialization.Serde; -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; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.WriteBuffer; /** * {@link Serde} factory for an optional {@link Set} of parent identifiers. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ParentsSerde.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ParentsSerde.java index 7a6745c93..b70df4632 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ParentsSerde.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/ParentsSerde.java @@ -3,10 +3,10 @@ package rocks.theodolite.benchmarks.uc4.kstreams; import java.util.HashSet; import java.util.Set; import org.apache.kafka.common.serialization.Serde; -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; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.WriteBuffer; /** * {@link Serde} factory for {@link Set} of parent identifiers. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/RecordAggregator.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/RecordAggregator.java index 0267d3bcc..bbc607952 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/RecordAggregator.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/RecordAggregator.java @@ -1,8 +1,8 @@ package rocks.theodolite.benchmarks.uc4.kstreams; import org.apache.kafka.streams.kstream.Windowed; -import rocks.theodolite.commons.model.records.ActivePowerRecord; -import rocks.theodolite.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; /** * Updates an {@link AggregatedActivePowerRecord} by a new {@link ActivePowerRecord}. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/SensorParentKeySerde.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/SensorParentKeySerde.java index 9b1a8c62f..1beab6094 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/SensorParentKeySerde.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/SensorParentKeySerde.java @@ -1,10 +1,10 @@ package rocks.theodolite.benchmarks.uc4.kstreams; import org.apache.kafka.common.serialization.Serde; -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; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.BufferSerde; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.ReadBuffer; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.SimpleSerdes; +import rocks.theodolite.benchmarks.commons.kafka.simpleserdes.WriteBuffer; /** * {@link Serde} factory for {@link SensorParentKey}. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/TopologyBuilder.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/TopologyBuilder.java index b95fb7439..341372b20 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/TopologyBuilder.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/TopologyBuilder.java @@ -15,15 +15,15 @@ import org.apache.kafka.streams.kstream.Materialized; import org.apache.kafka.streams.kstream.Produced; import org.apache.kafka.streams.kstream.Suppressed; import org.apache.kafka.streams.kstream.Suppressed.BufferConfig; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.configuration.events.EventSerde; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; +import rocks.theodolite.benchmarks.commons.model.records.ActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.records.AggregatedActivePowerRecord; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; import org.apache.kafka.streams.kstream.TimeWindows; import org.apache.kafka.streams.kstream.Windowed; import org.apache.kafka.streams.kstream.WindowedSerdes; -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.SensorRegistry; /** * Builds Kafka Stream Topology for the History microservice. diff --git a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/Uc4KafkaStreamsBuilder.java b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/Uc4KafkaStreamsBuilder.java index 33594e5a4..209eb519f 100644 --- a/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/Uc4KafkaStreamsBuilder.java +++ b/theodolite-benchmarks/uc4-kstreams/src/main/java/rocks/theodolite/benchmarks/uc4/kstreams/Uc4KafkaStreamsBuilder.java @@ -5,8 +5,8 @@ import java.util.Objects; import java.util.Properties; import org.apache.commons.configuration2.Configuration; import org.apache.kafka.streams.Topology; +import rocks.theodolite.benchmarks.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; import rocks.theodolite.benchmarks.commons.kstreams.KafkaStreamsBuilder; -import rocks.theodolite.commons.kafka.avro.SchemaRegistryAvroSerdeFactory; /** * Builder for the Kafka Streams configuration. 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 c7601ef3b..60c95321f 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 rocks.theodolite.commons.configuration.events.Event; -import rocks.theodolite.commons.configuration.events.EventSerde; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.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 79f4f21b0..3f02a4b5e 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 @@ -3,9 +3,9 @@ package rocks.theodolite.benchmarks.uc4.loadgenerator; import java.util.Objects; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import rocks.theodolite.benchmarks.commons.configuration.events.Event; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; import rocks.theodolite.benchmarks.loadgenerator.KeySpace; -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 b8b89a71a..c9dcfa0af 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 rocks.theodolite.commons.model.sensorregistry.MutableAggregatedSensor; -import rocks.theodolite.commons.model.sensorregistry.MutableSensorRegistry; -import rocks.theodolite.commons.model.sensorregistry.SensorRegistry; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableAggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MutableSensorRegistry; +import rocks.theodolite.benchmarks.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 8c695f6e5..037bd8119 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 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; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.AggregatedSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.MachineSensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.Sensor; +import rocks.theodolite.benchmarks.commons.model.sensorregistry.SensorRegistry; public class SensorRegistryBuilderTest { -- GitLab