Examples of RpcClient


Examples of org.apache.hadoop.hbase.ipc.RpcClient

      this.batchPool = pool;
      this.managed = managed;
      this.registry = setupRegistry();
      retrieveClusterId();

      this.rpcClient = new RpcClient(this.conf, this.clusterId);

      // Do we publish the status?
      boolean shouldListen = conf.getBoolean(HConstants.STATUS_PUBLISHED,
          HConstants.STATUS_PUBLISHED_DEFAULT);
      Class<? extends ClusterStatusListener.Listener> listenerClass =
View Full Code Here

Examples of org.apache.hadoop.hbase.ipc.RpcClient

     * For tests only.
     * @param rpcClient Client we should use instead.
     * @return Previous rpcClient
     */
    RpcClient setRpcClient(final RpcClient rpcClient) {
      RpcClient oldRpcClient = this.rpcClient;
      this.rpcClient = rpcClient;
      return oldRpcClient;
    }
View Full Code Here

Examples of org.apache.hadoop.hbase.ipc.RpcClient

      // Create the chore that cleans up nonces.
      nonceManagerChore = this.nonceManager.createCleanupChore(this);
    }

    // Setup RPC client for master communication
    rpcClient = new RpcClient(conf, clusterId, new InetSocketAddress(
        this.isa.getAddress(), 0));
    this.pauseMonitor = new JvmPauseMonitor(conf);
    pauseMonitor.start();
  }
View Full Code Here

Examples of org.apache.hadoop.hbase.ipc.RpcClient

    });

    ServerName sn = table.getRegionLocation(ROW).getServerName();
    ConnectionManager.HConnectionImplementation conn =
        (ConnectionManager.HConnectionImplementation) table.getConnection();
    RpcClient rpcClient = conn.getRpcClient();

    LOG.info("Going to cancel connections. connection=" + conn.toString() + ", sn=" + sn);
    for (int i = 0; i < 5000; i++) {
      rpcClient.cancelConnections(sn.getHostname(), sn.getPort());
      Thread.sleep(5);
    }

    step.compareAndSet(1, 2);
    // The test may fail here if the thread doing the gets is stuck. The way to find
View Full Code Here

Examples of org.openhab.binding.homematic.internal.communicator.client.interfaces.RpcClient

        itemDisabler = new ItemDisabler();
        itemDisabler.start();
        newDevicesCounter = 0;

        RpcClient rpcClient = new BinRpcClient();
        context.setServerId(rpcClient.getServerId(HmInterface.RF));
        logger.info("Homematic {}", context.getServerId());

        homematicClient = context.getServerId().isHomegear() ? new HomegearClient(rpcClient) : new CcuClient(
            rpcClient);
View Full Code Here

Examples of org.robotninjas.protobuf.netty.client.RpcClient

        .asEagerSingleton();

    expose(RaftClientProvider.class);
   
    bind(RpcClient.class)
        .toInstance(new RpcClient(eventLoopGroup));
  }
View Full Code Here

Examples of railo.runtime.net.rpc.client.RPCClient

  }

  @Override
  public final Object execute(Config config) throws PageException {
    try {
      RPCClient rpc = getRPCClient(client);
      return rpc.callWithNamedValues(config, getMethodName(), getArguments());
    }
    catch (Throwable t) {
      throw Caster.toPageException(t);
    }
  }
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.