Creating PM-producer
[nonrtric/plt/ranpm.git] / pmproducer / src / main / java / org / oran / pmproducer / tasks / JobDataDistributor.java
1 /*-
2  * ========================LICENSE_START=================================
3  * O-RAN-SC
4  * %%
5  * Copyright (C) 2023 Nordix Foundation
6  * %%
7  * Licensed under the Apache License, Version 2.0 (the "License");
8  * you may not use this file except in compliance with the License.
9  * You may obtain a copy of the License at
10  *
11  *      http://www.apache.org/licenses/LICENSE-2.0
12  *
13  * Unless required by applicable law or agreed to in writing, software
14  * distributed under the License is distributed on an "AS IS" BASIS,
15  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
16  * See the License for the specific language governing permissions and
17  * limitations under the License.
18  * ========================LICENSE_END===================================
19  */
20
21 package org.oran.pmproducer.tasks;
22
23 import java.io.ByteArrayOutputStream;
24 import java.io.IOException;
25 import java.time.OffsetDateTime;
26 import java.time.format.DateTimeFormatter;
27 import java.time.format.DateTimeFormatterBuilder;
28 import java.util.HashMap;
29 import java.util.Map;
30 import java.util.zip.GZIPOutputStream;
31
32 import lombok.Getter;
33
34 import org.apache.commons.lang3.StringUtils;
35 import org.apache.kafka.clients.producer.ProducerConfig;
36 import org.apache.kafka.clients.producer.ProducerRecord;
37 import org.apache.kafka.common.serialization.ByteArraySerializer;
38 import org.oran.pmproducer.configuration.ApplicationConfig;
39 import org.oran.pmproducer.datastore.DataStore;
40 import org.oran.pmproducer.filter.FilteredData;
41 import org.oran.pmproducer.filter.PmReportFilter;
42 import org.oran.pmproducer.repository.Job.Parameters.KafkaDeliveryInfo;
43 import org.oran.pmproducer.repository.Jobs.JobGroup;
44 import org.oran.pmproducer.tasks.TopicListener.DataFromTopic;
45 import org.slf4j.Logger;
46 import org.slf4j.LoggerFactory;
47
48 import reactor.core.Disposable;
49 import reactor.core.publisher.Flux;
50 import reactor.core.publisher.Mono;
51 import reactor.kafka.sender.KafkaSender;
52 import reactor.kafka.sender.SenderOptions;
53 import reactor.kafka.sender.SenderRecord;
54
55 /**
56  * The class streams data from a multi cast sink and sends the data to the Job
57  * owner via REST calls.
58  */
59 @SuppressWarnings("squid:S2629") // Invoke method(s) only conditionally
60 public class JobDataDistributor {
61     private static final Logger logger = LoggerFactory.getLogger(JobDataDistributor.class);
62
63     @Getter
64     private final JobGroup jobGroup;
65     private Disposable subscription;
66     private final ErrorStats errorStats = new ErrorStats();
67
68     private final DataStore dataStore;
69     private static com.google.gson.Gson gson = new com.google.gson.GsonBuilder().disableHtmlEscaping().create();
70     private final ApplicationConfig applConfig;
71
72     private KafkaSender<byte[], byte[]> sender;
73
74     private class ErrorStats {
75         @Getter
76         private int consumerFaultCounter = 0;
77
78         public void handleOkFromConsumer() {
79             this.consumerFaultCounter = 0;
80         }
81
82         public void handleException(Throwable t) {
83             ++this.consumerFaultCounter;
84         }
85     }
86
87     public JobDataDistributor(JobGroup jobGroup, ApplicationConfig applConfig) {
88         this.applConfig = applConfig;
89         this.jobGroup = jobGroup;
90         this.dataStore = DataStore.create(applConfig);
91         this.dataStore.create(DataStore.Bucket.FILES).subscribe();
92         this.dataStore.create(DataStore.Bucket.LOCKS).subscribe();
93
94         SenderOptions<byte[], byte[]> senderOptions = senderOptions(applConfig, jobGroup.getDeliveryInfo());
95         this.sender = KafkaSender.create(senderOptions);
96     }
97
98     public void start(Flux<TopicListener.DataFromTopic> input) {
99         logger.debug("Starting distribution, to topic: {}", jobGroup.getId());
100         PmReportFilter filter = jobGroup.getFilter();
101         if (filter == null || filter.getFilterData().getPmRopEndTime() == null) {
102             this.subscription = filter(input, this.jobGroup) //
103                     .flatMap(this::sendToClient) //
104                     .onErrorResume(this::handleError) //
105                     .subscribe(this::handleSentOk, //
106                             this::handleExceptionInStream, //
107                             () -> logger.warn("JobDataDistributor stopped jobId: {}", jobGroup.getId()));
108         }
109
110         if (filter != null && filter.getFilterData().getPmRopStartTime() != null) {
111             this.dataStore.createLock(collectHistoricalDataLockName()) //
112                     .doOnNext(isLockGranted -> {
113                         if (isLockGranted.booleanValue()) {
114                             logger.debug("Checking historical PM ROP files, jobId: {}", this.jobGroup.getId());
115                         } else {
116                             logger.debug("Skipping check of historical PM ROP files, already done. jobId: {}",
117                                     this.jobGroup.getId());
118                         }
119                     }) //
120                     .filter(isLockGranted -> isLockGranted) //
121                     .flatMapMany(b -> Flux.fromIterable(filter.getFilterData().getSourceNames())) //
122                     .doOnNext(sourceName -> logger.debug("Checking source name: {}, jobId: {}", sourceName,
123                             this.jobGroup.getId())) //
124                     .flatMap(sourceName -> dataStore.listObjects(DataStore.Bucket.FILES, sourceName), 1) //
125                     .filter(this::isRopFile) //
126                     .filter(fileName -> filterStartTime(filter.getFilterData(), fileName)) //
127                     .filter(fileName -> filterEndTime(filter.getFilterData(), fileName)) //
128                     .map(this::createFakeEvent) //
129                     .flatMap(data -> TopicListener.getDataFromFileIfNewPmFileEvent(data, this.jobGroup.getType(),
130                             dataStore), 100)
131                     .map(jobGroup::filter) //
132                     .map(this::gzip) //
133                     .flatMap(this::sendToClient, 1) //
134                     .onErrorResume(this::handleCollectHistoricalDataError) //
135                     .doFinally(sig -> sendLastStoredRecord()) //
136                     .subscribe();
137         }
138     }
139
140     private static SenderOptions<byte[], byte[]> senderOptions(ApplicationConfig config,
141             KafkaDeliveryInfo deliveryInfo) {
142
143         String bootstrapServers = deliveryInfo.getBootStrapServers();
144         if (bootstrapServers == null || bootstrapServers.isEmpty()) {
145             bootstrapServers = config.getKafkaBootStrapServers();
146         }
147
148         Map<String, Object> props = new HashMap<>();
149         props.put(ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, bootstrapServers);
150         props.put(ProducerConfig.ACKS_CONFIG, "all");
151         props.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, ByteArraySerializer.class);
152         props.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, ByteArraySerializer.class);
153         return SenderOptions.create(props);
154     }
155
156     private void sendLastStoredRecord() {
157         String data = "{}";
158         FilteredData output = new FilteredData(this.jobGroup.getType().getId(), null, data.getBytes());
159
160         sendToClient(output).subscribe();
161     }
162
163     private FilteredData gzip(FilteredData data) {
164         if (this.applConfig.isZipOutput()) {
165             try {
166                 ByteArrayOutputStream out = new ByteArrayOutputStream();
167                 GZIPOutputStream gzip = new GZIPOutputStream(out);
168                 gzip.write(data.value);
169                 gzip.flush();
170                 gzip.close();
171                 byte[] zipped = out.toByteArray();
172                 return new FilteredData(data.infoTypeId, data.key, zipped, true);
173             } catch (IOException e) {
174                 logger.error("Unexpected exception when zipping: {}", e.getMessage());
175                 return data;
176             }
177         } else {
178             return data;
179         }
180     }
181
182     private Mono<String> handleCollectHistoricalDataError(Throwable t) {
183         logger.error("Exception: {} job: {}", t.getMessage(), jobGroup.getId());
184         return tryDeleteLockFile() //
185                 .map(bool -> "OK");
186     }
187
188     private String collectHistoricalDataLockName() {
189         return "collectHistoricalDataLock" + this.jobGroup.getId();
190     }
191
192     private DataFromTopic createFakeEvent(String fileName) {
193         NewFileEvent ev = new NewFileEvent(fileName);
194         return new DataFromTopic(this.jobGroup.getType().getId(), null, null, gson.toJson(ev).getBytes());
195     }
196
197     private static String fileTimePartFromRopFileName(String fileName) {
198         // "O-DU-1122/A20000626.2315+0200-2330+0200_HTTPS-6-73.json"
199         return fileName.substring(fileName.lastIndexOf("/") + 2);
200     }
201
202     private static boolean filterStartTime(PmReportFilter.FilterData filter, String fileName) {
203         try {
204             OffsetDateTime fileStartTime = getStartTimeFromFileName(fileName);
205             OffsetDateTime startTime = OffsetDateTime.parse(filter.getPmRopStartTime());
206             boolean isMatch = fileStartTime.isAfter(startTime);
207             logger.debug("Checking file: {}, fileStartTime: {}, filterStartTime: {}, isAfter: {}", fileName,
208                     fileStartTime, startTime, isMatch);
209             return isMatch;
210         } catch (Exception e) {
211             logger.warn("Time parsing exception: {}", e.getMessage());
212             return false;
213         }
214     }
215
216     private boolean isRopFile(String fileName) {
217         return fileName.endsWith(".json") || fileName.endsWith(".json.gz");
218     }
219
220     private static boolean filterEndTime(PmReportFilter.FilterData filter, String fileName) {
221         if (filter.getPmRopEndTime() == null) {
222             return true;
223         }
224         try {
225             OffsetDateTime fileEndTime = getEndTimeFromFileName(fileName);
226             OffsetDateTime endTime = OffsetDateTime.parse(filter.getPmRopEndTime());
227             boolean isMatch = fileEndTime.isBefore(endTime);
228             logger.debug("Checking file: {}, fileEndTime: {}, endTime: {}, isBefore: {}", fileName, fileEndTime,
229                     endTime, isMatch);
230             return isMatch;
231
232         } catch (Exception e) {
233             logger.warn("Time parsing exception: {}", e.getMessage());
234             return false;
235         }
236     }
237
238     private static OffsetDateTime getStartTimeFromFileName(String fileName) {
239         String fileTimePart = fileTimePartFromRopFileName(fileName);
240         // A20000626.2315+0200-2330+0200_HTTPS-6-73.json
241         fileTimePart = fileTimePart.substring(0, 18);
242         return parseFileDate(fileTimePart);
243     }
244
245     private static OffsetDateTime getEndTimeFromFileName(String fileName) {
246         String fileTimePart = fileTimePartFromRopFileName(fileName);
247         // A20000626.2315+0200-2330+0200_HTTPS-6-73.json
248         fileTimePart = fileTimePart.substring(0, 9) + fileTimePart.substring(19, 28);
249         return parseFileDate(fileTimePart);
250     }
251
252     private static OffsetDateTime parseFileDate(String timeStr) {
253         DateTimeFormatter startTimeFormatter =
254                 new DateTimeFormatterBuilder().appendPattern("yyyyMMdd.HHmmZ").toFormatter();
255         return OffsetDateTime.parse(timeStr, startTimeFormatter);
256     }
257
258     private void handleExceptionInStream(Throwable t) {
259         logger.warn("JobDataDistributor exception: {}, jobId: {}", t.getMessage(), jobGroup.getId());
260     }
261
262     public Mono<String> sendToClient(FilteredData data) {
263
264         SenderRecord<byte[], byte[], Integer> senderRecord = senderRecord(data, this.getJobGroup().getDeliveryInfo());
265
266         logger.trace("Sending data '{}' to Kafka topic: {}", StringUtils.truncate(data.getValueAString(), 10),
267                 this.getJobGroup().getDeliveryInfo());
268
269         return this.sender.send(Mono.just(senderRecord)) //
270                 .doOnNext(n -> logger.debug("Sent data to Kafka topic: {}", this.getJobGroup().getDeliveryInfo())) //
271                 .doOnError(t -> logger.warn("Failed to send to Kafka, job: {}, reason: {}", this.getJobGroup().getId(),
272                         t.getMessage())) //
273                 .onErrorResume(t -> Mono.empty()) //
274                 .collectList() //
275                 .map(x -> "ok");
276
277     }
278
279     public synchronized void stop() {
280         if (this.subscription != null) {
281             logger.debug("Stopped, job: {}", jobGroup.getId());
282             this.subscription.dispose();
283             this.subscription = null;
284         }
285         if (sender != null) {
286             sender.close();
287             sender = null;
288         }
289
290         tryDeleteLockFile().subscribe();
291     }
292
293     private Mono<Boolean> tryDeleteLockFile() {
294         return dataStore.deleteLock(collectHistoricalDataLockName()) //
295                 .doOnNext(res -> logger.debug("Removed lockfile {} {}", collectHistoricalDataLockName(), res))
296                 .onErrorResume(t -> Mono.just(false));
297     }
298
299     public synchronized boolean isRunning() {
300         return this.subscription != null;
301     }
302
303     private SenderRecord<byte[], byte[], Integer> senderRecord(FilteredData output, KafkaDeliveryInfo deliveryInfo) {
304         int correlationMetadata = 2;
305         var producerRecord =
306                 new ProducerRecord<>(deliveryInfo.getTopic(), null, null, output.key, output.value, output.headers());
307         return SenderRecord.create(producerRecord, correlationMetadata);
308     }
309
310     private Flux<FilteredData> filter(Flux<DataFromTopic> inputFlux, JobGroup jobGroup) {
311         return inputFlux.doOnNext(data -> logger.trace("Received data, job {}", jobGroup.getId())) //
312                 .doOnNext(data -> jobGroup.getJobs().forEach(job -> job.getStatistics().received(data.value))) //
313                 .map(jobGroup::filter) //
314                 .filter(f -> !f.isEmpty()) //
315                 .map(this::gzip) //
316                 .doOnNext(f -> jobGroup.getJobs().forEach(job -> job.getStatistics().filtered(f.value))) //
317                 .doOnNext(data -> logger.trace("Filtered data, job {}", jobGroup.getId())) //
318         ; //
319     }
320
321     private Mono<String> handleError(Throwable t) {
322         logger.warn("exception: {} job: {}", t.getMessage(), jobGroup.getId());
323         this.errorStats.handleException(t);
324         return Mono.empty(); // Ignore
325     }
326
327     private void handleSentOk(String data) {
328         this.errorStats.handleOkFromConsumer();
329     }
330
331 }