Search in sources :

Example 1 with ThreadingPattern

use of com.axway.ats.agent.core.threading.patterns.ThreadingPattern in project ats-framework by Axway.

the class AgentWsImpl method scheduleActionsInMultipleThreads.

/**
     * Schedule a set of actions (queue) in multiple threads. The actions
     * will not be executed until a call to startQueue is made
     *
     * @param queueName the name of the action queue
     * @param actions the actions in that queue
     * @param serializedThreadingPattern the serialized threading pattern to be used
     * @param testCaseState the test case state
     * @throws AgentException on error
     * @throws InternalComponentException if an exception is thrown while the actions are executed
     */
@WebMethod
public void scheduleActionsInMultipleThreads(@WebParam(name = "name") String queueName, @WebParam(name = "queueId") int queueId, @WebParam(name = "actions") ActionWrapper[] actions, @WebParam(name = "serializedThreadingPattern") byte[] serializedThreadingPattern, @WebParam(name = "serializedLoaderDataConfig") byte[] serializedLoaderDataConfig, boolean isUseSynchronizedIterations) throws AgentException, InternalComponentException {
    final String caller = getCaller();
    ThreadsPerCaller.registerThread(caller);
    try {
        ArrayList<ActionRequest> actionRequests = new ArrayList<ActionRequest>();
        for (ActionWrapper actionWrapper : actions) {
            List<ArgumentWrapper> args = actionWrapper.getArgs();
            int numArguments = args.size();
            Object[] arguments = new Object[numArguments];
            // unwrap the action arguments
            for (int i = 0; i < numArguments; i++) {
                ArgumentWrapper argWrapper = args.get(i);
                ByteArrayInputStream byteInStream = new ByteArrayInputStream(argWrapper.getArgumentValue());
                ObjectInputStream objectInStream = new ObjectInputStream(byteInStream);
                arguments[i] = objectInStream.readObject();
            }
            // construct the action request
            ActionRequest actionRequest = new ActionRequest(actionWrapper.getComponentName(), actionWrapper.getActionName(), arguments);
            actionRequests.add(actionRequest);
        }
        ByteArrayInputStream byteInStream;
        ObjectInputStream objectInStream;
        // de-serialize the threading configuration
        byteInStream = new ByteArrayInputStream(serializedThreadingPattern);
        objectInStream = new ObjectInputStream(byteInStream);
        ThreadingPattern threadingPattern = (ThreadingPattern) objectInStream.readObject();
        // de-serialize the loader data configuration
        byteInStream = new ByteArrayInputStream(serializedLoaderDataConfig);
        objectInStream = new ObjectInputStream(byteInStream);
        LoaderDataConfig loaderDataConfig = (LoaderDataConfig) objectInStream.readObject();
        MultiThreadedActionHandler.getInstance(caller).scheduleActions(caller, queueName, queueId, actionRequests, threadingPattern, loaderDataConfig, isUseSynchronizedIterations);
    } catch (Exception e) {
        handleExceptions(e);
    } finally {
        ThreadsPerCaller.unregisterThread();
    }
}
Also used : ArrayList(java.util.ArrayList) InternalComponentException(com.axway.ats.agent.core.exceptions.InternalComponentException) AgentException(com.axway.ats.agent.core.exceptions.AgentException) NoSuchActionException(com.axway.ats.agent.core.exceptions.NoSuchActionException) NoCompatibleMethodFoundException(com.axway.ats.agent.core.exceptions.NoCompatibleMethodFoundException) NoSuchComponentException(com.axway.ats.agent.core.exceptions.NoSuchComponentException) IOException(java.io.IOException) ActionExecutionException(com.axway.ats.agent.core.exceptions.ActionExecutionException) LoaderDataConfig(com.axway.ats.agent.core.threading.data.config.LoaderDataConfig) ThreadingPattern(com.axway.ats.agent.core.threading.patterns.ThreadingPattern) ActionRequest(com.axway.ats.agent.core.action.ActionRequest) ByteArrayInputStream(java.io.ByteArrayInputStream) ObjectInputStream(java.io.ObjectInputStream) WebMethod(javax.jws.WebMethod)

Example 2 with ThreadingPattern

use of com.axway.ats.agent.core.threading.patterns.ThreadingPattern 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

ActionRequest (com.axway.ats.agent.core.action.ActionRequest)2 AgentException (com.axway.ats.agent.core.exceptions.AgentException)2 LoaderDataConfig (com.axway.ats.agent.core.threading.data.config.LoaderDataConfig)2 ThreadingPattern (com.axway.ats.agent.core.threading.patterns.ThreadingPattern)2 IOException (java.io.IOException)2 ArrayList (java.util.ArrayList)2 ActionExecutionException (com.axway.ats.agent.core.exceptions.ActionExecutionException)1 InternalComponentException (com.axway.ats.agent.core.exceptions.InternalComponentException)1 NoCompatibleMethodFoundException (com.axway.ats.agent.core.exceptions.NoCompatibleMethodFoundException)1 NoSuchActionException (com.axway.ats.agent.core.exceptions.NoSuchActionException)1 NoSuchComponentException (com.axway.ats.agent.core.exceptions.NoSuchComponentException)1 ImportantThread (com.axway.ats.agent.core.threading.ImportantThread)1 ActionWrapper (com.axway.ats.agent.webapp.client.ActionWrapper)1 AgentException_Exception (com.axway.ats.agent.webapp.client.AgentException_Exception)1 AgentService (com.axway.ats.agent.webapp.client.AgentService)1 InternalComponentException (com.axway.ats.agent.webapp.client.InternalComponentException)1 InternalComponentException_Exception (com.axway.ats.agent.webapp.client.InternalComponentException_Exception)1 ByteArrayInputStream (java.io.ByteArrayInputStream)1 ObjectInputStream (java.io.ObjectInputStream)1 WebMethod (javax.jws.WebMethod)1