Examples of wait()


Examples of org.apache.axis.client.Call.wait()

            }
        });
        IAsyncResult result = ac.invoke(new Object[]{});
        System.out.println("STARTED....");
        synchronized (call) {
            call.wait(0);
        }
    }
}

Examples of org.apache.axis2.client.async.AxisCallback.wait()

            sender.sendReceiveNonBlocking(operationName, method, callback);
            log.info("send the request");
            synchronized (callback) {
                if (!finish) {
                    callback.wait(45000);
                    if (!finish) {
                        throw new AxisFault(
                                "Server was shutdown as the async response take too long to complete");
                    }
                }

Examples of org.apache.bookkeeper.client.QuorumEngine.Operation.wait()

                LOG.debug("Going to sleep on queue");
                Operation op = pendingOps.poll(1000, TimeUnit.MILLISECONDS);
                if(op != null){
                    synchronized(op){
                        while(!op.isReady()){
                            op.wait();
                        }
                    }
                    LOG.debug("Request ready");

                    switch(op.type){

Examples of org.apache.cxf.message.Message.wait()

            Message inMessage = new MessageImpl();
            synchronized (inMessage) {
                correlationMap.put(correlationId, inMessage);
                jmsTemplate.send(jmsConfig.getTargetDestination(), messageCreator);
                try {
                    inMessage.wait(jmsTemplate.getReceiveTimeout());
                } catch (InterruptedException e) {
                    correlationMap.remove(correlationId);
                    throw new RuntimeException(e);
                }
                correlationMap.remove(correlationId);

Examples of org.apache.cxf.message.MessageImpl.wait()

            Message inMessage = new MessageImpl();
            synchronized (inMessage) {
                correlationMap.put(correlationId, inMessage);
                jmsTemplate.send(jmsConfig.getTargetDestination(), messageCreator);
                try {
                    inMessage.wait(jmsTemplate.getReceiveTimeout());
                } catch (InterruptedException e) {
                    correlationMap.remove(correlationId);
                    throw new RuntimeException(e);
                }
                correlationMap.remove(correlationId);

Examples of org.apache.derbyTesting.functionTests.harness.ProcessStreamResult.Wait()

        if (!wait)
            return;

    // wait until all the results have been processed or if we timed out
    prout.Wait();
    prerr.Wait();
        _bos.flush();
        System.out.flush();

  }

Examples of org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch.wait()

    TaskBatch batch = new TaskBatch();
    String tasknode = submitTaskAndWait(batch, "foo/1");
    ZKUtil.setData(zkw, tasknode, TaskState.TASK_DONE.get("worker"));
    synchronized (batch) {
      while (batch.installed != batch.done) {
        batch.wait();
      }
    }
    waitForCounter(tot_mgr_task_deleted, 0, 1, to/2);
    assertTrue(ZKUtil.checkExists(zkw, tasknode) == -1);
  }

Examples of org.apache.hedwig.client.data.PubSubData.wait()

        synchronized (pubSubData) {
            PubSubCallback pubSubCallback = new PubSubCallback(pubSubData);
            asyncSubUnsub(topic, subscriberId, pubSubCallback, null, operationType, createOrAttach);
            try {
                while (!pubSubData.isDone)
                    pubSubData.wait();
            } catch (InterruptedException e) {
                throw new ServiceDownException("Interrupted Exception while waiting for async subUnsub call");
            }
            // Check from the PubSubCallback if it was successful or not.
            if (!pubSubCallback.getIsCallSuccessful()) {

Examples of org.apache.jetspeed.aggregator.PortletContent.wait()

                else
                {
                    try
                    {
                        log.debug("Waiting on content for Fragment " + getId());
                        content.wait();
                        return content.getContent();
                    }
                    catch (InterruptedException e)
                    {
                        return e.getMessage();

Examples of org.apache.openejb.core.CoreDeploymentInfo.wait()

        if (deploymentInfo.get(EjbDeployment.class) == null) {
      synchronized (deploymentInfo) {
                if (deploymentInfo.get(EjbDeployment.class) == null) {
                    if (!deploymentInfo.isDestroyed()) {
                        try {
                            deploymentInfo.wait();
                        } catch (InterruptedException e) {
                        log.warn("Wait on deploymentInfo interrupted unexpectedly");
                        }
                    }
                }
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.