Java 17 Upgrade
[policy/models.git] / models-interactions / model-actors / actorServiceProvider / src / main / java / org / onap / policy / controlloop / actorserviceprovider / impl / HttpOperation.java
index c4bf5f4..1e11bce 100644 (file)
@@ -2,7 +2,8 @@
  * ============LICENSE_START=======================================================
  * ONAP
  * ================================================================================
- * Copyright (C) 2020 AT&T Intellectual Property. All rights reserved.
+ * Copyright (C) 2020-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.
 
 package org.onap.policy.controlloop.actorserviceprovider.impl;
 
+import jakarta.ws.rs.client.InvocationCallback;
+import jakarta.ws.rs.core.Response;
 import java.util.HashMap;
+import java.util.List;
 import java.util.Map;
 import java.util.concurrent.CompletableFuture;
-import java.util.concurrent.Executor;
 import java.util.concurrent.Future;
+import java.util.concurrent.TimeUnit;
 import java.util.function.Function;
-import javax.ws.rs.client.InvocationCallback;
-import javax.ws.rs.core.Response;
 import lombok.Getter;
 import org.onap.policy.common.endpoints.event.comm.Topic.CommInfrastructure;
 import org.onap.policy.common.endpoints.http.client.HttpClient;
 import org.onap.policy.common.endpoints.utils.NetLoggerUtil;
 import org.onap.policy.common.endpoints.utils.NetLoggerUtil.EventType;
-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.controlloop.actorserviceprovider.OperationOutcome;
+import org.onap.policy.controlloop.actorserviceprovider.OperationResult;
 import org.onap.policy.controlloop.actorserviceprovider.parameters.ControlLoopOperationParams;
+import org.onap.policy.controlloop.actorserviceprovider.parameters.HttpConfig;
 import org.onap.policy.controlloop.actorserviceprovider.parameters.HttpParams;
+import org.onap.policy.controlloop.actorserviceprovider.parameters.HttpPollingConfig;
 import org.onap.policy.controlloop.actorserviceprovider.pipeline.PipelineControllerFuture;
-import org.onap.policy.controlloop.policy.PolicyResult;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -52,38 +54,87 @@ import org.slf4j.LoggerFactory;
 @Getter
 public abstract class HttpOperation<T> extends OperationPartial {
     private static final Logger logger = LoggerFactory.getLogger(HttpOperation.class);
-    private static final Coder coder = new StandardCoder();
 
     /**
-     * Operator that created this operation.
+     * Response status.
      */
-    protected final HttpOperator operator;
+    public enum Status {
+        SUCCESS, FAILURE, STILL_WAITING
+    }
+
+    /**
+     * Configuration for this operation.
+     */
+    private final HttpConfig config;
 
     /**
      * Response class.
      */
     private final Class<T> responseClass;
 
+    /**
+     * {@code True} to use polling, {@code false} otherwise.
+     */
+    @Getter
+    private boolean usePolling;
+
+    /**
+     * Number of polls issued so far, on the current operation attempt.
+     */
+    @Getter
+    private int pollCount;
+
 
     /**
      * Constructs the object.
      *
      * @param params operation parameters
-     * @param operator operator that created this operation
+     * @param config configuration for this operation
      * @param clazz response class
+     * @param propertyNames names of properties required by this operation
      */
-    public HttpOperation(ControlLoopOperationParams params, HttpOperator operator, Class<T> clazz) {
-        super(params, operator);
-        this.operator = operator;
+    protected HttpOperation(ControlLoopOperationParams params, HttpConfig config, Class<T> clazz,
+                    List<String> propertyNames) {
+        super(params, config, propertyNames);
+        this.config = config;
         this.responseClass = clazz;
     }
 
+    /**
+     * Indicates that polling should be used.
+     */
+    protected void setUsePolling() {
+        if (!(config instanceof HttpPollingConfig)) {
+            throw new IllegalStateException("cannot poll without polling parameters");
+        }
+
+        usePolling = true;
+    }
+
+    public HttpClient getClient() {
+        return config.getClient();
+    }
+
+    /**
+     * Gets the path to be used when performing the request; this is typically appended to
+     * the base URL. This method simply invokes {@link #getPath()}.
+     *
+     * @return the path URI suffix
+     */
+    public String getPath() {
+        return config.getPath();
+    }
+
+    public long getTimeoutMs() {
+        return config.getTimeoutMs();
+    }
+
     /**
      * If no timeout is specified, then it returns the operator's configured timeout.
      */
     @Override
     protected long getTimeoutMs(Integer timeoutSec) {
-        return (timeoutSec == null || timeoutSec == 0 ? operator.getTimeoutMs() : super.getTimeoutMs(timeoutSec));
+        return (timeoutSec == null || timeoutSec == 0 ? getTimeoutMs() : super.getTimeoutMs(timeoutSec));
     }
 
     /**
@@ -96,24 +147,25 @@ public abstract class HttpOperation<T> extends OperationPartial {
     }
 
     /**
-     * Gets the path to be used when performing the request; this is typically appended to
-     * the base URL. This method simply invokes {@link #getPath()}.
+     * Makes the URL to which the HTTP request should be posted. This is primarily used
+     * for logging purposes. This particular method returns the base URL appended with the
+     * return value from {@link #getPath()}.
      *
-     * @return the path URI suffix
+     * @return the URL to which from which to get
      */
-    public String makePath() {
-        return operator.getPath();
+    public String getUrl() {
+        return (getClient().getBaseUrl() + getPath());
     }
 
     /**
-     * Makes the URL to which the "get" request should be posted. This ir primarily used
-     * for logging purposes. This particular method returns the base URL appended with the
-     * return value from {@link #makePath()}.
+     * Resets the polling count
      *
-     * @return the URL to which from which to get
+     * <p/>
+     * Note: This should be invoked at the start of each operation (i.e., in
+     * {@link #startOperationAsync(int, OperationOutcome)}.
      */
-    public String makeUrl() {
-        return (operator.getClient().getBaseUrl() + makePath());
+    protected void resetPollCount() {
+        pollCount = 0;
     }
 
     /**
@@ -130,7 +182,7 @@ public abstract class HttpOperation<T> extends OperationPartial {
 
         final PipelineControllerFuture<OperationOutcome> controller = new PipelineControllerFuture<>();
         final CompletableFuture<Response> future = new CompletableFuture<>();
-        final Executor executor = params.getExecutor();
+        final var executor = params.getExecutor();
 
         // arrange for the callback to complete "future"
         InvocationCallback<Response> callback = new InvocationCallback<>() {
@@ -151,136 +203,189 @@ public abstract class HttpOperation<T> extends OperationPartial {
         controller.add(requester.apply(callback));
 
         // once "future" completes, process the response, and then complete the controller
-        future.thenApplyAsync(response -> processResponse(outcome, url, response), executor)
+        future.thenComposeAsync(response -> processResponse(outcome, url, response), executor)
                         .whenCompleteAsync(controller.delayedComplete(), executor);
 
         return controller;
     }
 
     /**
-     * Processes a response. This method simply sets the outcome to SUCCESS.
+     * Processes a response. This method decodes the response, sets the outcome based on
+     * the response, and then returns a completed future.
      *
      * @param outcome outcome to be populate
      * @param url URL to which to request was sent
-     * @param response raw response to process
-     * @return the outcome
+     * @param rawResponse raw response to process
+     * @return a future to cancel or await the outcome
      */
-    protected OperationOutcome processResponse(OperationOutcome outcome, String url, Response rawResponse) {
+    protected CompletableFuture<OperationOutcome> processResponse(OperationOutcome outcome, String url,
+                    Response rawResponse) {
 
         logger.info("{}.{}: response received for {}", params.getActor(), params.getOperation(), params.getRequestId());
 
-        String strResponse = HttpClient.getBody(rawResponse, String.class);
+        String strResponse = rawResponse.readEntity(String.class);
 
-        logRestResponse(url, strResponse);
+        logMessage(EventType.IN, CommInfrastructure.REST, url, strResponse);
 
         T response;
         if (responseClass == String.class) {
             response = responseClass.cast(strResponse);
-
         } else {
             try {
-                response = makeCoder().decode(strResponse, responseClass);
+                response = getCoder().decode(strResponse, responseClass);
             } catch (CoderException e) {
-                logger.warn("{}.{} cannot decode response with http error code {} for {}", params.getActor(),
-                                params.getOperation(), rawResponse.getStatus(), params.getRequestId(), e);
-                return setOutcome(outcome, PolicyResult.FAILURE_EXCEPTION);
+                logger.warn("{}.{} cannot decode response for {}", params.getActor(), params.getOperation(),
+                                params.getRequestId(), e);
+                throw new IllegalArgumentException("cannot decode response");
             }
         }
 
         if (!isSuccess(rawResponse, response)) {
             logger.info("{}.{} request failed with http error code {} for {}", params.getActor(), params.getOperation(),
                             rawResponse.getStatus(), params.getRequestId());
-            return setOutcome(outcome, PolicyResult.FAILURE);
+            return CompletableFuture.completedFuture(
+                    setOutcome(outcome, OperationResult.FAILURE, rawResponse, response));
         }
 
         logger.info("{}.{} request succeeded for {}", params.getActor(), params.getOperation(), params.getRequestId());
-        setOutcome(outcome, PolicyResult.SUCCESS);
-        postProcessResponse(outcome, url, rawResponse, response);
-
-        return outcome;
+        setOutcome(outcome, OperationResult.SUCCESS, rawResponse, response);
+        return postProcessResponse(outcome, url, rawResponse, response);
     }
 
     /**
-     * Processes a successful response.
+     * Sets an operation's outcome and default message based on the result.
      *
-     * @param outcome outcome to be populate
-     * @param url URL to which to request was sent
+     * @param outcome operation to be updated
+     * @param result result of the operation
      * @param rawResponse raw response
      * @param response decoded response
+     * @return the updated operation
      */
-    protected void postProcessResponse(OperationOutcome outcome, String url, Response rawResponse, T response) {
-        // do nothing
+    public OperationOutcome setOutcome(OperationOutcome outcome, OperationResult result, Response rawResponse,
+                    T response) {
+
+        outcome.setResponse(response);
+        return setOutcome(outcome, result);
     }
 
     /**
-     * Determines if the response indicates success. This method simply checks the HTTP
-     * status code.
+     * Processes a successful response. This method simply returns the outcome wrapped in
+     * a completed future.
      *
+     * @param outcome outcome to be populate
+     * @param url URL to which to request was sent
      * @param rawResponse raw response
      * @param response decoded response
-     * @return {@code true} if the response indicates success, {@code false} otherwise
+     * @return a future to cancel or await the outcome
      */
-    protected boolean isSuccess(Response rawResponse, T response) {
-        return (rawResponse.getStatus() == 200);
+    protected CompletableFuture<OperationOutcome> postProcessResponse(OperationOutcome outcome, String url,
+                    Response rawResponse, T response) {
+
+        if (!usePolling) {
+            // doesn't use polling - just return the completed future
+            return CompletableFuture.completedFuture(outcome);
+        }
+
+        HttpPollingConfig cfg = (HttpPollingConfig) config;
+
+        switch (detmStatus(rawResponse, response)) {
+            case SUCCESS -> {
+                logger.info("{}.{} request succeeded for {}", params.getActor(), params.getOperation(),
+                    params.getRequestId());
+                return CompletableFuture
+                    .completedFuture(setOutcome(outcome, OperationResult.SUCCESS, rawResponse, response));
+            }
+            case FAILURE -> {
+                logger.info("{}.{} request failed for {}", params.getActor(), params.getOperation(),
+                    params.getRequestId());
+                return CompletableFuture
+                    .completedFuture(setOutcome(outcome, OperationResult.FAILURE, rawResponse, response));
+            }
+            default -> logger.info("{}.{} request incomplete for {}", params.getActor(), params.getOperation(),
+                params.getRequestId());
+        }
+
+        // still incomplete
+
+        // see if the limit for the number of polls has been reached
+        if (pollCount++ >= cfg.getMaxPolls()) {
+            logger.warn("{}: exceeded 'poll' limit {} for {}", getFullName(), cfg.getMaxPolls(),
+                            params.getRequestId());
+            setOutcome(outcome, OperationResult.FAILURE_TIMEOUT);
+            return CompletableFuture.completedFuture(outcome);
+        }
+
+        // sleep and then poll
+        Function<Void, CompletableFuture<OperationOutcome>> doPoll = unused -> issuePoll(outcome);
+        return sleep(getPollWaitMs(), TimeUnit.MILLISECONDS).thenComposeAsync(doPoll);
     }
 
     /**
-     * Logs a REST request. If the request is not of type, String, then it attempts to
-     * pretty-print it into JSON before logging.
+     * Polls to see if the original request is complete. This method polls using an HTTP
+     * "get" request whose URL is constructed by appending the extracted "poll ID" to the
+     * poll path from the configuration data.
      *
-     * @param url request URL
-     * @param request request to be logged
+     * @param outcome outcome to be populated with the response
+     * @return a future that can be used to cancel the poll or await its response
      */
-    public <Q> void logRestRequest(String url, Q request) {
-        String json;
-        try {
-            if (request == null) {
-                json = null;
-            } else if (request instanceof String) {
-                json = request.toString();
-            } else {
-                json = makeCoder().encode(request, true);
-            }
+    protected CompletableFuture<OperationOutcome> issuePoll(OperationOutcome outcome) {
+        String path = getPollingPath();
+        String url = getClient().getBaseUrl() + path;
 
-        } catch (CoderException e) {
-            logger.warn("cannot pretty-print request", e);
-            json = request.toString();
-        }
+        logger.debug("{}: 'poll' count {} for {}", getFullName(), pollCount, params.getRequestId());
+
+        logMessage(EventType.OUT, CommInfrastructure.REST, url, null);
+
+        return handleResponse(outcome, url, callback -> getClient().get(callback, path, null));
+    }
 
-        NetLoggerUtil.log(EventType.OUT, CommInfrastructure.REST, url, json);
-        logger.info("[OUT|{}|{}|]{}{}", CommInfrastructure.REST, url, NetLoggerUtil.SYSTEM_LS, json);
+    /**
+     * Determines the status of the response. This particular method simply throws an
+     * exception.
+     *
+     * @param rawResponse raw response
+     * @param response decoded response
+     * @return the status of the response
+     */
+    protected Status detmStatus(Response rawResponse, T response) {
+        throw new UnsupportedOperationException("cannot determine response status");
     }
 
     /**
-     * Logs a REST response. If the response is not of type, String, then it attempts to
-     * pretty-print it into JSON before logging.
+     * Gets the URL to use when polling. Typically, this is some unique ID appended to the
+     * polling path found within the configuration data. This particular method simply
+     * returns the polling path from the configuration data.
      *
-     * @param url request URL
-     * @param response response to be logged
+     * @return the URL to use when polling
      */
-    public <S> void logRestResponse(String url, S response) {
-        String json;
-        try {
-            if (response == null) {
-                json = null;
-            } else if (response instanceof String) {
-                json = response.toString();
-            } else {
-                json = makeCoder().encode(response, true);
-            }
+    protected String getPollingPath() {
+        return ((HttpPollingConfig) config).getPollPath();
+    }
 
-        } catch (CoderException e) {
-            logger.warn("cannot pretty-print response", e);
-            json = response.toString();
-        }
+    /**
+     * Determines if the response indicates success. This method simply checks the HTTP
+     * status code.
+     *
+     * @param rawResponse raw response
+     * @param response decoded response
+     * @return {@code true} if the response indicates success, {@code false} otherwise
+     */
+    protected boolean isSuccess(Response rawResponse, T response) {
+        return (rawResponse.getStatus() == 200);
+    }
 
-        NetLoggerUtil.log(EventType.IN, CommInfrastructure.REST, url, json);
-        logger.info("[IN|{}|{}|]{}{}", CommInfrastructure.REST, url, NetLoggerUtil.SYSTEM_LS, json);
+    @Override
+    public <Q> String logMessage(EventType direction, CommInfrastructure infra, String sink, Q request) {
+        String json = super.logMessage(direction, infra, sink, request);
+        NetLoggerUtil.log(direction, infra, sink, json);
+        return json;
     }
 
     // these may be overridden by junit tests
 
-    protected Coder makeCoder() {
-        return coder;
+    protected long getPollWaitMs() {
+        HttpPollingConfig cfg = (HttpPollingConfig) config;
+
+        return TimeUnit.MILLISECONDS.convert(cfg.getPollWaitSec(), TimeUnit.SECONDS);
     }
 }