Search in sources :

Example 1 with InternalComponentException_Exception

use of com.axway.ats.agent.webapp.client.InternalComponentException_Exception in project ats-framework by Axway.

the class DistributedLoadExecutor method waitUntilQueueFinish.

@Override
public void waitUntilQueueFinish() throws AgentException {
    try {
        for (String host : atsAgents) {
            AgentService agentServicePort = AgentServicePool.getInstance().getClient(host);
            log.info("Waiting until action queue '" + queueName + "' finish its execution on agent '" + host + "'");
            //wait until finished on this host
            agentServicePort.waitUntilQueueFinish(queueName);
            log.info("Action queue '" + queueName + "' finished on agent '" + host + "'");
        }
    } catch (AgentException_Exception ae) {
        throw new AgentException(ae.getMessage());
    } catch (InternalComponentException_Exception ice) {
        throw new AgentException(ice.getMessage() + ", check server log for stack trace");
    } catch (Exception e) {
        throw new AgentException(e.getMessage(), e);
    }
}
Also used : AgentService(com.axway.ats.agent.webapp.client.AgentService) AgentException(com.axway.ats.agent.core.exceptions.AgentException) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) InternalComponentException(com.axway.ats.agent.webapp.client.InternalComponentException) AgentException(com.axway.ats.agent.core.exceptions.AgentException) IOException(java.io.IOException) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception)

Example 2 with InternalComponentException_Exception

use of com.axway.ats.agent.webapp.client.InternalComponentException_Exception in project ats-framework by Axway.

the class RemoteExecutor method executeAction.

@Override
public Object executeAction(ActionRequest actionRequest) throws AgentException {
    String actionName = actionRequest.getActionName();
    String componentName = actionRequest.getComponentName();
    Object[] arguments = actionRequest.getArguments();
    Object result = null;
    List<ArgumentWrapper> wrappedArguments = new ArrayList<ArgumentWrapper>();
    try {
        //a byte stream
        for (Object argument : arguments) {
            ArgumentWrapper argWrapper = new ArgumentWrapper();
            ByteArrayOutputStream byteOutStream = new ByteArrayOutputStream();
            ObjectOutputStream objectOutStream = new ObjectOutputStream(byteOutStream);
            objectOutStream.writeObject(argument);
            argWrapper.setArgumentValue(byteOutStream.toByteArray());
            wrappedArguments.add(argWrapper);
        }
    } catch (IOException ioe) {
        throw new AgentException("Could not serialize input arguments", ioe);
    }
    //get the client
    AgentService agentServicePort = AgentServicePool.getInstance().getClient(atsAgent);
    try {
        //FIXME: swap with ActionWrapper
        byte[] resultAsBytes = agentServicePort.executeAction(componentName, actionName, wrappedArguments);
        //the result is returned as serialized stream
        //so we need to deserialize it
        ByteArrayInputStream byteInStream = new ByteArrayInputStream(resultAsBytes);
        ObjectInputStream objectInStream = new ObjectInputStream(byteInStream);
        result = objectInStream.readObject();
    } catch (IOException ioe) {
        throw new AgentException("Could not deserialize returned result from agent at " + atsAgent, ioe);
    } catch (AgentException_Exception ae) {
        throw new AgentException("Error while executing action on agent at " + atsAgent + ". Exception message: " + ae.getMessage());
    } catch (InternalComponentException_Exception ice) {
        //we need to get internal component exception info from the soap fault
        InternalComponentException faultInfo = ice.getFaultInfo();
        //then construct and throw a real InternalComponentException (not the JAXB mapping type above)
        throw new com.axway.ats.agent.core.exceptions.InternalComponentException(faultInfo.getComponentName(), faultInfo.getActionName(), faultInfo.getExceptionMessage() + "\n[" + HostUtils.getLocalHostIP() + " stacktrace]", atsAgent);
    } catch (Exception e) {
        throw new AgentException(e.getMessage(), e);
    }
    return result;
}
Also used : AgentException(com.axway.ats.agent.core.exceptions.AgentException) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) ArrayList(java.util.ArrayList) ArgumentWrapper(com.axway.ats.agent.webapp.client.ArgumentWrapper) ByteArrayOutputStream(java.io.ByteArrayOutputStream) IOException(java.io.IOException) InternalComponentException(com.axway.ats.agent.webapp.client.InternalComponentException) ObjectOutputStream(java.io.ObjectOutputStream) AgentException(com.axway.ats.agent.core.exceptions.AgentException) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) IOException(java.io.IOException) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception) InternalComponentException(com.axway.ats.agent.webapp.client.InternalComponentException) AgentService(com.axway.ats.agent.webapp.client.AgentService) ByteArrayInputStream(java.io.ByteArrayInputStream) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception) ObjectInputStream(java.io.ObjectInputStream)

Example 3 with InternalComponentException_Exception

use of com.axway.ats.agent.webapp.client.InternalComponentException_Exception in project ats-framework by Axway.

the class RemoteExecutor method waitUntilQueueFinish.

@Override
public void waitUntilQueueFinish() throws AgentException {
    /*
         * In real environment, this method is most likely never used
         * as this remote client is used for running a single action, so
         * no performance queues are available.
         *
         * TODO: maybe we can safely throw some error here to say that
         * it is not expected to call this method.
         * Or we can implement an empty body here or in the abstract parent.
         */
    //get the client
    AgentService agentServicePort = AgentServicePool.getInstance().getClient(atsAgent);
    try {
        log.info("Waiting until all queues on host '" + atsAgent + "' finish execution");
        agentServicePort.waitUntilAllQueuesFinish();
    } catch (AgentException_Exception ae) {
        throw new AgentException(ae.getMessage());
    } catch (InternalComponentException_Exception ice) {
        throw new AgentException(ice.getMessage() + ", check server log for stack trace");
    } catch (Exception e) {
        throw new AgentException(e.getMessage(), e);
    }
}
Also used : AgentService(com.axway.ats.agent.webapp.client.AgentService) AgentException(com.axway.ats.agent.core.exceptions.AgentException) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception) AgentException(com.axway.ats.agent.core.exceptions.AgentException) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) IOException(java.io.IOException) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception) InternalComponentException(com.axway.ats.agent.webapp.client.InternalComponentException)

Example 4 with InternalComponentException_Exception

use of com.axway.ats.agent.webapp.client.InternalComponentException_Exception in project ats-framework by Axway.

the class DistributedLoadExecutor method executeActions.

@Override
public void executeActions(List<ActionRequest> actionRequests) throws AgentException {
    //set the block until completion param to false
    //this way we'll be able to start all the loaders on all boxes at the same time
    //and then wait for all of them to finish
    final boolean blockUntilCompletion = threadingPattern.isBlockUntilCompletion();
    threadingPattern.setBlockUntilCompletion(false);
    int maxHostCount = atsAgents.size();
    // distribute the threading pattern for each agent host
    final List<ThreadingPattern> distributedPatterns = threadingPattern.distribute(maxHostCount);
    if (distributedPatterns.size() < maxHostCount) {
        log.warn("Threading pattern cannot be distributed accross all agents, only the first " + distributedPatterns.size() + " agents will execute");
    }
    // distribute the data configurators for each agent host
    final List<LoaderDataConfig> distributedLoaderDataConfigs = loaderDataConfig.distribute(distributedPatterns.size());
    // start queue in the database and retrieve its ID
    int queueId = retrieveQueueId(queueSequence, getHostsList());
    //call the web service now
    try {
        //first schedule the loaders on all hosts
        for (int i = 0; i < distributedPatterns.size(); i++) {
            //serialize the threading pattern - it's easier to pass it to the web service that way
            byte[] serializedThreadingPattern = serializeObject(distributedPatterns.get(i));
            byte[] serializedLoaderDataConfig = serializeObject(distributedLoaderDataConfigs.get(i));
            //wrap all the action requests
            List<ActionWrapper> actionWrappers = new ArrayList<ActionWrapper>();
            for (ActionRequest actionRequest : actionRequests) {
                actionWrappers.add(wrapActionRequest(actionRequest));
            }
            //schedule the actions, but do not execute
            //get the client
            AgentService agentServicePort = AgentServicePool.getInstance().getClient(atsAgents.get(i));
            agentServicePort.scheduleActionsInMultipleThreads(queueName, queueId, actionWrappers, serializedThreadingPattern, serializedLoaderDataConfig, distributedPatterns.get(0).isUseSynchronizedIterations());
        }
        boolean useSynchronizedIterations = distributedPatterns.get(0).isUseSynchronizedIterations();
        if (useSynchronizedIterations && !blockUntilCompletion) {
            // It is non blocking, but synchronized - we have to wait until the queue finish its execution.
            // We first start the queue. This assures the queue is created before the user have the chance
            // to say "wait for completion"
            startSynchedIterations();
            // and then wait in another thread until the queue finish
            ImportantThread helpThread = new ImportantThread(new Runnable() {

                @Override
                public void run() {
                    runSynchedIterations();
                }
            });
            helpThread.setDescription(queueName);
            helpThread.start();
        } else {
            if (useSynchronizedIterations) {
                // it is blocking - we can wait until the queue finish it execution
                startSynchedIterations();
                runSynchedIterations();
            } else {
                // if blocking - we can wait until the queue finish it execution
                // if non blocking - as it is not synchronized, we will wait only until the queue is started
                runNotSynchedIterations(blockUntilCompletion);
            }
        }
    } catch (AgentException_Exception ae) {
        throw new AgentException(ae.getMessage());
    } catch (InternalComponentException_Exception ice) {
        //we need to get internal component exception info from the soap fault
        InternalComponentException faultInfo = ice.getFaultInfo();
        //then construct and throw a real InternalComponentException (not the JAXB mapping type above)
        throw new com.axway.ats.agent.core.exceptions.InternalComponentException(faultInfo.getComponentName(), faultInfo.getActionName(), faultInfo.getExceptionMessage(), faultInfo.getHostIp());
    } catch (Exception e) {
        throw new AgentException(e.getMessage(), e);
    }
    // restore this flag
    threadingPattern.setBlockUntilCompletion(blockUntilCompletion);
}
Also used : AgentException(com.axway.ats.agent.core.exceptions.AgentException) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) ArrayList(java.util.ArrayList) ActionWrapper(com.axway.ats.agent.webapp.client.ActionWrapper) InternalComponentException(com.axway.ats.agent.webapp.client.InternalComponentException) ImportantThread(com.axway.ats.agent.core.threading.ImportantThread) InternalComponentException_Exception(com.axway.ats.agent.webapp.client.InternalComponentException_Exception) InternalComponentException(com.axway.ats.agent.webapp.client.InternalComponentException) AgentException(com.axway.ats.agent.core.exceptions.AgentException) IOException(java.io.IOException) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception) LoaderDataConfig(com.axway.ats.agent.core.threading.data.config.LoaderDataConfig) ThreadingPattern(com.axway.ats.agent.core.threading.patterns.ThreadingPattern) AgentService(com.axway.ats.agent.webapp.client.AgentService) ActionRequest(com.axway.ats.agent.core.action.ActionRequest) AgentException_Exception(com.axway.ats.agent.webapp.client.AgentException_Exception)

Aggregations

AgentException (com.axway.ats.agent.core.exceptions.AgentException)4 AgentException_Exception (com.axway.ats.agent.webapp.client.AgentException_Exception)4 AgentService (com.axway.ats.agent.webapp.client.AgentService)4 InternalComponentException (com.axway.ats.agent.webapp.client.InternalComponentException)4 InternalComponentException_Exception (com.axway.ats.agent.webapp.client.InternalComponentException_Exception)4 IOException (java.io.IOException)4 ArrayList (java.util.ArrayList)2 ActionRequest (com.axway.ats.agent.core.action.ActionRequest)1 ImportantThread (com.axway.ats.agent.core.threading.ImportantThread)1 LoaderDataConfig (com.axway.ats.agent.core.threading.data.config.LoaderDataConfig)1 ThreadingPattern (com.axway.ats.agent.core.threading.patterns.ThreadingPattern)1 ActionWrapper (com.axway.ats.agent.webapp.client.ActionWrapper)1 ArgumentWrapper (com.axway.ats.agent.webapp.client.ArgumentWrapper)1 ByteArrayInputStream (java.io.ByteArrayInputStream)1 ByteArrayOutputStream (java.io.ByteArrayOutputStream)1 ObjectInputStream (java.io.ObjectInputStream)1 ObjectOutputStream (java.io.ObjectOutputStream)1