Removed redundant timeout handling for executeCommand
[ccsdk/cds.git] / ms / blueprintsprocessor / functions / python-executor / src / main / kotlin / org / onap / ccsdk / cds / blueprintsprocessor / functions / python / executor / ComponentRemotePythonExecutor.kt
index d4c8841..5f6d98f 100644 (file)
@@ -1,5 +1,6 @@
 /*
  *  Copyright Â© 2019 IBM.
+ *  Modifications Copyright © 2020 Bell Canada.
  *
  *  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.ccsdk.cds.blueprintsprocessor.functions.python.executor
 
 import com.fasterxml.jackson.databind.JsonNode
-import kotlinx.coroutines.GlobalScope
-import kotlinx.coroutines.TimeoutCancellationException
-import kotlinx.coroutines.async
-import kotlinx.coroutines.withTimeout
-import org.onap.ccsdk.cds.blueprintsprocessor.core.BluePrintPropertiesService
+import com.google.protobuf.ByteString
+import org.onap.ccsdk.cds.blueprintsprocessor.core.BlueprintPropertiesService
 import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.ExecutionServiceInput
 import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.PrepareRemoteEnvInput
 import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.RemoteIdentifier
 import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.RemoteScriptExecutionInput
+import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.RemoteScriptExecutionOutput
+import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.RemoteScriptUploadBlueprintInput
 import org.onap.ccsdk.cds.blueprintsprocessor.core.api.data.StatusType
+import org.onap.ccsdk.cds.blueprintsprocessor.db.primary.repository.BlueprintModelRepository
 import org.onap.ccsdk.cds.blueprintsprocessor.services.execution.AbstractComponentFunction
 import org.onap.ccsdk.cds.blueprintsprocessor.services.execution.ExecutionServiceConstant
 import org.onap.ccsdk.cds.blueprintsprocessor.services.execution.RemoteScriptExecutionService
-import org.onap.ccsdk.cds.controllerblueprints.core.BluePrintProcessorException
+import org.onap.ccsdk.cds.controllerblueprints.core.BlueprintProcessorException
 import org.onap.ccsdk.cds.controllerblueprints.core.asJsonPrimitive
+import org.onap.ccsdk.cds.controllerblueprints.core.asJsonType
 import org.onap.ccsdk.cds.controllerblueprints.core.checkFileExists
 import org.onap.ccsdk.cds.controllerblueprints.core.checkNotBlank
 import org.onap.ccsdk.cds.controllerblueprints.core.data.OperationAssignment
@@ -50,12 +52,14 @@ import org.springframework.stereotype.Component
 @Scope(value = ConfigurableBeanFactory.SCOPE_PROTOTYPE)
 open class ComponentRemotePythonExecutor(
     private val remoteScriptExecutionService: RemoteScriptExecutionService,
-    private var bluePrintPropertiesService: BluePrintPropertiesService
+    private val bluePrintPropertiesService: BlueprintPropertiesService,
+    private val blueprintModelRepository: BlueprintModelRepository
 ) : AbstractComponentFunction() {
 
     private val log = LoggerFactory.getLogger(ComponentRemotePythonExecutor::class.java)!!
 
     companion object {
+
         const val SELECTOR_CMD_EXEC = "blueprintsprocessor.remote-script-command"
         const val INPUT_ENDPOINT_SELECTOR = "endpoint-selector"
         const val INPUT_DYNAMIC_PROPERTIES = "dynamic-properties"
@@ -75,6 +79,8 @@ open class ComponentRemotePythonExecutor(
         const val ATTRIBUTE_RESPONSE_DATA = "response-data"
         const val DEFAULT_ENV_PREPARE_TIMEOUT_IN_SEC = 120
         const val DEFAULT_EXECUTE_TIMEOUT_IN_SEC = 180
+        const val TIMEOUT_DELTA = 100L
+        const val DEFAULT_CBA_UPLOAD_TIMEOUT_IN_SEC = 30
     }
 
     override suspend fun processNB(executionRequest: ExecutionServiceInput) {
@@ -87,11 +93,21 @@ open class ComponentRemotePythonExecutor(
         val blueprintName = bluePrintContext.name()
         val blueprintVersion = bluePrintContext.version()
 
+        // fetch the template (plus cba bindata) from repository
+        val cbaModel = blueprintModelRepository.findByArtifactNameAndArtifactVersion(blueprintName, blueprintVersion)
+        val blueprintUUID = cbaModel?.id!!
+        val cbaBinData = ByteString.copyFrom(cbaModel?.blueprintModelContent?.content)
+        val archiveType = cbaModel?.blueprintModelContent?.contentType // TODO: should be enum
+        val remoteIdentifier = RemoteIdentifier(blueprintName = blueprintName, blueprintVersion = blueprintVersion, blueprintUUID = blueprintUUID)
+        val originatorId = executionServiceInput.commonHeader.originatorId
+        val subRequestId = executionServiceInput.commonHeader.subRequestId
+        val requestId = processId
+
         val operationAssignment: OperationAssignment = bluePrintContext
             .nodeTemplateInterfaceOperation(nodeTemplateName, interfaceName, operationName)
 
         val artifactName: String = operationAssignment.implementation?.primary
-            ?: throw BluePrintProcessorException("missing primary field to get artifact name for node template ($nodeTemplateName)")
+            ?: throw BlueprintProcessorException("missing primary field to get artifact name for node template ($nodeTemplateName)")
 
         val artifactDefinition =
             bluePrintRuntimeService.resolveNodeTemplateArtifactDefinition(nodeTemplateName, artifactName)
@@ -104,15 +120,14 @@ open class ComponentRemotePythonExecutor(
 
         val endPointSelector = getOperationInput(INPUT_ENDPOINT_SELECTOR)
         val dynamicProperties = getOptionalOperationInput(INPUT_DYNAMIC_PROPERTIES)
-        val packages = getOptionalOperationInput(INPUT_PACKAGES)?.returnNullIfMissing()
-
-        val argsNode = getOptionalOperationInput(INPUT_ARGUMENT_PROPERTIES)?.returnNullIfMissing()
+        var packages = getOptionalOperationInput(INPUT_PACKAGES)?.returnNullIfMissing()
 
         // This prevents unescaping values, as well as quoting the each parameter, in order to allow for spaces in values
         val args = getOptionalOperationInput(INPUT_ARGUMENT_PROPERTIES)?.returnNullIfMissing()
             ?.rootFieldsToMap()?.toSortedMap()?.values?.joinToString(" ") { formatNestedJsonNode(it) }
 
         val command = getOperationInput(INPUT_COMMAND).asText()
+        val cbaNameVerUuid = "blueprintName($blueprintName) blueprintVersion($blueprintVersion) blueprintUUID($blueprintUUID)"
 
         /**
          * Timeouts that are specific to the command executor.
@@ -123,7 +138,10 @@ open class ComponentRemotePythonExecutor(
         val executionTimeout = getOptionalOperationInput(INPUT_EXECUTE_TIMEOUT)?.asInt()
             ?: DEFAULT_EXECUTE_TIMEOUT_IN_SEC
 
-        var scriptCommand = command.replace(pythonScript.name, pythonScript.absolutePath)
+        // component level timeout should be => env_prep_timeout + execution_timeout
+        val timeout = implementation.timeout
+
+        var scriptCommand = command.replace(pythonScript.name, artifactDefinition.file)
         if (args != null && args.isNotEmpty()) {
             scriptCommand = scriptCommand.plus(" ").plus(args)
         }
@@ -139,124 +157,151 @@ open class ComponentRemotePythonExecutor(
             }
 
             // If packages are defined, then install in remote server
-            if (packages != null) {
-                val prepareEnvInput = PrepareRemoteEnvInput(
-                    requestId = processId,
-                    remoteIdentifier = RemoteIdentifier(
-                        blueprintName = blueprintName,
-                        blueprintVersion = blueprintVersion),
-                    packages = packages,
-                    timeOut = envPrepTimeout.toLong()
-
-                )
-                val prepareEnvOutput = remoteScriptExecutionService.prepareEnv(prepareEnvInput)
-                log.info("$ATTRIBUTE_PREPARE_ENV_LOG - ${prepareEnvOutput.response}")
-                val logs = JacksonUtils.jsonNodeFromObject(prepareEnvOutput.response)
-                val logsEnv = logs.toString().asJsonPrimitive()
-                setAttribute(ATTRIBUTE_PREPARE_ENV_LOG, logsEnv)
-
-                if (prepareEnvOutput.status != StatusType.SUCCESS) {
-                    val errorMessage = prepareEnvOutput.payload
-                    setNodeOutputErrors(prepareEnvOutput.status.name,
-                            STEP_PREPARE_ENV,
-                            logs,
-                            errorMessage,
-                            isLogResponseEnabled
-                    )
-                } else {
-                    setNodeOutputProperties(prepareEnvOutput.status.name.asJsonPrimitive(),
-                            STEP_PREPARE_ENV,
-                            logsEnv,
-                            "".asJsonPrimitive(),
-                            isLogResponseEnabled
-                    )
-                }
-            } else {
+            if (packages == null) {
                 // set env preparation log to empty...
                 setAttribute(ATTRIBUTE_PREPARE_ENV_LOG, "".asJsonPrimitive())
+                packages = mutableListOf<Object>().asJsonType()
             }
+            prepareEnv(originatorId, requestId, subRequestId, remoteIdentifier, packages, envPrepTimeout, cbaNameVerUuid, archiveType, cbaBinData, isLogResponseEnabled)
+            // in cases where the exception is caught in BP side due to timeout, we do not have `err_msg` returned by cmd-exec (inside `payload`),
+            // hence `artifact` field will be empty
         } catch (grpcEx: io.grpc.StatusRuntimeException) {
-            val grpcErrMsg = "Command failed during env. preparation... timeout($envPrepTimeout) requestId ($processId)."
+            val componentLevelWarningMsg =
+                if (timeout < envPrepTimeout) "Note: component-level timeout ($timeout) is shorter than env-prepare timeout ($envPrepTimeout). " else ""
+            val grpcErrMsg =
+                "Command failed during env. preparation... timeout($envPrepTimeout) requestId ($processId).$componentLevelWarningMsg grpcError: (${grpcEx.cause?.message})"
+            // no execution log in case of timeout (as cmd-exec side hasn't finished to transfer output)
+            // set prepare-env-log to the error msg, and cmd-exec-log to empty
             setAttribute(ATTRIBUTE_PREPARE_ENV_LOG, grpcErrMsg.asJsonPrimitive())
-            setNodeOutputErrors(status = grpcErrMsg, step = STEP_PREPARE_ENV, error = "${grpcEx.status}".asJsonPrimitive(), logging = isLogResponseEnabled)
+            setNodeOutputErrors(STEP_PREPARE_ENV, "[]".asJsonPrimitive(), "{}".asJsonPrimitive(), isLogResponseEnabled)
+            addError(StatusType.FAILURE.name, STEP_PREPARE_ENV, grpcErrMsg)
             log.error(grpcErrMsg, grpcEx)
-            addError(grpcErrMsg)
         } catch (e: Exception) {
-            val timeoutErrMsg = "Command executor failed during env. preparation.. timeout($envPrepTimeout) requestId ($processId)."
-            setAttribute(ATTRIBUTE_PREPARE_ENV_LOG, e.message.asJsonPrimitive())
-            setNodeOutputErrors(status = timeoutErrMsg, step = STEP_PREPARE_ENV, error = "${e.message}".asJsonPrimitive(), logging = isLogResponseEnabled)
-            log.error("Failed to process on remote executor requestId ($processId)", e)
-            addError(timeoutErrMsg)
+            val catchallErrMsg =
+                "Command executor failed during env. preparation.. catch-all case. timeout($envPrepTimeout) requestId ($processId). exception msg: ${e.message}"
+            // no environment prepare log from executor in case of timeout (as cmd-exec side hasn't finished to transfer output), set it to error msg. Execution logs is empty.
+            setAttribute(ATTRIBUTE_PREPARE_ENV_LOG, catchallErrMsg.asJsonPrimitive())
+            setNodeOutputErrors(STEP_PREPARE_ENV, "[]".asJsonPrimitive(), "{}".asJsonPrimitive(), isLogResponseEnabled)
+            addError(StatusType.FAILURE.name, STEP_PREPARE_ENV, catchallErrMsg)
+            log.error(catchallErrMsg, e)
         }
         // if Env preparation was successful, then proceed with command execution in this Env
-        if (bluePrintRuntimeService.getBluePrintError().errors.isEmpty()) {
+        if (noBlueprintErrors()) {
             try {
                 // Populate command execution properties and pass it to the remote server
                 val properties = dynamicProperties?.returnNullIfMissing()?.rootFieldsToMap() ?: hashMapOf()
 
                 val remoteExecutionInput = RemoteScriptExecutionInput(
+                    originatorId = executionServiceInput.commonHeader.originatorId,
                     requestId = processId,
-                    remoteIdentifier = RemoteIdentifier(blueprintName = blueprintName, blueprintVersion = blueprintVersion),
+                    subRequestId = executionServiceInput.commonHeader.subRequestId,
+                    remoteIdentifier = remoteIdentifier,
                     command = scriptCommand,
                     properties = properties,
-                    timeOut = implementation.timeout.toLong())
+                    timeOut = executionTimeout.toLong()
+                )
 
-                val remoteExecutionOutputDeferred = GlobalScope.async {
-                    remoteScriptExecutionService.executeCommand(remoteExecutionInput)
-                }
-
-                val remoteExecutionOutput = withTimeout(implementation.timeout * 1000L) {
-                    remoteExecutionOutputDeferred.await()
-                }
+                val remoteExecutionOutput = remoteScriptExecutionService.executeCommand(remoteExecutionInput)
 
                 checkNotNull(remoteExecutionOutput) {
-                    "Error: Request-id $processId did not return a restul from remote command execution."
+                    "Error: Request-id $processId did not return a result from remote command execution."
                 }
                 val logs = JacksonUtils.jsonNodeFromObject(remoteExecutionOutput.response)
+                val returnedPayload = remoteExecutionOutput.payload
+                // In case of execution, `payload` (dictionary from Python execution) is preserved in `remoteExecutionOutput.payload`;
+                // It would contain `err_msg` key. It is valid to return it.
                 if (remoteExecutionOutput.status != StatusType.SUCCESS) {
-                    setNodeOutputErrors(remoteExecutionOutput.status.name,
-                            STEP_EXEC_CMD,
-                            logs,
-                            remoteExecutionOutput.payload,
-                            isLogResponseEnabled
-                    )
+                    setNodeOutputErrors(STEP_EXEC_CMD, logs, returnedPayload, isLogResponseEnabled)
+                    addError(StatusType.FAILURE.name, STEP_EXEC_CMD, logs.toString())
                 } else {
-                    setNodeOutputProperties(remoteExecutionOutput.status.name.asJsonPrimitive(),
-                            STEP_EXEC_CMD,
-                            logs,
-                            remoteExecutionOutput.payload,
-                            isLogResponseEnabled
-                    )
-                }
-            } catch (timeoutEx: TimeoutCancellationException) {
-                val timeoutErrMsg = "Command executor timed out executing after $executionTimeout seconds requestId ($processId)"
-                setNodeOutputErrors(status = timeoutErrMsg,
-                        step = STEP_EXEC_CMD,
-                        logs = "".asJsonPrimitive(),
-                        error = "".asJsonPrimitive(),
-                        logging = isLogResponseEnabled
-                )
-                log.error(timeoutErrMsg, timeoutEx)
+                    setNodeOutputProperties(remoteExecutionOutput.status, STEP_EXEC_CMD, logs, returnedPayload, isLogResponseEnabled)
+                } // In timeout exception cases, we don't have payload, hence `payload` is empty value.
             } catch (grpcEx: io.grpc.StatusRuntimeException) {
-                val timeoutErrMsg = "Command executor timed out executing after $executionTimeout seconds requestId ($processId)"
-                setNodeOutputErrors(status = timeoutErrMsg,
-                        step = STEP_EXEC_CMD,
-                        logs = "".asJsonPrimitive(),
-                        error = "".asJsonPrimitive(),
-                        logging = isLogResponseEnabled
-                )
-                log.error("Command executor time out during GRPC call", grpcEx)
+                val componentLevelWarningMsg =
+                    if (timeout < executionTimeout) "Note: component-level timeout ($timeout) is shorter than execution timeout ($executionTimeout). " else ""
+                val timeoutErrMsg =
+                    "Command executor timed out executing after $executionTimeout seconds requestId ($processId). $componentLevelWarningMsg grpcErr: ${grpcEx.status}"
+                setNodeOutputErrors(STEP_EXEC_CMD, listOf(timeoutErrMsg).asJsonType(), logging = isLogResponseEnabled)
+                addError(StatusType.FAILURE.name, STEP_EXEC_CMD, timeoutErrMsg)
+                log.error(timeoutErrMsg, grpcEx)
             } catch (e: Exception) {
-                log.error("Failed to process on remote executor requestId ($processId)", e)
+                val catchAllErrMsg =
+                    "Command executor failed during process catch-all case requestId ($processId) timeout($envPrepTimeout) exception msg: ${e.message}"
+                setNodeOutputErrors(STEP_PREPARE_ENV, listOf(catchAllErrMsg).asJsonType(), logging = isLogResponseEnabled)
+                addError(StatusType.FAILURE.name, STEP_EXEC_CMD, catchAllErrMsg)
+                log.error(catchAllErrMsg, e)
             }
         }
         log.debug("Trying to close GRPC channel. request ($processId)")
         remoteScriptExecutionService.close()
     }
 
+    // wrapper for call to prepare_env step on cmd-exec - reupload CBA and call prepare env again if cmd-exec reported CBA uuid mismatch
+    private suspend fun prepareEnv(originatorId: String, requestId: String, subRequestId: String, remoteIdentifier: RemoteIdentifier, packages: JsonNode, envPrepTimeout: Int, cbaNameVerUuid: String, archiveType: String?, cbaBinData: ByteString?, isLogResponseEnabled: Boolean, retries: Int = 3) {
+        val prepareEnvInput = PrepareRemoteEnvInput(
+            originatorId = originatorId,
+            requestId = requestId,
+            subRequestId = subRequestId,
+            remoteIdentifier = remoteIdentifier,
+            packages = packages,
+            timeOut = envPrepTimeout.toLong()
+        )
+        val prepareEnvOutput = remoteScriptExecutionService.prepareEnv(prepareEnvInput)
+        log.info("$ATTRIBUTE_PREPARE_ENV_LOG - ${prepareEnvOutput.response}")
+        val logs = JacksonUtils.jsonNodeFromObject(prepareEnvOutput.response)
+        setAttribute(ATTRIBUTE_PREPARE_ENV_LOG, logs)
+
+        // there are no artifacts for env. prepare, but we reuse it for err_log...
+        if (prepareEnvOutput.status != StatusType.SUCCESS) {
+            // Check for the flag that blueprint is mismatched first, if so, reupload the blueprint
+            if (prepareEnvOutput.payload.has("reupload_cba")) {
+                log.info("Cmd-exec is missing the CBA $cbaNameVerUuid, it will be reuploaded.")
+                uploadCba(remoteIdentifier, requestId, subRequestId, originatorId, archiveType, cbaBinData, cbaNameVerUuid, prepareEnvOutput, isLogResponseEnabled, logs)
+                // call prepare_env again.
+                if (retries > 0) {
+                    log.info("Calling prepare environment again")
+                    prepareEnv(originatorId, requestId, subRequestId, remoteIdentifier, packages, envPrepTimeout, cbaNameVerUuid, archiveType, cbaBinData, isLogResponseEnabled, retries - 1)
+                } else {
+                    val errMsg = "Something is wrong: prepare_env step attempted to call itself too many times after upload CBA step!"
+                    log.error(errMsg)
+                    setNodeOutputErrors(STEP_PREPARE_ENV, "[]".asJsonPrimitive(), prepareEnvOutput.payload, isLogResponseEnabled)
+                    addError(StatusType.FAILURE.name, STEP_PREPARE_ENV, errMsg)
+                }
+            } else {
+                setNodeOutputErrors(STEP_PREPARE_ENV, "[]".asJsonPrimitive(), prepareEnvOutput.payload, isLogResponseEnabled)
+                addError(StatusType.FAILURE.name, STEP_PREPARE_ENV, logs.toString())
+            }
+        } else {
+            setNodeOutputProperties(prepareEnvOutput.status, STEP_PREPARE_ENV, logs, prepareEnvOutput.payload, isLogResponseEnabled)
+        }
+    }
+
+    private suspend fun uploadCba(remoteIdentifier: RemoteIdentifier, requestId: String, subRequestId: String, originatorId: String, archiveType: String?, cbaBinData: ByteString?, cbaNameVerUuid: String, prepareEnvOutput: RemoteScriptExecutionOutput, isLogResponseEnabled: Boolean, logs: JsonNode) {
+        val uploadCbaInput = RemoteScriptUploadBlueprintInput(
+            remoteIdentifier = remoteIdentifier,
+            requestId = requestId,
+            subRequestId = subRequestId,
+            originatorId = originatorId,
+            timeOut = DEFAULT_CBA_UPLOAD_TIMEOUT_IN_SEC.toLong(),
+            archiveType = archiveType!!,
+            binData = cbaBinData!!
+        )
+
+        val cbaUploadOutput = remoteScriptExecutionService.uploadBlueprint(uploadCbaInput)
+        if (cbaUploadOutput.status != StatusType.SUCCESS) {
+            log.error("Error uploading CBA $cbaNameVerUuid error(${cbaUploadOutput.payload})")
+            setNodeOutputErrors(STEP_PREPARE_ENV, "[]".asJsonPrimitive(), prepareEnvOutput.payload, isLogResponseEnabled)
+            addError(StatusType.FAILURE.name, STEP_PREPARE_ENV, logs.toString())
+        } else {
+            log.info("Finished uploading CBA $cbaNameVerUuid")
+        }
+    }
+
+    private fun noBlueprintErrors() =
+        bluePrintRuntimeService.getBlueprintError().stepErrors(stepName).isNullOrEmpty()
+
     override suspend fun recoverNB(runtimeException: RuntimeException, executionRequest: ExecutionServiceInput) {
-        bluePrintRuntimeService.getBluePrintError()
-            .addError("Failed in ComponentRemotePythonExecutor : ${runtimeException.message}")
+        addError("Failed in ComponentRemotePythonExecutor : ${runtimeException.message}")
     }
 
     private fun formatNestedJsonNode(node: JsonNode): String {
@@ -272,38 +317,43 @@ open class ComponentRemotePythonExecutor(
     /**
      * Utility function to set the output properties of the executor node
      */
-    private fun setNodeOutputProperties(status: JsonNode, step: String, message: JsonNode, artifacts: JsonNode, logging: Boolean = true) {
-        setAttribute(ATTRIBUTE_EXEC_CMD_STATUS, status)
+    private fun setNodeOutputProperties(
+        status: StatusType,
+        step: String,
+        executionLogs: JsonNode,
+        artifacts: JsonNode,
+        logging: Boolean = true
+    ) {
+
+        setAttribute(ATTRIBUTE_EXEC_CMD_STATUS, status.name.asJsonPrimitive())
+        setAttribute(ATTRIBUTE_EXEC_CMD_LOG, executionLogs)
         setAttribute(ATTRIBUTE_RESPONSE_DATA, artifacts)
-        setAttribute(ATTRIBUTE_EXEC_CMD_LOG, message)
 
         if (logging) {
-            log.info("Executor status   : $step : $status")
+            log.info("Executor status : $step : $status")
+            log.info("Executor logs   : $step : $executionLogs")
             log.info("Executor artifacts: $step : $artifacts")
-            log.info("Executor message  : $step : $message")
         }
     }
 
     /**
-     * Utility function to set the output properties and errors of the executor node, in cas of errors
+     * Utility function to set the output properties and errors of the executor node, in case of errors
      */
     private fun setNodeOutputErrors(
-        status: String,
         step: String,
-        logs: JsonNode = "N/A".asJsonPrimitive(),
-        error: JsonNode,
+        executionLogs: JsonNode = "[]".asJsonPrimitive(),
+        artifacts: JsonNode = "{}".asJsonPrimitive(),
         logging: Boolean = true
     ) {
+        val status = StatusType.FAILURE.name
         setAttribute(ATTRIBUTE_EXEC_CMD_STATUS, status.asJsonPrimitive())
-        setAttribute(ATTRIBUTE_EXEC_CMD_LOG, logs)
-        setAttribute(ATTRIBUTE_RESPONSE_DATA, "N/A".asJsonPrimitive())
+        setAttribute(ATTRIBUTE_EXEC_CMD_LOG, executionLogs)
+        setAttribute(ATTRIBUTE_RESPONSE_DATA, artifacts)
 
         if (logging) {
-            log.info("Executor status   : $step : $status")
-            log.info("Executor message  : $step : $error")
-            log.info("Executor logs     : $step : $logs")
+            log.info("Executor status : $step : $status")
+            log.info("Executor logs   : $step : $executionLogs")
+            log.info("Executor artifacts: $step : $artifacts")
         }
-
-        addError(status, step, error.toString())
     }
 }