Examples of stop()


Examples of org.apache.solr.common.util.RTimer.stop()

      for( SearchComponent c : components ) {
        rb.setTimer( subt.sub( c.getName() ) );
        c.prepare(rb);
        rb.getTimer().stop();
      }
      subt.stop();
    }

    if (rb.shards == null) {
      // a normal non-distributed request
View Full Code Here

Examples of org.apache.spark.api.java.JavaSparkContext.stop()

    List<Tuple2<String, Double>> output = ranks.collect();
    for (Tuple2<?,?> tuple : output) {
        System.out.println(tuple._1() + " has rank: " + tuple._2() + ".");
    }

    ctx.stop();
  }
}
View Full Code Here

Examples of org.apache.spark.streaming.api.java.JavaStreamingContext.stop()

        Thread.sleep(100);
      }
      while (dataCounter.get() == 0 && System.currentTimeMillis() - startTime < timeout) {
        Thread.sleep(100);
      }
      ssc.stop();
      assertTrue(dataCounter.get() > 0);
    } finally {
      server.stop();
    }
  }
View Full Code Here

Examples of org.apache.sshd.SshClient.stop()

            pipedIn.write("exit\r\n".getBytes());
            pipedIn.flush();

            channel.waitFor(ClientChannel.CLOSED, 0);
            channel.close(false);
            client.stop();

            assertTrue(new String(sent.toByteArray()).contains("properties\r\nexit\r\n"));
            assertTrue(new String(out.toByteArray()).contains("ServerService(id=ssh)"));
        } catch (Exception e) {
            e.printStackTrace();
View Full Code Here

Examples of org.apache.sshd.SshServer.stop()

        execute(session, "git --git-dir test add readme.txt");

        execute(session, "git --git-dir test commit -m \"readme\"");

        client.stop();
        sshd.stop();
    }

    private void execute(ClientSession session, String command) throws Exception {
        ChannelExec channel = session.createExecChannel(command);
        channel.setOut(System.out);
View Full Code Here

Examples of org.apache.stratos.cartridge.agent.data.publisher.log.LogPublisherManager.stop()

        Thread.sleep(1000);
      } catch (InterruptedException ignore) {
      }
        }

        logPublisherManager.stop();
    }

  protected void subscribeToTopicsAndRegisterListeners() {
    if(log.isDebugEnabled()) {
            log.debug("Starting instance notifier event message receiver thread");
View Full Code Here

Examples of org.apache.synapse.ServerManager.stop()

    public void destroy() {
        try {
            Object o = getServletConfig().getServletContext().getAttribute(SYNAPSE_SERVER_MANAGER);
            if (o != null && o instanceof ServerManager) {
                ServerManager serverManager = (ServerManager) o;
                serverManager.stop();
                getServletContext().removeAttribute(ALREADY_INITED);
            }
        } catch (Exception e) {
            log.error("Error stopping the Synapse listener manager", e);
        }
View Full Code Here

Examples of org.apache.synapse.core.axis2.ProxyService.stop()

                }
                initializeProxy(proxy);
                if (log.isDebugEnabled()) {
                    log.debug("Initialized the ProxyService : " + proxy.getName());
                }
                proxy.stop(getSynapseConfiguration());
                getSynapseConfiguration().removeProxyService(existingArtifactName);
                if (!existingArtifactName.equals(proxy.getName())) {
                    log.info("ProxyService named " + existingArtifactName + " has been Undeployed");
                }
                proxy.buildAxisService(getSynapseConfiguration(),
View Full Code Here

Examples of org.apache.tajo.master.rm.TajoWorkerResourceManager.stop()

    assertEquals(numWorkers, tajoWorkerResourceManager.getWorkers().size());
    for(WorkerResource eachWorker: tajoWorkerResourceManager.getWorkers().values()) {
      assertEquals(workerMemoryMB, eachWorker.getAvailableMemoryMB());
      assertEquals(workerDiskSlots, eachWorker.getAvailableDiskSlots(), 0);
    }
    tajoWorkerResourceManager.stop();
  }

  @Test
  public void testMemoryResource() throws Exception {
    TajoWorkerResourceManager tajoWorkerResourceManager = initResourceManager(false);
View Full Code Here

Examples of org.apache.tajo.worker.dataserver.HttpDataServer.stop()

    InetSocketAddress addr = server.getBindAddress();
   
    URI uri = URI.create("http://127.0.0.1:"+addr.getPort() + "/data");
    Fetcher fetcher = new Fetcher(uri, new File(OUTPUT_DIR + "data"));
    fetcher.get();
    server.stop();
   
    FileSystem fs = FileSystem.getLocal(new TajoConf());
    FileStatus inStatus = fs.getFileStatus(new Path(INPUT_DIR, "data"));
    FileStatus outStatus = fs.getFileStatus(new Path(OUTPUT_DIR, "data"));
    assertEquals(inStatus.getLen(), outStatus.getLen());
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.