Package org.apache.hadoop.hbase.client.coprocessor

Examples of org.apache.hadoop.hbase.client.coprocessor.Exec


    dob.writeUTF(protocolName);

    DataInputBuffer dib = new DataInputBuffer();
    dib.reset(dob.getData(), dob.getLength());

    Exec after = new Exec();
    after.setConf(HBaseConfiguration.create());
    after.readFields(dib);
    // no error thrown
    assertEquals(after.getProtocolName(), protocolName);
    assertEquals(after.getMethodName(), methodName);
  }
View Full Code Here


  public Object invoke(Object instance, final Method method, final Object[] args)
      throws Throwable {
    if (LOG.isDebugEnabled()) {
      LOG.debug("Call: "+method.getName()+", "+(args != null ? args.length : 0));
    }
    Exec exec = new Exec(conf, protocol, method, args);
    ExecResult result = connection.getMaster().execCoprocessor(exec);
    LOG.debug("Master Result is value="+result.getValue());
    return result.getValue();
  }
View Full Code Here

    if (LOG.isDebugEnabled()) {
      LOG.debug("Call: "+method.getName()+", "+(args != null ? args.length : 0));
    }

    if (row != null) {
      final Exec exec = new Exec(conf, row, protocol, method, args);
      ServerCallable<ExecResult> callable =
          new ServerCallable<ExecResult>(connection, table, row) {
            public ExecResult call() throws Exception {
              return server.execCoprocessor(location.getRegionInfo().getRegionName(),
                  exec);
View Full Code Here

    dob.writeUTF(protocolName);

    DataInputBuffer dib = new DataInputBuffer();
    dib.reset(dob.getData(), dob.getLength());

    Exec after = new Exec();
    after.readFields(dib);
    // no error thrown
    assertEquals(after.getProtocolName(), protocolName);
    assertEquals(after.getMethodName(), methodName);
  }
View Full Code Here

    if (LOG.isDebugEnabled()) {
      LOG.debug("Call: "+method.getName()+", "+(args != null ? args.length : 0));
    }

    if (row != null) {
      final Exec exec = new Exec(conf, row, protocol, method, args);
      ServerCallable<ExecResult> callable =
          new ServerCallable<ExecResult>(connection, table, row) {
            public ExecResult call() throws Exception {
              return server.execCoprocessor(location.getRegionInfo().getRegionName(),
                  exec);
View Full Code Here

    dob.writeUTF(protocolName);

    DataInputBuffer dib = new DataInputBuffer();
    dib.reset(dob.getData(), dob.getLength());

    Exec after = new Exec();
    after.setConf(HBaseConfiguration.create());
    after.readFields(dib);
    // no error thrown
    assertEquals(after.getProtocolName(), protocolName);
    assertEquals(after.getMethodName(), methodName);
  }
View Full Code Here

    dob.writeUTF(protocolName);

    DataInputBuffer dib = new DataInputBuffer();
    dib.reset(dob.getData(), dob.getLength());

    Exec after = new Exec();
    after.setConf(HBaseConfiguration.create());
    after.readFields(dib);
    // no error thrown
    assertEquals(after.getProtocolName(), protocolName);
    assertEquals(after.getMethodName(), methodName);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.client.coprocessor.Exec

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.