aboutsummaryrefslogtreecommitdiffstats
path: root/models-sim/models-sim-dmaap/src
diff options
context:
space:
mode:
Diffstat (limited to 'models-sim/models-sim-dmaap/src')
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/DmaapSimParameterGroup.java56
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/RestServerParameters.java95
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupData.java190
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapGetTopicResponse.java37
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProvider.java189
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/TopicData.java200
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1.java94
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandler.java177
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1.java91
-rw-r--r--models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandler.java66
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupDataTest.java305
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProviderTest.java288
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/TopicDataTest.java214
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1Test.java64
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandlerTest.java146
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1Test.java102
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandlerTest.java82
-rw-r--r--models-sim/models-sim-dmaap/src/test/java/org/onap/policy/sim/dmaap/parameters/DmaapSimParameterGroupTest.java34
-rw-r--r--models-sim/models-sim-dmaap/src/test/resources/logback-test.xml54
-rw-r--r--models-sim/models-sim-dmaap/src/test/resources/parameters/NormalParameters.json8
20 files changed, 0 insertions, 2492 deletions
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/DmaapSimParameterGroup.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/DmaapSimParameterGroup.java
deleted file mode 100644
index af5e4fd46..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/DmaapSimParameterGroup.java
+++ /dev/null
@@ -1,56 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019 Nordix Foundation.
- * Modifications Copyright (C) 2019-2021 AT&T Intellectual Property. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- * SPDX-License-Identifier: Apache-2.0
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.parameters;
-
-import lombok.Getter;
-import org.onap.policy.common.parameters.ParameterGroupImpl;
-import org.onap.policy.common.parameters.annotations.Min;
-import org.onap.policy.common.parameters.annotations.NotBlank;
-import org.onap.policy.common.parameters.annotations.NotNull;
-import org.onap.policy.common.parameters.annotations.Valid;
-
-/**
- * Class to hold all parameters needed for the DMaaP simulator component.
- */
-@NotNull
-@NotBlank
-@Getter
-public class DmaapSimParameterGroup extends ParameterGroupImpl {
- private @Valid RestServerParameters restServerParameters;
-
- /**
- * Frequency, in seconds, with which to sweep the topics of idle consumers. On each
- * sweep cycle, if a consumer group has had no new poll requests since the last sweep
- * cycle, it is removed.
- */
- @Min(1)
- private long topicSweepSec;
-
- /**
- * Create the DMaaP simulator parameter group.
- *
- * @param name the parameter group name
- */
- public DmaapSimParameterGroup(final String name) {
- super(name);
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/RestServerParameters.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/RestServerParameters.java
deleted file mode 100644
index 4a7b12cbf..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/parameters/RestServerParameters.java
+++ /dev/null
@@ -1,95 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019,2023 Nordix Foundation.
- * Modifications Copyright (C) 2019, 2021 AT&T Intellectual Property. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- * SPDX-License-Identifier: Apache-2.0
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.parameters;
-
-import java.util.Properties;
-import lombok.Getter;
-import org.onap.policy.common.endpoints.properties.PolicyEndPointProperties;
-import org.onap.policy.common.gson.GsonMessageBodyHandler;
-import org.onap.policy.common.parameters.ParameterGroupImpl;
-import org.onap.policy.common.parameters.annotations.Min;
-import org.onap.policy.common.parameters.annotations.NotBlank;
-import org.onap.policy.common.parameters.annotations.NotNull;
-import org.onap.policy.models.sim.dmaap.rest.CambriaMessageBodyHandler;
-import org.onap.policy.models.sim.dmaap.rest.DmaapSimRestControllerV1;
-import org.onap.policy.models.sim.dmaap.rest.TextMessageBodyHandler;
-
-/**
- * Class to hold all parameters needed for rest server.
- */
-@NotNull
-@NotBlank
-@Getter
-public class RestServerParameters extends ParameterGroupImpl {
- private String host;
-
- @Min(value = 1)
- private int port;
-
- private String userName;
-
- private String password;
-
- private boolean useHttps;
-
- private boolean sniHostCheck;
-
- public RestServerParameters() {
- super(RestServerParameters.class.getSimpleName());
- }
-
- /**
- * Creates a set of properties, suitable for building a REST server, from the
- * parameters.
- *
- * @return a set of properties representing the given parameters
- */
- public Properties getServerProperties() {
- final var props = new Properties();
- props.setProperty(PolicyEndPointProperties.PROPERTY_HTTP_SERVER_SERVICES, getName());
-
- final String svcpfx =
- PolicyEndPointProperties.PROPERTY_HTTP_SERVER_SERVICES + "." + getName();
-
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_HOST_SUFFIX, getHost());
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_PORT_SUFFIX,
- Integer.toString(getPort()));
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_REST_CLASSES_SUFFIX,
- DmaapSimRestControllerV1.class.getName());
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_MANAGED_SUFFIX, "false");
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_SWAGGER_SUFFIX, "false");
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_HTTPS_SUFFIX, Boolean.toString(isUseHttps()));
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_SNI_HOST_CHECK_SUFFIX,
- Boolean.toString(isSniHostCheck()));
-
- if (getUserName() != null && getPassword() != null) {
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_AUTH_USERNAME_SUFFIX, getUserName());
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_AUTH_PASSWORD_SUFFIX, getPassword());
- }
-
- props.setProperty(svcpfx + PolicyEndPointProperties.PROPERTY_HTTP_SERIALIZATION_PROVIDER,
- String.join(",", CambriaMessageBodyHandler.class.getName(),
- GsonMessageBodyHandler.class.getName(),
- TextMessageBodyHandler.class.getName()));
- return props;
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupData.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupData.java
deleted file mode 100644
index 3acaf0888..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupData.java
+++ /dev/null
@@ -1,190 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019, 2021 AT&T Intellectual Property. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.List;
-import java.util.concurrent.BlockingQueue;
-import java.util.concurrent.LinkedBlockingQueue;
-import java.util.concurrent.TimeUnit;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Data associated with a consumer group. All consumer instances within a group share the
- * same data object.
- */
-public class ConsumerGroupData {
- private static final Logger logger = LoggerFactory.getLogger(ConsumerGroupData.class);
-
- /**
- * Returned when messages can no longer be read from this consumer group object,
- * because it is being removed from the topic. {@link #UNREADABLE_LIST} must not be
- * the same list as Collections.emptyList(), thus we wrap it.
- */
- public static final List<String> UNREADABLE_LIST = Collections.unmodifiableList(Collections.emptyList());
-
- /**
- * Returned when there are no messages read. Collections.emptyList() is already
- * unmodifiable, thus no need to wrap it.
- */
- private static final List<String> EMPTY_LIST = Collections.emptyList();
-
- /**
- * This is locked while fields other than {@link #messageQueue} are updated.
- */
- private final Object lockit = new Object();
-
- /**
- * Number of sweep cycles that have occurred since a consumer has attempted to read
- * from the queue. This consumer group should be removed once this count exceeds
- * {@code 1}, provided {@link #nreaders} is zero.
- */
- private int nsweeps = 0;
-
- /**
- * Number of consumers that are currently attempting to read from the queue. This
- * consumer group should not be removed as long as this is non-zero.
- */
- private int nreaders = 0;
-
- /**
- * Message queue.
- */
- private final BlockingQueue<String> messageQueue = new LinkedBlockingQueue<>();
-
-
- /**
- * Constructs the object.
- *
- * @param topicName name of the topic with which this object is associated
- * @param groupName name of the consumer group with which this object is associated
- */
- public ConsumerGroupData(String topicName, String groupName) {
- logger.info("Topic {}: add consumer group: {}", topicName, groupName);
- }
-
- /**
- * Determines if this consumer group should be removed. This should be invoked once
- * during each sweep cycle. When this returns {@code true}, this consumer group should
- * be immediately discarded, as any readers will sit in a spin loop waiting for it to
- * be discarded.
- *
- * @return {@code true} if this consumer group should be removed, {@code false}
- * otherwise
- */
- public boolean shouldRemove() {
- synchronized (lockit) {
- return (nreaders == 0 && ++nsweeps > 1);
- }
- }
-
- /**
- * Reads messages from the queue, blocking if necessary.
- *
- * @param maxRead maximum number of messages to read
- * @param waitMs time to wait, in milliseconds, if the queue is currently empty
- * @return a list of messages read from the queue, empty if no messages became
- * available before the wait time elapsed, or {@link #UNREADABLE_LIST} if this
- * consumer group object is no longer active
- * @throws InterruptedException if this thread was interrupted while waiting for the
- * first message
- */
- public List<String> read(int maxRead, long waitMs) throws InterruptedException {
-
- synchronized (lockit) {
- if (nsweeps > 1 && nreaders == 0) {
- // cannot use this consumer group object anymore
- return UNREADABLE_LIST;
- }
-
- ++nreaders;
- }
-
- /*
- * Note: do EVERYTHING inside of the "try" block, so that the "finally" block can
- * update the reader count.
- *
- * Do NOT hold the lockit while we're polling, as poll() may block for a while.
- */
- try {
- // always read at least one message
- int maxRead2 = Math.max(1, maxRead);
- long waitMs2 = Math.max(0, waitMs);
-
- // perform a blocking read of the queue
- String obj = getNextMessage(waitMs2);
- if (obj == null) {
- return EMPTY_LIST;
- }
-
- /*
- * List should hold all messages from the queue PLUS the one we already have.
- * Note: it's possible for additional messages to be added to the queue while
- * we're reading from it. In that case, the list will grow as needed.
- */
- List<String> lst = new ArrayList<>(Math.min(maxRead2, messageQueue.size() + 1));
- lst.add(obj);
-
- // perform NON-blocking read of subsequent messages
- for (var x = 1; x < maxRead2; ++x) {
- if ((obj = messageQueue.poll()) == null) {
- break;
- }
-
- lst.add(obj);
- }
-
- return lst;
-
- } finally {
- synchronized (lockit) {
- --nreaders;
- nsweeps = 0;
- }
- }
- }
-
- /**
- * Writes messages to the queue.
- *
- * @param messages messages to be written to the queue
- */
- public void write(List<String> messages) {
- messageQueue.addAll(messages);
- }
-
- // the following methods may be overridden by junit tests
-
- /**
- * Gets the next message from the queue.
- *
- * @param waitMs time to wait, in milliseconds, if the queue is currently empty
- * @return the next message, or {@code null} if no messages became available before
- * the wait time elapsed
- * @throws InterruptedException if this thread was interrupted while waiting for the
- * message
- */
- protected String getNextMessage(long waitMs) throws InterruptedException {
- return messageQueue.poll(waitMs, TimeUnit.MILLISECONDS);
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapGetTopicResponse.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapGetTopicResponse.java
deleted file mode 100644
index 1f05976f7..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapGetTopicResponse.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2021 Bell Canada. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- * SPDX-License-Identifier: Apache-2.0
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import java.util.List;
-import lombok.Getter;
-import lombok.Setter;
-import lombok.ToString;
-
-/**
- * Class to capture get topic response from dmaap simulator.
- */
-@Getter
-@Setter
-@ToString
-public class DmaapGetTopicResponse {
-
- private List<String> topics;
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProvider.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProvider.java
deleted file mode 100644
index afbe10f51..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProvider.java
+++ /dev/null
@@ -1,189 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019, 2023 Nordix Foundation.
- * Modifications Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2021 Bell Canada. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- * SPDX-License-Identifier: Apache-2.0
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import jakarta.ws.rs.core.Response;
-import jakarta.ws.rs.core.Response.Status;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.concurrent.Executors;
-import java.util.concurrent.ScheduledExecutorService;
-import java.util.concurrent.TimeUnit;
-import lombok.Getter;
-import lombok.Setter;
-import org.onap.policy.common.utils.services.ServiceManagerContainer;
-import org.onap.policy.models.sim.dmaap.parameters.DmaapSimParameterGroup;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Provider to simulate DMaaP.
- *
- * @author Liam Fallon (liam.fallon@est.tech)
- */
-public class DmaapSimProvider extends ServiceManagerContainer {
- private static final Logger LOGGER = LoggerFactory.getLogger(DmaapSimProvider.class);
-
- @Getter
- @Setter
- private static DmaapSimProvider instance;
-
- /**
- * Maps a topic name to its data.
- */
- private final Map<String, TopicData> topic2data = new ConcurrentHashMap<>();
-
- /**
- * Thread used to remove idle consumers from the topics.
- */
- private ScheduledExecutorService timerPool;
-
-
- /**
- * Constructs the object.
- *
- * @param params parameters
- */
- public DmaapSimProvider(DmaapSimParameterGroup params) {
- addAction("Topic Sweeper", () -> {
- timerPool = makeTimerPool();
- timerPool.scheduleWithFixedDelay(new SweeperTask(), params.getTopicSweepSec(), params.getTopicSweepSec(),
- TimeUnit.SECONDS);
- }, () -> timerPool.shutdown());
- }
-
- /**
- * Process a DMaaP message.
- *
- * @param topicName the topic name
- * @param dmaapMessage the message to process
- * @return a response to the message
- */
- @SuppressWarnings("unchecked")
- public Response processDmaapMessagePut(final String topicName, final Object dmaapMessage) {
- LOGGER.debug("Topic: {}, Received DMaaP message(s): {}", topicName, dmaapMessage);
-
- List<Object> lst;
-
- if (dmaapMessage instanceof List) {
- lst = (List<Object>) dmaapMessage;
- } else {
- lst = Collections.singletonList(dmaapMessage);
- }
-
- TopicData topic = topic2data.get(topicName);
-
- /*
- * Write all messages and return the count. If the topic doesn't exist yet, then
- * there are no subscribers to receive the messages, thus treat it as if all
- * messages were published.
- */
- int nmessages = (topic != null ? topic.write(lst) : lst.size());
-
- Map<String, Object> map = new LinkedHashMap<>();
- map.put("serverTimeMs", 0);
- map.put("count", nmessages);
-
- return Response.status(Response.Status.OK).entity(map).build();
- }
-
- /**
- * Wait for and return a DMaaP message.
- *
- * @param topicName The topic to wait on
- * @param consumerGroup the consumer group that is waiting
- * @param consumerId the consumer ID that is waiting
- * @param limit the maximum number of messages to get
- * @param timeoutMs the length of time to wait for
- * @return the DMaaP message or
- */
- public Response processDmaapMessageGet(final String topicName, final String consumerGroup, final String consumerId,
- final int limit, final long timeoutMs) {
-
- LOGGER.debug("Topic: {}, Request for DMaaP message: {}: {} with limit={} timeout={}", topicName, consumerGroup,
- consumerId, limit, timeoutMs);
-
- try {
- List<String> lst = topic2data.computeIfAbsent(topicName, this::makeTopicData).read(consumerGroup, limit,
- timeoutMs);
-
- LOGGER.debug("Topic: {}, Retrieved {} messages for: {}: {}", topicName, lst.size(), consumerGroup,
- consumerId);
- return Response.status(Status.OK).entity(lst).build();
-
- } catch (InterruptedException e) {
- LOGGER.warn("Topic: {}, Request for DMaaP message interrupted: {}: {}", topicName, consumerGroup,
- consumerId, e);
- Thread.currentThread().interrupt();
- return Response.status(Status.GONE).entity(Collections.emptyList()).build();
- }
- }
-
- /**
- * Returns the list of default topics.
- *
- * @return the topic list
- */
- public Response processDmaapTopicsGet() {
-
- LOGGER.debug("Request for listing DMaaP topics");
- var response = new DmaapGetTopicResponse();
- response.setTopics(List.of("POLICY-PDP-PAP", "POLICY-NOTIFICATION", "unauthenticated.DCAE_CL_OUTPUT",
- "POLICY-CL-MGT"));
- return Response.status(Status.OK).entity(response).build();
- }
-
- /**
- * Task to remove idle consumers from each topic.
- */
- private class SweeperTask implements Runnable {
- @Override
- public void run() {
- topic2data.values().forEach(TopicData::removeIdleConsumers);
- }
- }
-
- // the following methods may be overridden by junit tests
-
- /**
- * Makes a new timer pool.
- *
- * @return a new timer pool
- */
- protected ScheduledExecutorService makeTimerPool() {
- return Executors.newScheduledThreadPool(1);
- }
-
- /**
- * Makes a new topic.
- *
- * @param topicName topic name
- * @return a new topic
- */
- protected TopicData makeTopicData(String topicName) {
- return new TopicData(topicName);
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/TopicData.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/TopicData.java
deleted file mode 100644
index 8e5cf24cc..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/provider/TopicData.java
+++ /dev/null
@@ -1,200 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019, 2021 AT&T Intellectual Property. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import java.util.ArrayList;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.Map.Entry;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.function.Function;
-import org.onap.policy.common.utils.coder.Coder;
-import org.onap.policy.common.utils.coder.CoderException;
-import org.onap.policy.common.utils.coder.StandardCoder;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Data associated with a topic.
- *
- * <p/>
- * Note: for ease of implementation, this adds a topic when a consumer polls it rather
- * than when a publisher writes to it. This is the opposite of how the real DMaaP works.
- * As a result, this will never return a topic-not-found message to the consumer.
- */
-public class TopicData {
- private static final Logger logger = LoggerFactory.getLogger(TopicData.class);
-
- /**
- * Name of the topic with which this data is associated.
- */
- private final String topicName;
-
- /**
- * Maps a consumer group name to its associated data.
- */
- private final Map<String, ConsumerGroupData> group2data = new ConcurrentHashMap<>();
-
-
- /**
- * Constructs the object.
- *
- * @param topicName name of the topic with which this object is associated
- */
- public TopicData(String topicName) {
- logger.info("Topic {}: added", topicName);
- this.topicName = topicName;
- }
-
- /**
- * Removes idle consumers from the topic. This is typically called once during each
- * sweep cycle.
- */
- public void removeIdleConsumers() {
- Iterator<Entry<String, ConsumerGroupData>> iter = group2data.entrySet().iterator();
- while (iter.hasNext()) {
- Entry<String, ConsumerGroupData> ent = iter.next();
- if (ent.getValue().shouldRemove()) {
- /*
- * We want the minimum amount of time to elapse between invoking
- * shouldRemove() and iter.remove(), thus all other statements (e.g.,
- * logging) should be done AFTER iter.remove().
- */
- iter.remove();
-
- logger.info("Topic {}: removed consumer group: {}", topicName, ent.getKey());
- }
- }
- }
-
- /**
- * Reads from a particular consumer group's queue.
- *
- * @param consumerGroup name of the consumer group from which to read
- * @param maxRead maximum number of messages to read
- * @param waitMs time to wait, in milliseconds, if the queue is currently empty
- * @return a list of messages read from the queue, empty if no messages became
- * available before the wait time elapsed
- * @throws InterruptedException if this thread was interrupted while waiting for the
- * first message
- */
- public List<String> read(String consumerGroup, int maxRead, long waitMs) throws InterruptedException {
- /*
- * It's possible that this thread may spin several times while waiting for
- * removeIdleConsumers() to complete its call to iter.remove(), thus we create
- * this closure once, rather than each time through the loop.
- */
- Function<String, ConsumerGroupData> maker = this::makeData;
-
- // loop until we get a readable list
- List<String> result;
-
- // @formatter:off
-
- do {
- result = group2data.computeIfAbsent(consumerGroup, maker).read(maxRead, waitMs);
- } while (result == ConsumerGroupData.UNREADABLE_LIST);
-
- // @formatter:on
-
- return result;
- }
-
- /**
- * Writes messages to the queues of every consumer group.
- *
- * @param messages messages to be written to the queues
- * @return the number of messages enqueued
- */
- public int write(List<Object> messages) {
- List<String> list = convertMessagesToStrings(messages);
-
- /*
- * We don't care if a consumer group is deleted from the map while we're adding
- * messages to it, as those messages will simply be ignored (and discarded by the
- * garbage collector).
- */
- for (ConsumerGroupData data : group2data.values()) {
- data.write(list);
- }
-
- return list.size();
- }
-
- /**
- * Converts a list of message objects to a list of message strings. If a message
- * cannot be converted for some reason, then it is not added to the result list, thus
- * the result list may be shorted than the original input list.
- *
- * @param messages objects to be converted
- * @return a list of message strings
- */
- protected List<String> convertMessagesToStrings(List<Object> messages) {
- Coder coder = new StandardCoder();
- List<String> list = new ArrayList<>(messages.size());
-
- for (Object msg : messages) {
- var str = convertMessageToString(msg, coder);
- if (str != null) {
- list.add(str);
- }
- }
-
- return list;
- }
-
- /**
- * Converts a message object to a message string.
- *
- * @param message message to be converted
- * @param coder used to encode the message as a string
- * @return the message string, or {@code null} if it cannot be converted
- */
- protected String convertMessageToString(Object message, Coder coder) {
- if (message == null) {
- return null;
- }
-
- if (message instanceof String) {
- return message.toString();
- }
-
- try {
- return coder.encode(message);
- } catch (CoderException e) {
- logger.warn("cannot encode {}", message, e);
- return null;
- }
- }
-
- // this may be overridden by junit tests
-
- /**
- * Makes data for a consumer group.
- *
- * @param consumerGroup name of the consumer group to make
- * @return new consumer group data
- */
- protected ConsumerGroupData makeData(String consumerGroup) {
- return new ConsumerGroupData(topicName, consumerGroup);
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1.java
deleted file mode 100644
index 84b610a8f..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1.java
+++ /dev/null
@@ -1,94 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019, 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- * SPDX-License-Identifier: Apache-2.0
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import jakarta.ws.rs.Consumes;
-import jakarta.ws.rs.Produces;
-import jakarta.ws.rs.core.Response.ResponseBuilder;
-import java.net.HttpURLConnection;
-import java.util.UUID;
-
-/**
- * Version v1 common superclass to provide DMaaP endpoints for the DMaaP simulator component.
- */
-@Produces("application/json")
-@Consumes({"application/cambria", "application/json"})
-public class BaseRestControllerV1 {
- public static final String EXTENSION_NAME = "interface info";
-
- public static final String API_VERSION_NAME = "api-version";
- public static final String API_VERSION = "1.0.0";
-
- public static final String LAST_MOD_NAME = "last-mod-release";
- public static final String LAST_MOD_RELEASE = "Dublin";
-
- public static final String VERSION_MINOR_NAME = "X-MinorVersion";
- public static final String VERSION_MINOR_DESCRIPTION =
- "Used to request or communicate a MINOR version back from the client"
- + " to the server, and from the server back to the client";
-
- public static final String VERSION_PATCH_NAME = "X-PatchVersion";
- public static final String VERSION_PATCH_DESCRIPTION = "Used only to communicate a PATCH version in a response for"
- + " troubleshooting purposes only, and will not be provided by" + " the client on request";
-
- public static final String VERSION_LATEST_NAME = "X-LatestVersion";
- public static final String VERSION_LATEST_DESCRIPTION = "Used only to communicate an API's latest version";
-
- public static final String REQUEST_ID_NAME = "X-ONAP-RequestID";
- public static final String REQUEST_ID_HDR_DESCRIPTION = "Used to track REST transactions for logging purpose";
- public static final String REQUEST_ID_PARAM_DESCRIPTION = "RequestID for http transaction";
-
- public static final String AUTHORIZATION_TYPE = "basicAuth";
-
- public static final int AUTHENTICATION_ERROR_CODE = HttpURLConnection.HTTP_UNAUTHORIZED;
- public static final int AUTHORIZATION_ERROR_CODE = HttpURLConnection.HTTP_FORBIDDEN;
- public static final int SERVER_ERROR_CODE = HttpURLConnection.HTTP_INTERNAL_ERROR;
-
- public static final String AUTHENTICATION_ERROR_MESSAGE = "Authentication Error";
- public static final String AUTHORIZATION_ERROR_MESSAGE = "Authorization Error";
- public static final String SERVER_ERROR_MESSAGE = "Internal Server Error";
-
- /**
- * Adds version headers to the response.
- *
- * @param respBuilder response builder
- * @return the response builder, with version headers
- */
- public ResponseBuilder addVersionControlHeaders(ResponseBuilder respBuilder) {
- return respBuilder.header(VERSION_MINOR_NAME, "0").header(VERSION_PATCH_NAME, "0").header(VERSION_LATEST_NAME,
- API_VERSION);
- }
-
- /**
- * Adds logging headers to the response.
- *
- * @param respBuilder response builder
- * @return the response builder, with version logging
- */
- public ResponseBuilder addLoggingHeaders(ResponseBuilder respBuilder, UUID requestId) {
- if (requestId == null) {
- // Generate a random uuid if client does not embed requestId in rest request
- return respBuilder.header(REQUEST_ID_NAME, UUID.randomUUID());
- }
-
- return respBuilder.header(REQUEST_ID_NAME, requestId);
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandler.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandler.java
deleted file mode 100644
index 0efab160b..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandler.java
+++ /dev/null
@@ -1,177 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019, 2021 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import jakarta.ws.rs.Consumes;
-import jakarta.ws.rs.core.MediaType;
-import jakarta.ws.rs.core.MultivaluedMap;
-import jakarta.ws.rs.ext.MessageBodyReader;
-import jakarta.ws.rs.ext.Provider;
-import java.io.BufferedReader;
-import java.io.EOFException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.io.Reader;
-import java.lang.annotation.Annotation;
-import java.lang.reflect.Type;
-import java.nio.charset.StandardCharsets;
-import java.util.LinkedList;
-import java.util.List;
-import org.apache.commons.io.IOUtils;
-
-/**
- * Provider that decodes "application/cambria" messages.
- */
-@Provider
-@Consumes(CambriaMessageBodyHandler.MEDIA_TYPE_APPLICATION_CAMBRIA)
-public class CambriaMessageBodyHandler implements MessageBodyReader<Object> {
- public static final String MEDIA_TYPE_APPLICATION_CAMBRIA = "application/cambria";
-
- /**
- * Maximum length of a message or partition.
- */
- private static final int MAX_LEN = 10000000;
-
- /**
- * Maximum digits in a length field.
- */
- private static final int MAX_DIGITS = 10;
-
- @Override
- public boolean isReadable(Class<?> type, Type genericType, Annotation[] annotations, MediaType mediaType) {
- return (mediaType != null && MEDIA_TYPE_APPLICATION_CAMBRIA.equals(mediaType.toString()));
- }
-
- @Override
- public List<Object> readFrom(Class<Object> type, Type genericType, Annotation[] annotations, MediaType mediaType,
- MultivaluedMap<String, String> httpHeaders, InputStream entityStream) throws IOException {
-
- try (var bufferedReader = new BufferedReader(new InputStreamReader(entityStream, StandardCharsets.UTF_8))) {
- List<Object> messages = new LinkedList<>();
- String msg;
- while ((msg = readMessage(bufferedReader)) != null) {
- messages.add(msg);
- }
-
- return messages;
- }
- }
-
- /**
- * Reads a message.
- *
- * @param reader source from which to read
- * @return the message that was read, or {@code null} if there are no more messages
- * @throws IOException if an error occurs
- */
- private String readMessage(Reader reader) throws IOException {
- if (!skipWhitespace(reader)) {
- return null;
- }
-
- int partlen = readLength(reader);
- if (partlen > MAX_LEN) {
- throw new IOException("invalid partition length");
- }
-
- int msglen = readLength(reader);
- if (msglen > MAX_LEN) {
- throw new IOException("invalid message length");
- }
-
- // skip over the partition
- reader.skip(partlen);
-
- return readString(reader, msglen);
- }
-
- /**
- * Skips whitespace.
- *
- * @param reader source from which to read
- * @return {@code true} if there is another character after the whitespace,
- * {@code false} if the end of the stream has been reached
- * @throws IOException if an error occurs
- */
- private boolean skipWhitespace(Reader reader) throws IOException {
- int chr;
-
- do {
- reader.mark(1);
- if ((chr = reader.read()) < 0) {
- return false;
- }
- } while (Character.isWhitespace(chr));
-
- // push the last character back onto the reader
- reader.reset();
-
- return true;
- }
-
- /**
- * Reads a length field, which is a number followed by ".".
- *
- * @param reader source from which to read
- * @return the length, or -1 if EOF has been reached
- * @throws IOException if an error occurs
- */
- private int readLength(Reader reader) throws IOException {
- var bldr = new StringBuilder(MAX_DIGITS);
-
- int chr;
- for (var x = 0; x < MAX_DIGITS; ++x) {
- if ((chr = reader.read()) < 0) {
- throw new EOFException("missing '.' in 'length' field");
- }
-
- if (chr == '.') {
- String text = bldr.toString().trim();
- return (text.isEmpty() ? 0 : Integer.parseInt(text));
- }
-
- if (!Character.isDigit(chr)) {
- throw new IOException("invalid character in 'length' field");
- }
-
- bldr.append((char) chr);
- }
-
- throw new IOException("too many digits in 'length' field");
- }
-
- /**
- * Reads a string.
- *
- * @param reader source from which to read
- * @param len length of the string (i.e., number of characters to read)
- * @return the string that was read
- * @throws IOException if an error occurs
- */
- private String readString(Reader reader, int len) throws IOException {
- var buf = new char[len];
- IOUtils.readFully(reader, buf);
-
- return new String(buf);
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1.java
deleted file mode 100644
index 5ed04f1a3..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1.java
+++ /dev/null
@@ -1,91 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019, 2021, 2023 Nordix Foundation.
- * Modifications Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2021 Bell Canada. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- * SPDX-License-Identifier: Apache-2.0
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import jakarta.ws.rs.Consumes;
-import jakarta.ws.rs.DefaultValue;
-import jakarta.ws.rs.GET;
-import jakarta.ws.rs.POST;
-import jakarta.ws.rs.Path;
-import jakarta.ws.rs.PathParam;
-import jakarta.ws.rs.Produces;
-import jakarta.ws.rs.QueryParam;
-import jakarta.ws.rs.core.Response;
-import org.onap.policy.models.sim.dmaap.provider.DmaapSimProvider;
-
-/**
- * Class to provide REST endpoints for DMaaP simulator component statistics.
- */
-@Path("/")
-@Produces(DmaapSimRestControllerV1.MEDIA_TYPE_APPLICATION_JSON)
-public class DmaapSimRestControllerV1 extends BaseRestControllerV1 {
- public static final String MEDIA_TYPE_APPLICATION_JSON = "application/json";
-
- /**
- * Get a DMaaP message.
- *
- * @param topicName topic to get message from
- * @param consumerGroup consumer group that is getting the message
- * @param consumerId consumer ID that is getting the message
- * @param timeoutMs timeout for the message
- * @return the message
- */
- @GET
- @Path("events/{topicName}/{consumerGroup}/{consumerId}")
- public Response getDmaapMessage(@PathParam("topicName") final String topicName,
- @PathParam("consumerGroup") final String consumerGroup,
- @PathParam("consumerId") final String consumerId,
- @QueryParam("limit") @DefaultValue("1") final int limit,
- @QueryParam("timeout") @DefaultValue("15000") final long timeoutMs) {
-
- return DmaapSimProvider.getInstance().processDmaapMessageGet(topicName, consumerGroup, consumerId, limit,
- timeoutMs);
- }
-
- /**
- * Post a DMaaP message.
- *
- * @param topicName topic to get message from
- * @return the response to the post
- */
- @POST
- @Path("events/{topicName}")
- @Consumes(value = {CambriaMessageBodyHandler.MEDIA_TYPE_APPLICATION_CAMBRIA,
- TextMessageBodyHandler.MEDIA_TYPE_TEXT_PLAIN, MEDIA_TYPE_APPLICATION_JSON})
- public Response postDmaapMessage(@PathParam("topicName") final String topicName, final Object dmaapMessage) {
-
- return DmaapSimProvider.getInstance().processDmaapMessagePut(topicName, dmaapMessage);
- }
-
- /**
- * Get the list of topics configured.
- *
- * @return the message
- */
- @GET
- @Path("topics")
- public Response getDmaapTopics() {
-
- return DmaapSimProvider.getInstance().processDmaapTopicsGet();
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandler.java b/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandler.java
deleted file mode 100644
index 6d3bd730e..000000000
--- a/models-sim/models-sim-dmaap/src/main/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandler.java
+++ /dev/null
@@ -1,66 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019, 2021 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import jakarta.ws.rs.Consumes;
-import jakarta.ws.rs.core.MediaType;
-import jakarta.ws.rs.core.MultivaluedMap;
-import jakarta.ws.rs.ext.MessageBodyReader;
-import jakarta.ws.rs.ext.Provider;
-import java.io.BufferedReader;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.lang.annotation.Annotation;
-import java.lang.reflect.Type;
-import java.nio.charset.StandardCharsets;
-import java.util.LinkedList;
-import java.util.List;
-
-/**
- * Provider that decodes "text/plain" messages.
- */
-@Provider
-@Consumes(TextMessageBodyHandler.MEDIA_TYPE_TEXT_PLAIN)
-public class TextMessageBodyHandler implements MessageBodyReader<Object> {
- public static final String MEDIA_TYPE_TEXT_PLAIN = "text/plain";
-
- @Override
- public boolean isReadable(Class<?> type, Type genericType, Annotation[] annotations, MediaType mediaType) {
- return (mediaType != null && MEDIA_TYPE_TEXT_PLAIN.equals(mediaType.toString()));
- }
-
- @Override
- public List<Object> readFrom(Class<Object> type, Type genericType, Annotation[] annotations, MediaType mediaType,
- MultivaluedMap<String, String> httpHeaders, InputStream entityStream) throws IOException {
-
- try (var bufferedReader = new BufferedReader(new InputStreamReader(entityStream, StandardCharsets.UTF_8))) {
- List<Object> messages = new LinkedList<>();
- String msg;
- while ((msg = bufferedReader.readLine()) != null) {
- messages.add(msg);
- }
-
- return messages;
- }
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupDataTest.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupDataTest.java
deleted file mode 100644
index 4513ffb82..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/ConsumerGroupDataTest.java
+++ /dev/null
@@ -1,305 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertSame;
-import static org.junit.Assert.assertTrue;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.List;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.TimeUnit;
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-
-public class ConsumerGroupDataTest {
- private static final int WAIT_MS = 5000;
- private static final int MIN_WAIT_MS = WAIT_MS / 2;
- private static final String MY_TOPIC = "my-topic";
- private static final String MY_CONSUMER = "my-consumer";
- private static final String MSG1 = "hello";
- private static final String MSG2 = "there";
- private static final String MSG3 = "world";
- private static final int MAX_THREADS = 30;
-
- private MyData data;
- private MyReader thread;
- private List<MyReader> threads;
-
- /**
- * Sets up.
- */
- @Before
- public void setUp() {
- data = new MyData();
- thread = null;
- threads = new ArrayList<>(MAX_THREADS);
- }
-
- /**
- * Stops any running thread.
- */
- @After
- public void tearDown() {
- for (MyReader thr : threads) {
- thr.interrupt();
- }
-
- for (MyReader thr : threads) {
- thr.await();
- }
- }
-
- @Test
- public void testShouldRemove() throws InterruptedException {
- assertFalse(data.shouldRemove());
- assertTrue(data.shouldRemove());
-
- data = new MyData();
-
- // start a reader thread and wait for it to poll its queue
- startReader(0, 10);
- assertTrue(data.await());
-
- assertFalse(data.shouldRemove());
- }
-
- @Test
- public void testRead() {
- data.enqueue(MSG1, MSG2, MSG3, MSG1, MSG2, MSG3);
-
- // this reader only wants one
- startReader(1, 1);
- assertTrue(thread.await());
- assertEquals("[hello]", thread.result.toString());
-
- // this reader wants three
- startReader(3, 1);
- assertTrue(thread.await());
- assertEquals("[there, world, hello]", thread.result.toString());
-
- // this reader wants three, but will only get two
- startReader(3, 1);
- assertTrue(thread.await());
- assertEquals("[there, world]", thread.result.toString());
- }
-
- @Test
- public void testRead_Idle() throws InterruptedException {
- // force it to idle
- data.shouldRemove();
- data.shouldRemove();
-
- long tbeg = System.currentTimeMillis();
- assertSame(ConsumerGroupData.UNREADABLE_LIST, data.read(1, WAIT_MS));
-
- // should not have waited
- assertTrue(System.currentTimeMillis() < tbeg + MIN_WAIT_MS);
- }
-
- @Test
- public void testRead_NegativeCount() throws InterruptedException {
- data.enqueue(MSG1, MSG2);
- startReader(-1, 3);
- assertTrue(data.await());
-
- // wait time should be unaffected
- assertEquals(3L, data.waitMs2);
-
- assertTrue(thread.await());
-
- // should only return one message
- assertEquals("[hello]", thread.result.toString());
- }
-
- @Test
- public void testRead_NegativeWait() throws InterruptedException {
- data.enqueue(MSG1, MSG2, MSG3);
- startReader(2, -3);
- assertTrue(data.await());
-
- assertEquals(0L, data.waitMs2);
-
- assertTrue(thread.await());
-
- // should return two messages, as requested
- assertEquals("[hello, there]", thread.result.toString());
- }
-
- @Test
- public void testRead_NoMessages() throws InterruptedException {
- startReader(0, 0);
- assertTrue(data.await());
-
- assertTrue(thread.await());
- assertTrue(thread.result.isEmpty());
- }
-
- @Test
- public void testRead_MultiThreaded() {
- // queue up a bunch of messages
- final int expected = MAX_THREADS * 3;
- for (int x = 0; x < expected; ++x) {
- data.enqueue(MSG1);
- }
-
- for (int x = 0; x < MAX_THREADS; ++x) {
- startReader(4, 1);
- }
-
- int actual = 0;
- for (MyReader thr : threads) {
- thr.await();
- actual += thr.result.size();
- }
-
- assertEquals(expected, actual);
- }
-
-
- /**
- * Starts a reader thread.
- *
- * @param limit number of messages to read at one time
- * @param waitMs wait time, in milliseconds
- */
- private void startReader(int limit, long waitMs) {
- thread = new MyReader(limit, waitMs);
-
- thread.setDaemon(true);
- thread.start();
-
- threads.add(thread);
- }
-
-
- private class MyData extends ConsumerGroupData {
-
- /**
- * Decremented when {@link #getNextMessage(long)} is invoked.
- */
- private final CountDownLatch latch = new CountDownLatch(1);
-
- /**
- * Messages to be added to the queue when {@link #getNextMessage(long)} is
- * invoked.
- */
- private final List<String> messages = new ArrayList<>();
-
- /**
- * Value passed to {@link #getNextMessage(long)}.
- */
- private volatile long waitMs2 = -1;
-
- /**
- * Constructs the object.
- */
- public MyData() {
- super(MY_TOPIC, MY_CONSUMER);
- }
-
- /**
- * Arranges for messages to be injected into the queue the next time
- * {@link #getNextMessage(long)} is invoked.
- *
- * @param messages the messages to be injected
- */
- public void enqueue(String... messages) {
- this.messages.addAll(Arrays.asList(messages));
- }
-
- @Override
- protected String getNextMessage(long waitMs) throws InterruptedException {
- waitMs2 = waitMs;
-
- latch.countDown();
-
- synchronized (messages) {
- write(messages);
- messages.clear();
- }
-
- return super.getNextMessage(waitMs);
- }
-
- /**
- * Waits for {@link #getNextMessage(long)} to be invoked.
- *
- * @return {@code true} if {@link #getNextMessage(long)} was invoked,
- * {@code false} if the timer expired first
- * @throws InterruptedException if the current thread is interrupted while waiting
- */
- public boolean await() throws InterruptedException {
- return latch.await(WAIT_MS, TimeUnit.MILLISECONDS);
- }
- }
-
- /**
- * Thread that will invoke the consumer group's read() method one time.
- */
- private class MyReader extends Thread {
- private final ConsumerGroupData group = data;
- private final int limit;
- private final long waitMs;
-
- /**
- * Result returned by the read() method.
- */
- private List<String> result = Collections.emptyList();
-
- public MyReader(int limit, long waitMs) {
- this.limit = limit;
- this.waitMs = waitMs;
- }
-
- @Override
- public void run() {
- try {
- result = group.read(limit, waitMs);
-
- } catch (InterruptedException e) {
- Thread.currentThread().interrupt();
- }
- }
-
- /**
- * Waits for the thread to complete.
- *
- * @return {@code true} if the thread completed, {@code false} if the thread is
- * still running
- */
- public boolean await() {
- try {
- this.join(WAIT_MS);
-
- } catch (InterruptedException e) {
- Thread.currentThread().interrupt();
- }
-
- return !this.isAlive();
- }
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProviderTest.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProviderTest.java
deleted file mode 100644
index f82ef03f2..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/DmaapSimProviderTest.java
+++ /dev/null
@@ -1,288 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019-2021 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import static org.assertj.core.api.Assertions.assertThatCode;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertSame;
-import static org.mockito.ArgumentMatchers.any;
-import static org.mockito.ArgumentMatchers.anyInt;
-import static org.mockito.ArgumentMatchers.anyLong;
-import static org.mockito.ArgumentMatchers.eq;
-import static org.mockito.Mockito.spy;
-import static org.mockito.Mockito.times;
-import static org.mockito.Mockito.verify;
-import static org.mockito.Mockito.when;
-
-import jakarta.ws.rs.core.Response;
-import jakarta.ws.rs.core.Response.Status;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.List;
-import java.util.concurrent.BlockingQueue;
-import java.util.concurrent.LinkedBlockingQueue;
-import java.util.concurrent.ScheduledExecutorService;
-import java.util.concurrent.TimeUnit;
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.mockito.ArgumentCaptor;
-import org.mockito.Captor;
-import org.mockito.Mock;
-import org.mockito.junit.MockitoJUnitRunner;
-import org.onap.policy.common.utils.coder.CoderException;
-import org.onap.policy.common.utils.coder.StandardCoder;
-import org.onap.policy.common.utils.coder.StandardCoderObject;
-import org.onap.policy.models.sim.dmaap.parameters.DmaapSimParameterGroup;
-
-@RunWith(MockitoJUnitRunner.class)
-public class DmaapSimProviderTest {
- private static final String EXPECTED_EXCEPTION = "expected exception";
- private static final long SWEEP_SEC = 10L;
- private static final String TOPIC1 = "topic-A";
- private static final String TOPIC2 = "topic-B";
- private static final String CONSUMER1 = "consumer-X";
- private static final String CONSUMER_ID1 = "id1";
-
- private MyProvider prov;
-
- @Mock
- private DmaapSimParameterGroup params;
-
- @Mock
- private ScheduledExecutorService timer;
-
- @Mock
- private TopicData data1;
-
- @Mock
- private TopicData data2;
-
- @Captor
- private ArgumentCaptor<List<Object>> listCaptor;
-
- @Captor
- private ArgumentCaptor<List<Object>> listCaptor2;
-
- /**
- * Sets up.
- */
- @Before
- public void setUp() {
- when(params.getTopicSweepSec()).thenReturn(SWEEP_SEC);
-
- prov = new MyProvider(params);
- }
-
- /**
- * Shuts down the provider, if it's running.
- */
- @After
- public void tearDown() {
- if (prov.isAlive()) {
- prov.shutdown();
- }
- }
-
- /**
- * Verifies that the constructor adds all the expected actions to the service
- * manager container.
- */
- @Test
- public void testDmaapSimProvider() {
- prov.start();
- verify(timer).scheduleWithFixedDelay(any(), eq(SWEEP_SEC), eq(SWEEP_SEC), eq(TimeUnit.SECONDS));
-
- prov.stop();
- verify(timer).shutdown();
- }
-
- @Test
- public void testProcessDmaapMessagePut_List() throws CoderException {
- prov = spy(new MyProvider(params));
-
- when(data1.write(any())).thenReturn(2);
-
- // force topics to exist
- prov.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 1, 0);
- prov.processDmaapMessageGet(TOPIC2, CONSUMER1, CONSUMER_ID1, 1, 0);
-
- List<Object> lst = Arrays.asList("hello", "world");
- Response resp = prov.processDmaapMessagePut(TOPIC1, lst);
- assertEquals(Status.OK.getStatusCode(), resp.getStatus());
- StandardCoderObject sco = new StandardCoder().decode(resp.getEntity().toString(), StandardCoderObject.class);
- assertEquals("2", sco.getString("count"));
-
- List<Object> lst2 = Arrays.asList("helloB", "worldB");
- prov.processDmaapMessagePut(TOPIC1, lst2);
- prov.processDmaapMessagePut(TOPIC2, lst2);
-
- // should only invoke this once for each topic
- verify(prov).makeTopicData(TOPIC1);
- verify(prov).makeTopicData(TOPIC2);
-
- // should process all writes
- verify(data1).write(lst);
- verify(data1).write(lst2);
-
- verify(data2).write(lst2);
- }
-
- @Test
- public void testProcessDmaapMessagePut_Single() throws CoderException {
- prov = spy(new MyProvider(params));
-
- // force topics to exist
- prov.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 1, 0);
- prov.processDmaapMessageGet(TOPIC2, CONSUMER1, CONSUMER_ID1, 1, 0);
-
- final String value1 = "abc";
- Response resp = prov.processDmaapMessagePut(TOPIC1, value1);
- assertEquals(Status.OK.getStatusCode(), resp.getStatus());
-
- // ensure that the response can be decoded
- new StandardCoder().decode(resp.getEntity().toString(), StandardCoderObject.class);
-
- final String value2 = "def";
- prov.processDmaapMessagePut(TOPIC1, value2);
- prov.processDmaapMessagePut(TOPIC2, value2);
-
- // should only invoke this once for each topic
- verify(prov).makeTopicData(TOPIC1);
- verify(prov).makeTopicData(TOPIC2);
-
- // should process all writes as singleton lists
- verify(data1, times(2)).write(listCaptor.capture());
- assertEquals(Collections.singletonList(value1), listCaptor.getAllValues().get(0));
- assertEquals(Collections.singletonList(value2), listCaptor.getAllValues().get(1));
-
- verify(data2).write(listCaptor2.capture());
- assertEquals(Collections.singletonList(value2), listCaptor2.getAllValues().get(0));
- }
-
- @Test
- public void testProcessDmaapMessageGet() throws InterruptedException {
- List<String> msgs = Arrays.asList("400", "500");
- when(data1.read(any(), anyInt(), anyLong())).thenReturn(msgs);
-
- Response resp = prov.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 4, 400L);
- assertEquals(Status.OK.getStatusCode(), resp.getStatus());
- assertEquals(msgs.toString(), resp.getEntity().toString());
- }
-
- @Test
- public void testProcessDmaapMessageGet_Timeout() throws InterruptedException {
- when(data1.read(any(), anyInt(), anyLong())).thenReturn(Collections.emptyList());
-
- Response resp = prov.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 3, 300L);
- assertEquals(Status.OK.getStatusCode(), resp.getStatus());
- assertEquals("[]", resp.getEntity().toString());
- }
-
- @Test
- public void testProcessDmaapMessageGet_Ex() throws InterruptedException {
- BlockingQueue<Response> respQueue = new LinkedBlockingQueue<>();
-
- // put in a background thread, so it doesn't interrupt the tester thread
- new Thread(() -> {
- try {
- when(data1.read(any(), anyInt(), anyLong())).thenThrow(new InterruptedException(EXPECTED_EXCEPTION));
- respQueue.offer(prov.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 3, 300L));
- } catch (InterruptedException e) {
- Thread.currentThread().interrupt();
- }
- }).start();
-
- Response resp = respQueue.poll(3, TimeUnit.SECONDS);
- assertNotNull(resp);
-
- assertEquals(Status.GONE.getStatusCode(), resp.getStatus());
- assertEquals("[]", resp.getEntity().toString());
- }
-
- @Test
- public void testSweepTopicTaskRun() {
- prov.start();
- prov.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 0, 0);
- prov.processDmaapMessageGet(TOPIC2, CONSUMER1, CONSUMER_ID1, 0, 0);
-
- ArgumentCaptor<Runnable> captor = ArgumentCaptor.forClass(Runnable.class);
- verify(timer).scheduleWithFixedDelay(captor.capture(), anyLong(), anyLong(), any(TimeUnit.class));
-
- captor.getValue().run();
- verify(data1).removeIdleConsumers();
- verify(data2).removeIdleConsumers();
-
- // run it again
- captor.getValue().run();
- verify(data1, times(2)).removeIdleConsumers();
- verify(data2, times(2)).removeIdleConsumers();
- }
-
- @Test
- public void testMakeTimerPool() {
- // use a real provider, so we can test the real makeTimer() method
- DmaapSimProvider prov2 = new DmaapSimProvider(params);
- prov2.start();
- assertThatCode(prov2::stop).doesNotThrowAnyException();
- }
-
- @Test
- public void testMakeTopicData() {
- // use a real provider, so we can test the real makeTopicData() method
- DmaapSimProvider prov2 = new DmaapSimProvider(params);
- assertThatCode(() -> prov2.processDmaapMessageGet(TOPIC1, CONSUMER1, CONSUMER_ID1, 0, 0))
- .doesNotThrowAnyException();
- }
-
- @Test
- public void testGetInstance_testSetInstance() {
- DmaapSimProvider.setInstance(prov);
- assertSame(prov, DmaapSimProvider.getInstance());
-
- DmaapSimProvider.setInstance(null);
- assertNull(DmaapSimProvider.getInstance());
- }
-
-
- public class MyProvider extends DmaapSimProvider {
-
- public MyProvider(DmaapSimParameterGroup params) {
- super(params);
- }
-
- @Override
- protected ScheduledExecutorService makeTimerPool() {
- return timer;
- }
-
- @Override
- protected TopicData makeTopicData(String topicName) {
- return switch (topicName) {
- case TOPIC1 -> data1;
- case TOPIC2 -> data2;
- default -> throw new IllegalArgumentException("unknown topic name: " + topicName);
- };
- }
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/TopicDataTest.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/TopicDataTest.java
deleted file mode 100644
index f37255acf..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/provider/TopicDataTest.java
+++ /dev/null
@@ -1,214 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019-2020 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.provider;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertSame;
-import static org.junit.Assert.assertTrue;
-import static org.mockito.ArgumentMatchers.any;
-import static org.mockito.ArgumentMatchers.anyInt;
-import static org.mockito.ArgumentMatchers.anyLong;
-import static org.mockito.Mockito.mock;
-import static org.mockito.Mockito.times;
-import static org.mockito.Mockito.verify;
-import static org.mockito.Mockito.when;
-
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.LinkedList;
-import java.util.List;
-import java.util.Map;
-import java.util.TreeMap;
-import java.util.TreeSet;
-import java.util.stream.Collectors;
-import org.junit.Before;
-import org.junit.Test;
-import org.onap.policy.common.utils.coder.Coder;
-import org.onap.policy.common.utils.coder.CoderException;
-import org.onap.policy.common.utils.coder.StandardCoder;
-import org.springframework.test.util.ReflectionTestUtils;
-
-public class TopicDataTest {
- private static final String EXPECTED_EXCEPTION = "expected exception";
- private static final String GROUP1 = "group-A";
- private static final String GROUP2 = "group-B";
- private static final String GROUP3 = "group-C";
-
- private TopicData data;
- private ConsumerGroupData consgrp1;
- private ConsumerGroupData consgrp2;
- private ConsumerGroupData consgrp3;
- private List<ConsumerGroupData> groups;
-
- /**
- * Sets up mocks and the initial data object.
- *
- * @throws Exception if an error occurs
- */
- @Before
- public void setUp() throws Exception {
- consgrp1 = mock(ConsumerGroupData.class);
- consgrp2 = mock(ConsumerGroupData.class);
- consgrp3 = mock(ConsumerGroupData.class);
-
- when(consgrp1.read(anyInt(), anyLong())).thenReturn(Collections.emptyList());
- when(consgrp2.read(anyInt(), anyLong())).thenReturn(Collections.emptyList());
- when(consgrp3.read(anyInt(), anyLong())).thenReturn(Collections.emptyList());
-
- groups = new LinkedList<>(Arrays.asList(consgrp1, consgrp2, consgrp3));
-
- data = new TopicData("my-topic") {
- @Override
- protected ConsumerGroupData makeData(String consumerGroup) {
- return groups.remove(0);
- }
- };
- }
-
- @Test
- public void testRemoveIdleConsumers() throws Exception {
- // force two consumers into the map
- data.read(GROUP1, 0, 0);
- data.read(GROUP2, 0, 0);
- data.read(GROUP3, 0, 0);
-
- // indicate that one should be removed
- when(consgrp1.shouldRemove()).thenReturn(true);
-
- // sweep
- data.removeIdleConsumers();
-
- assertEquals("[group-B, group-C]", new TreeSet<>(getGroups().keySet()).toString());
-
- // indicate that the others should be removed
- when(consgrp2.shouldRemove()).thenReturn(true);
- when(consgrp3.shouldRemove()).thenReturn(true);
-
- // sweep
- data.removeIdleConsumers();
-
- assertTrue(getGroups().isEmpty());
- }
-
- @Test
- public void testRead() throws Exception {
- List<String> lst = Collections.emptyList();
-
- when(consgrp1.read(anyInt(), anyLong())).thenReturn(ConsumerGroupData.UNREADABLE_LIST)
- .thenReturn(ConsumerGroupData.UNREADABLE_LIST).thenReturn(lst);
-
- assertSame(lst, data.read(GROUP1, 10, 20));
-
- // should have invoked three times
- verify(consgrp1, times(3)).read(anyInt(), anyLong());
-
- // should have used the given values
- verify(consgrp1, times(3)).read(10, 20);
-
- // should not have allocated more than one group
- assertEquals(2, groups.size());
- }
-
- @Test
- public void testRead_MultipleGroups() throws Exception {
- List<String> lst1 = Collections.emptyList();
- when(consgrp1.read(anyInt(), anyLong())).thenReturn(lst1);
-
- List<String> lst2 = Collections.emptyList();
- when(consgrp2.read(anyInt(), anyLong())).thenReturn(lst2);
-
- // one from each group
- assertSame(lst1, data.read(GROUP1, 0, 0));
- assertSame(lst2, data.read(GROUP2, 0, 0));
-
- // repeat
- assertSame(lst1, data.read(GROUP1, 0, 0));
- assertSame(lst2, data.read(GROUP2, 0, 0));
-
- // again
- assertSame(lst1, data.read(GROUP1, 0, 0));
- assertSame(lst2, data.read(GROUP2, 0, 0));
-
- // should still have group3 in the list
- assertEquals(1, groups.size());
- }
-
- @Test
- public void testWrite() throws Exception {
- // no groups yet
- List<Object> messages = Arrays.asList("hello", "world");
- data.write(messages);
-
- // add two groups
- data.read(GROUP1, 0, 0);
- data.read(GROUP2, 0, 0);
-
- data.write(messages);
-
- // should have been written to both groups
- List<String> strings = messages.stream().map(Object::toString).collect(Collectors.toList());
- verify(consgrp1).write(strings);
- verify(consgrp2).write(strings);
- }
-
- @Test
- public void testConvertMessagesToStrings() {
- assertEquals("[abc, 200]", data.convertMessagesToStrings(Arrays.asList("abc", null, 200)).toString());
- }
-
- @Test
- public void testConvertMessageToString() throws CoderException {
- Coder coder = new StandardCoder();
-
- assertNull(data.convertMessageToString(null, coder));
- assertEquals("text-msg", data.convertMessageToString("text-msg", coder));
- assertEquals("100", data.convertMessageToString(100, coder));
-
- coder = mock(Coder.class);
- when(coder.encode(any())).thenThrow(new CoderException(EXPECTED_EXCEPTION));
- assertNull(data.convertMessageToString(new TreeMap<String, Object>(), coder));
- }
-
- @Test
- public void testMakeData() throws Exception {
- // use real objects instead of mocks
- TopicData data2 = new TopicData("real-data-topic");
-
- // force a group into the topic
- data2.read(GROUP1, 0, 0);
-
- data2.write(Arrays.asList("abc", "def", "ghi"));
-
- assertEquals("[abc, def]", data2.read(GROUP1, 2, 0).toString());
- }
-
- /**
- * Gets the consumer group map from the topic data object.
- *
- * @return the topic's consumer group map
- */
- @SuppressWarnings("unchecked")
- private Map<String, ConsumerGroupData> getGroups() {
- return (Map<String, ConsumerGroupData>) ReflectionTestUtils.getField(data, "group2data");
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1Test.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1Test.java
deleted file mode 100644
index 0d24436f7..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/BaseRestControllerV1Test.java
+++ /dev/null
@@ -1,64 +0,0 @@
-/*
- * ============LICENSE_START=======================================================
- * ONAP PAP
- * ================================================================================
- * Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-
-import jakarta.ws.rs.core.Response;
-import jakarta.ws.rs.core.Response.ResponseBuilder;
-import java.util.UUID;
-import org.junit.Before;
-import org.junit.Test;
-
-public class BaseRestControllerV1Test {
-
- private BaseRestControllerV1 ctlr;
- private ResponseBuilder bldr;
-
- @Before
- public void setUp() {
- ctlr = new BaseRestControllerV1();
- bldr = Response.status(Response.Status.OK);
- }
-
- @Test
- public void testAddVersionControlHeaders() {
- Response resp = ctlr.addVersionControlHeaders(bldr).build();
- assertEquals("0", resp.getHeaderString(BaseRestControllerV1.VERSION_MINOR_NAME));
- assertEquals("0", resp.getHeaderString(BaseRestControllerV1.VERSION_PATCH_NAME));
- assertEquals("1.0.0", resp.getHeaderString(BaseRestControllerV1.VERSION_LATEST_NAME));
- }
-
- @Test
- public void testAddLoggingHeaders_Null() {
- Response resp = ctlr.addLoggingHeaders(bldr, null).build();
- assertNotNull(resp.getHeaderString(BaseRestControllerV1.REQUEST_ID_NAME));
- }
-
- @Test
- public void testAddLoggingHeaders_NonNull() {
- UUID uuid = UUID.randomUUID();
- Response resp = ctlr.addLoggingHeaders(bldr, uuid).build();
- assertEquals(uuid.toString(), resp.getHeaderString(BaseRestControllerV1.REQUEST_ID_NAME));
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandlerTest.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandlerTest.java
deleted file mode 100644
index ea2a4a530..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/CambriaMessageBodyHandlerTest.java
+++ /dev/null
@@ -1,146 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * ONAP Policy Models
- * ================================================================================
- * Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import static org.assertj.core.api.Assertions.assertThatThrownBy;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertTrue;
-
-import jakarta.ws.rs.core.MediaType;
-import java.io.ByteArrayInputStream;
-import java.io.EOFException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.nio.charset.StandardCharsets;
-import java.util.List;
-import org.junit.Before;
-import org.junit.Test;
-
-public class CambriaMessageBodyHandlerTest {
- private static final String STD_INPUT = "1.3.XAbc";
- private static final String EXPECTED_OUTPUT = "[Abc]";
-
- private CambriaMessageBodyHandler hdlr;
-
- @Before
- public void setUp() {
- hdlr = new CambriaMessageBodyHandler();
- }
-
- @Test
- public void testIsReadable() {
- assertTrue(hdlr.isReadable(null, null, null, MediaType.valueOf("application/cambria")));
-
- assertFalse(hdlr.isReadable(null, null, null, null));
- assertFalse(hdlr.isReadable(null, null, null, MediaType.valueOf("application/other")));
- assertFalse(hdlr.isReadable(null, null, null, MediaType.valueOf("other/cambria")));
- }
-
- @Test
- public void testReadFrom() throws IOException {
- List<Object> lst = readStream("1.11.AMessageBody", "3.3.123Foo3.3.123Bar", "0.16.You can do that..8.Or that.");
- assertEquals("[MessageBody, Foo, Bar, You can do that., Or that.]", lst.toString());
-
- // empty stream
- lst = readStream();
- assertEquals("[]", lst.toString());
- }
-
- @Test
- public void testReadMessage_InvalidPartitionLength() {
- assertThatThrownBy(() -> readStream("100000000.3.")).isInstanceOf(IOException.class)
- .hasMessage("invalid partition length");
- }
-
- @Test
- public void testReadMessage_InvalidMessageLength() {
- assertThatThrownBy(() -> readStream("3.100000000.ABC")).isInstanceOf(IOException.class)
- .hasMessage("invalid message length");
- }
-
- @Test
- public void testSkipWhitespace() throws IOException {
- // no white space
- assertEquals(EXPECTED_OUTPUT, readStream(STD_INPUT).toString());
-
- // single white space
- assertEquals(EXPECTED_OUTPUT, readStream(" " + STD_INPUT).toString());
-
- // multiple white spaces
- assertEquals(EXPECTED_OUTPUT, readStream("\n\n\t" + STD_INPUT).toString());
- }
-
- @Test
- public void testReadLength_NoDigits() throws IOException {
- assertEquals("[]", readStream("..").toString());
- }
-
- @Test
- public void testReadLength_NoDot() {
- assertThatThrownBy(() -> readStream("3.2")).isInstanceOf(EOFException.class)
- .hasMessage("missing '.' in 'length' field");
- }
-
- @Test
- public void testReadLength_NonDigit() {
- assertThatThrownBy(() -> readStream("3.2x.ABCde")).isInstanceOf(IOException.class)
- .hasMessage("invalid character in 'length' field");
- }
-
- @Test
- public void testReadLength_TooManyDigits() {
- assertThatThrownBy(() -> readStream("3.12345678901234567890.ABCde")).isInstanceOf(IOException.class)
- .hasMessage("too many digits in 'length' field");
- }
-
- @Test
- public void testReadString_ZeroLength() throws IOException {
- assertEquals("[]", readStream("1..X").toString());
- }
-
- @Test
- public void testReadString_TooShort() {
- assertThatThrownBy(() -> readStream(".5.me")).isInstanceOf(EOFException.class).hasMessageContaining("actual");
- }
-
- /**
- * Reads a stream via the handler.
- *
- * @param text lines of text to be read
- * @return the list of objects that were decoded from the stream
- * @throws IOException if an error occurs
- */
- private List<Object> readStream(String... text) throws IOException {
- return hdlr.readFrom(null, null, null, null, null, makeStream(text));
- }
-
- /**
- * Creates an input stream from lines of text.
- *
- * @param text lines of text
- * @return an input stream
- */
- private InputStream makeStream(String... text) {
- return new ByteArrayInputStream(String.join("\n", text).getBytes(StandardCharsets.UTF_8));
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1Test.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1Test.java
deleted file mode 100644
index fd9397e34..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/DmaapSimRestControllerV1Test.java
+++ /dev/null
@@ -1,102 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2021 Bell Canada. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import static org.assertj.core.api.Assertions.assertThat;
-import static org.junit.Assert.assertEquals;
-
-import jakarta.ws.rs.core.Response;
-import java.io.File;
-import java.util.Arrays;
-import java.util.Map;
-import org.junit.Before;
-import org.junit.Test;
-import org.onap.policy.common.utils.coder.Coder;
-import org.onap.policy.common.utils.coder.CoderException;
-import org.onap.policy.common.utils.coder.StandardCoder;
-import org.onap.policy.models.sim.dmaap.parameters.DmaapSimParameterGroup;
-import org.onap.policy.models.sim.dmaap.provider.DmaapSimProvider;
-
-public class DmaapSimRestControllerV1Test {
- private static final int LIMIT = 5;
- private static final String TOPIC = "my-topic";
- private static final String TOPIC2 = "my-topic-B";
- private static final String MESSAGE = "my-message";
- private static final String MESSAGE2 = "my-message-B";
- private static final String CONSUMER = "my-consumer";
- private static final String CONSUMER_ID = "my-id";
-
- private static final Coder coder = new StandardCoder();
-
- private DmaapSimRestControllerV1 rest;
-
- /**
- * Creates the controller.
- *
- * @throws CoderException if the parameters cannot be loaded
- */
- @Before
- public void setUp() throws CoderException {
- DmaapSimParameterGroup params = coder.decode(new File("src/test/resources/parameters/NormalParameters.json"),
- DmaapSimParameterGroup.class);
- DmaapSimProvider.setInstance(new DmaapSimProvider(params));
- rest = new DmaapSimRestControllerV1();
- }
-
- @Test
- public void test() {
- Response resp = rest.getDmaapMessage(TOPIC, CONSUMER, CONSUMER_ID, LIMIT, 0);
- assertEquals(Response.Status.OK.getStatusCode(), resp.getStatus());
- assertEquals("[]", resp.getEntity().toString());
-
- // add some messages
- resp = rest.postDmaapMessage(TOPIC, Arrays.asList(MESSAGE, MESSAGE2));
- assertEquals(Response.Status.OK.getStatusCode(), resp.getStatus());
- assertEquals(2, getCount(resp));
-
- resp = rest.postDmaapMessage(TOPIC2, Arrays.asList(MESSAGE, MESSAGE2, MESSAGE));
- assertEquals(Response.Status.OK.getStatusCode(), resp.getStatus());
- assertEquals(3, getCount(resp));
-
- // hadn't registered with topic 2 so nothing expected from there
- resp = rest.getDmaapMessage(TOPIC2, CONSUMER, CONSUMER_ID, LIMIT, 0);
- assertEquals(Response.Status.OK.getStatusCode(), resp.getStatus());
- assertEquals("[]", resp.getEntity().toString());
-
- // now read from topic 1
- resp = rest.getDmaapMessage(TOPIC, CONSUMER, CONSUMER_ID, LIMIT, 0);
- assertEquals(Response.Status.OK.getStatusCode(), resp.getStatus());
- assertEquals("[my-message, my-message-B]", resp.getEntity().toString());
-
- // verify getDmaapTopics
- resp = rest.getDmaapTopics();
- assertEquals(Response.Status.OK.getStatusCode(), resp.getStatus());
- assertThat(resp.getEntity().toString()).contains("POLICY-PDP-PAP");
- }
-
- private int getCount(Response resp) {
- @SuppressWarnings("unchecked")
- Map<String, Object> map = (Map<String, Object>) resp.getEntity();
-
- return (int) map.get("count");
- }
-
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandlerTest.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandlerTest.java
deleted file mode 100644
index 50db94e5c..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/models/sim/dmaap/rest/TextMessageBodyHandlerTest.java
+++ /dev/null
@@ -1,82 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * Modifications Copyright (C) 2023 Nordix Foundation.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.models.sim.dmaap.rest;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertTrue;
-
-import jakarta.ws.rs.core.MediaType;
-import java.io.ByteArrayInputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import java.nio.charset.StandardCharsets;
-import java.util.List;
-import org.junit.Before;
-import org.junit.Test;
-
-public class TextMessageBodyHandlerTest {
- private TextMessageBodyHandler hdlr;
-
- @Before
- public void setUp() {
- hdlr = new TextMessageBodyHandler();
- }
-
- @Test
- public void testIsReadable() {
- assertTrue(hdlr.isReadable(null, null, null, MediaType.valueOf("text/plain")));
-
- assertFalse(hdlr.isReadable(null, null, null, null));
- assertFalse(hdlr.isReadable(null, null, null, MediaType.valueOf("text/other")));
- assertFalse(hdlr.isReadable(null, null, null, MediaType.valueOf("other/plain")));
- }
-
- @Test
- public void testReadFrom() throws IOException {
- List<Object> lst = readStream("hello", "world");
- assertEquals("[hello, world]", lst.toString());
-
- // empty stream
- lst = readStream();
- assertEquals("[]", lst.toString());
- }
-
- /**
- * Reads a stream via the handler.
- *
- * @param text lines of text to be read
- * @return the list of objects that were decoded from the stream
- * @throws IOException if an error occurs
- */
- private List<Object> readStream(String... text) throws IOException {
- return hdlr.readFrom(null, null, null, null, null, makeStream(text));
- }
-
- /**
- * Creates an input stream from lines of text.
- *
- * @param text lines of text
- * @return an input stream
- */
- private InputStream makeStream(String... text) {
- return new ByteArrayInputStream(String.join("\n", text).getBytes(StandardCharsets.UTF_8));
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/sim/dmaap/parameters/DmaapSimParameterGroupTest.java b/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/sim/dmaap/parameters/DmaapSimParameterGroupTest.java
deleted file mode 100644
index 828cd89b0..000000000
--- a/models-sim/models-sim-dmaap/src/test/java/org/onap/policy/sim/dmaap/parameters/DmaapSimParameterGroupTest.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/*-
- * ============LICENSE_START=======================================================
- * Copyright (C) 2019 AT&T Intellectual Property. All rights reserved.
- * ================================================================================
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- * ============LICENSE_END=========================================================
- */
-
-package org.onap.policy.sim.dmaap.parameters;
-
-import static org.junit.Assert.assertEquals;
-
-import org.junit.Test;
-import org.onap.policy.models.sim.dmaap.parameters.DmaapSimParameterGroup;
-
-public class DmaapSimParameterGroupTest {
- private static final String MY_NAME = "my-name";
-
- @Test
- public void testDmaapSimParameterGroup() {
- DmaapSimParameterGroup params = new DmaapSimParameterGroup(MY_NAME);
- assertEquals(MY_NAME, params.getName());
- }
-}
diff --git a/models-sim/models-sim-dmaap/src/test/resources/logback-test.xml b/models-sim/models-sim-dmaap/src/test/resources/logback-test.xml
deleted file mode 100644
index de7ef98da..000000000
--- a/models-sim/models-sim-dmaap/src/test/resources/logback-test.xml
+++ /dev/null
@@ -1,54 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
- ============LICENSE_START=======================================================
- Copyright (C) 2019 Nordix Foundation.
- ================================================================================
- Licensed under the Apache License, Version 2.0 (the "License");
- you may not use this file except in compliance with the License.
- You may obtain a copy of the License at
-
- http://www.apache.org/licenses/LICENSE-2.0
-
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
-
- SPDX-License-Identifier: Apache-2.0
- ============LICENSE_END=========================================================
--->
-
-<configuration>
-
- <contextName>DMaaPSim</contextName>
- <statusListener class="ch.qos.logback.core.status.OnConsoleStatusListener" />
- <property name="LOG_DIR" value="${java.io.tmpdir}/pf_logging/" />
-
- <!-- USE FOR STD OUT ONLY -->
- <appender name="STDOUT" class="ch.qos.logback.core.ConsoleAppender">
- <encoder>
- <Pattern>%d %contextName [%t] %level %logger{36} - %msg%n</Pattern>
- </encoder>
- </appender>
-
- <root level="info">
- <appender-ref ref="STDOUT" />
- </root>
-
- <appender name="FILE" class="ch.qos.logback.core.rolling.RollingFileAppender">
- <file>${LOG_DIR}/apex.log</file>
- <encoder>
- <pattern>%d %-5relative [procId=${processId}] [%thread] %-5level
- %logger{26} - %msg %n %ex{full}</pattern>
- </encoder>
- </appender>
-
- <logger name="org.eclipse.jetty" level="info" additivity="false">
- <appender-ref ref="STDOUT" />
- </logger>
-
- <logger name="org.onap.policy.models.sim.dmaap" level="trace" additivity="false">
- <appender-ref ref="STDOUT" />
- </logger>
-</configuration>
diff --git a/models-sim/models-sim-dmaap/src/test/resources/parameters/NormalParameters.json b/models-sim/models-sim-dmaap/src/test/resources/parameters/NormalParameters.json
deleted file mode 100644
index deec966e8..000000000
--- a/models-sim/models-sim-dmaap/src/test/resources/parameters/NormalParameters.json
+++ /dev/null
@@ -1,8 +0,0 @@
-{
- "name": "DMaapSim",
- "topicSweepSec": 300,
- "restServerParameters": {
- "host": "0.0.0.0",
- "port": 6845
- }
-}