Examples of fail()


Examples of gnu.testlet.TestHarness.fail()

        {
          Element root = e.getDocument().getDefaultRootElement();
          DocumentEvent.ElementChange ec = e.getChange(root);               
          harness2.checkPoint ("removeUpdate without removing children");
          if (ec != null)
            harness2.fail("ElementChange should be null");
        }
      });

    textArea.append("7");
    try
View Full Code Here

Examples of hivemind.test.services.FailService.fail()

        FailService fs = (FailService) targetClass.newInstance();

        try
        {
            fs.fail();
            unreachable();
        }
        catch (IOException ex)
        {
            assertEquals("Ouch!", ex.getMessage());
View Full Code Here

Examples of net.jodah.concurrentunit.Waiter.fail()

      public void run() {
        try {
          performInvocation();
          waiter.resume();
        } catch (Throwable t) {
          waiter.fail(t);
        }
      }
    });

    waiter.await(1000);
View Full Code Here

Examples of net.jodah.concurrentunit.Waiter.fail()

        public void run() {
          try {
            performInvocation();
            waiter.resume();
          } catch (Throwable t) {
            waiter.fail(t);
          }
        }
      });

    waiter.await(2000);
View Full Code Here

Examples of net.kuujo.copycat.internal.util.Quorum.fail()

    final long lastTerm = lastEntry != null ? lastEntry.term() : 0;
    for (RemoteNode<?> node : (Set<RemoteNode<?>>) context.clusterManager().remoteNodes()) {
      final ProtocolClient client = node.client();
      client.connect().whenComplete((result1, error1) -> {
        if (error1 != null) {
          quorum.fail();
        } else {
          LOGGER.debug("{} - Polling {}", context.clusterManager().localNode(), node.member());
          client.poll(new PollRequest(context.nextCorrelationId(), context.currentTerm(), context.clusterManager()
            .localNode()
            .member()
View Full Code Here

Examples of org.agilewiki.jactor2.core.reactors.impl.ReactorImpl.fail()

     */
    public void onHungRequest(final RequestMtImpl<?> _requestImpl)
            throws Exception {
        final ReactorImpl reactor = _requestImpl.getTargetReactorImpl();
        reactor.error("request hung -> reactor close");
        reactor.fail("hung request");
    }

    /**
     * Handles StackOverflowError. Default action: close the reactor.
     *
 
View Full Code Here

Examples of org.apache.drill.exec.work.RemoteFragmentRunnerListener.fail()

      RootExec exec = ImplCreator.getExec(context, rootOperator);
      FragmentRunner fr = new FragmentRunner(context, exec, listener);
      bee.addFragmentRunner(fr);

    }catch(IOException e){
      listener.fail(fragment.getHandle(), "Failure while parsing fragment execution plan.", e);
    }catch(ExecutionSetupException e){
      listener.fail(fragment.getHandle(), "Failure while setting up execution plan.", e);
    } catch (Exception e) {
      listener.fail(fragment.getHandle(), "Failure due to uncaught exception", e);
    } catch (OutOfMemoryError t) {
View Full Code Here

Examples of org.apache.drill.exec.work.fragment.NonRootStatusReporter.fail()

    try{
      FragmentRoot rootOperator = bee.getContext().getPlanReader().readFragmentOperator(fragment.getFragmentJson());
      FragmentExecutor fr = new FragmentExecutor(context, bee, rootOperator, listener);
      bee.addFragmentRunner(fr);
    } catch (Exception e) {
      listener.fail(fragment.getHandle(), "Failure due to uncaught exception", e);
    } catch (OutOfMemoryError t) {
      if(t.getMessage().startsWith("Direct buffer")){
        listener.fail(fragment.getHandle(), "Failure due to error", t);
      }else{
        throw t;
View Full Code Here

Examples of org.apache.flink.runtime.executiongraph.Execution.fail()

  public void cancel() {
    if (STATUS_UPDATER.compareAndSet(this, ALLOCATED_AND_ALIVE, CANCELLED)) {
      // kill all tasks currently running in this slot
      Execution exec = this.executedTask;
      if (exec != null && !exec.isFinished()) {
        exec.fail(new Exception("The slot in which the task was scheduled has been killed (probably loss of TaskManager)."));
      }
    }
  }
 
  public void releaseSlot() {
View Full Code Here

Examples of org.apache.geronimo.deployment.plugin.remote.FileUploadProgress.fail()

            public void describeWith(ExpressionDescriber arg) throws IOException {
            }

            public boolean passes(Object arg) {
                FileUploadProgress progress = (FileUploadProgress) arg;
                progress.fail("message");
                return true;
            }
        });
       
        startVerification();
View Full Code Here
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.