Package com.kurento.kmf.rabbitmq.client

Examples of com.kurento.kmf.rabbitmq.client.JsonRpcClientRabbitMq


    log.info("Server started");

    long initTime = System.nanoTime();

    log.info("Starting client");
    JsonRpcClientRabbitMq client = new JsonRpcClientRabbitMq();

    MediaPipelineFactory mpf = new MediaPipelineFactory(client);
    MediaPipeline pipeline = mpf.create();

    checkKeepAlives(initTime, NUM_KEEP_ALIVES * 1000,
        (NUM_KEEP_ALIVES + 1) * 1000);

    // There are two pipelines and NUM_KEEP_ALIVES are submited in the half
    // of the time
    initTime = System.nanoTime();
    latch = new CountDownLatch(NUM_KEEP_ALIVES);
    MediaPipeline pipeline2 = mpf.create();
    checkKeepAlives(initTime, NUM_KEEP_ALIVES * 1000 / 2,
        (NUM_KEEP_ALIVES + 1) * 1000 / 2);

    client.close();

    log.info("Client finished");

    server.destroy();

View Full Code Here


    System.setProperty(RabbitMqManager.RETRY_TIMEOUT_PROPERTY,
        Integer.toString(TIMEOUT_RETRY_TIME));
    System.setProperty(RabbitMqManager.NUM_RETRIES_PROPERTY, "3");

    log.info("Starting client");
    client = new JsonRpcClientRabbitMq();

    mpf = new MediaPipelineFactory(client);
  }
View Full Code Here

  private static final String PIPELINE_CREATION = "pipeline_creation";

  @Test
  public void test() throws IOException {

    JsonRpcClientRabbitMq client = new JsonRpcClientRabbitMq();

    RabbitManager manager = new RabbitManager();
    System.out.println(manager.getQueueInfo(PIPELINE_CREATION));

    client.close();

    System.out.println(manager.getQueueInfo(PIPELINE_CREATION));

    manager.deleteQueue(PIPELINE_CREATION);
View Full Code Here

  public void test() {

    KurentoServicesTestHelper.startKurentoMediaServer();

    MediaPipelineFactory mpf = new MediaPipelineFactory(
        new JsonRpcClientRabbitMq());

    JsonRpcServerRabbitMq server = new JsonRpcServerRabbitMq(
        new JsonRpcClientThrift());

    server.start();
View Full Code Here

  private CountDownLatch finished = new CountDownLatch(1);

  private String logId;

  public ClientApp(String logId) {
    this.mpf = new MediaPipelineFactory(new JsonRpcClientRabbitMq(
        KmfMediaApiProperties.getRabbitMqAddress()));
  }
View Full Code Here

TOP

Related Classes of com.kurento.kmf.rabbitmq.client.JsonRpcClientRabbitMq

Copyright © 2018 www.massapicom. 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.