Package org.apache.accumulo.core.tabletserver.thrift.TabletClientService

Examples of org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface


    ThriftUtil.returnClient(client);
  }
 
  private int startTabletClientService() throws UnknownHostException {
    // start listening for client connection last
    Iface tch = TraceWrap.service(new ThriftClientHandler());
    Processor<Iface> processor = new Processor<Iface>(tch);
    int port = startServer(getSystemConfiguration(), Property.TSERV_CLIENTPORT, processor, "Thrift Client Server");
    log.info("port = " + port);
    return port;
  }
View Full Code Here


    ThriftUtil.returnClient(client);
  }
 
  private int startTabletClientService() throws UnknownHostException {
    // start listening for client connection last
    Iface tch = TraceWrap.service(new ThriftClientHandler());
    Processor<Iface> processor = new Processor<Iface>(tch);
    int port = startServer(getSystemConfiguration(), Property.TSERV_CLIENTPORT, processor, "Thrift Client Server");
    log.info("port = " + port);
    return port;
  }
View Full Code Here

    ThriftUtil.returnClient(client);
  }

  private HostAndPort startTabletClientService() throws UnknownHostException {
    // start listening for client connection last
    Iface tch = RpcWrapper.service(new ThriftClientHandler());
    Processor<Iface> processor = new Processor<Iface>(tch);
    HostAndPort address = startServer(getSystemConfiguration(), clientAddress.getHostText(), Property.TSERV_CLIENTPORT, processor, "Thrift Client Server");
    log.info("address = " + address);
    return address;
  }
View Full Code Here

   * @throws TException
   *           any other problem
   */
  public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, String tableId) throws ThriftSecurityException, TException {
    log.debug("Scanning tablet server " + tserver + " for table " + tableId);
    Iface client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), tserver.getLocation(), ServerConfiguration.getSystemConfiguration());
    try {
      List<TabletStats> onlineTabletsForTable = client.getTabletStats(null, SecurityConstants.getSystemCredentials(), tableId);
      return onlineTabletsForTable;
    } catch (TTransportException e) {
      log.error("Unable to connect to " + tserver + ": " + e);
    } finally {
      ThriftUtil.returnClient(client);
View Full Code Here

    ThriftUtil.returnClient(client);
  }
 
  private int startTabletClientService() throws UnknownHostException {
    // start listening for client connection last
    Iface tch = TraceWrap.service(new ThriftClientHandler());
    Processor<Iface> processor = new Processor<Iface>(tch);
    int port = startServer(getSystemConfiguration(), Property.TSERV_CLIENTPORT, processor, "Thrift Client Server");
    log.info("port = " + port);
    return port;
  }
View Full Code Here

    ThriftUtil.returnClient(client);
  }

  private HostAndPort startTabletClientService() throws UnknownHostException {
    // start listening for client connection last
    Iface tch = TraceWrap.service(new ThriftClientHandler());
    Processor<Iface> processor = new Processor<Iface>(tch);
    HostAndPort address = startServer(getSystemConfiguration(), clientAddress.getHostText(), Property.TSERV_CLIENTPORT, processor, "Thrift Client Server");
    log.info("address = " + address);
    return address;
  }
View Full Code Here

   * @throws TException
   *           any other problem
   */
  public List<TabletStats> getOnlineTabletsForTable(TServerInstance tserver, String tableId) throws ThriftSecurityException, TException {
    log.debug("Scanning tablet server " + tserver + " for table " + tableId);
    Iface client = ThriftUtil.getClient(new TabletClientService.Client.Factory(), tserver.getLocation(), AccumuloConfiguration.getSystemConfiguration());
    try {
      List<TabletStats> onlineTabletsForTable = client.getTabletStats(null, SecurityConstants.systemCredentials, tableId);
      return onlineTabletsForTable;
    } catch (TTransportException e) {
      log.error("Unable to connect to " + tserver + ": " + e);
    } finally {
      ThriftUtil.returnClient(client);
View Full Code Here

   */
 
  @Override
  public List<ActiveScan> getActiveScans(String tserver) throws AccumuloException, AccumuloSecurityException {

    Iface client = null;
    try {
      client = ThriftUtil.getTServerClient(tserver, instance.getConfiguration());
     
      List<ActiveScan> as = new ArrayList<ActiveScan>();
      for (org.apache.accumulo.core.tabletserver.thrift.ActiveScan activeScan : client.getActiveScans(null, credentials)) {
        try {
          as.add(new ActiveScan(instance, activeScan));
        } catch (TableNotFoundException e) {
          throw new AccumuloException(e);
        }
View Full Code Here

TOP

Related Classes of org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface

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.