Package org.apache.accumulo.core.master.thrift

Examples of org.apache.accumulo.core.master.thrift.MasterMonitorInfo


     
    }
   
    @Override
    public MasterMonitorInfo getMasterStats(TInfo info, TCredentials credentials) throws ThriftSecurityException, TException {
      final MasterMonitorInfo result = new MasterMonitorInfo();
     
      result.tServerInfo = new ArrayList<TabletServerStatus>();
      result.tableMap = new DefaultMap<String,TableInfo>(new TableInfo());
      for (Entry<TServerInstance,TabletServerStatus> serverEntry : tserverStatus.entrySet()) {
        final TabletServerStatus status = serverEntry.getValue();
View Full Code Here


     
    }
   
    @Override
    public MasterMonitorInfo getMasterStats(TInfo info, AuthInfo credentials) throws ThriftSecurityException, TException {
      final MasterMonitorInfo result = new MasterMonitorInfo();
      result.loggers = new ArrayList<LoggerStatus>();
      for (String logger : loggers.getLoggersFromZooKeeper().values()) {
        result.loggers.add(new LoggerStatus(logger));
      }
      result.recovery = recovery.status();
View Full Code Here

    exec.waitFor();
    while (true) {
      try {
        Instance instance = HdfsZooInstance.getInstance();
        Client client = MasterClient.getConnection(instance);
        MasterMonitorInfo masterStats = client.getMasterStats(Tracer.traceInfo(), SystemCredentials.get().toThrift(instance));
        if (!masterStats.tServerInfo.isEmpty())
          break;
      } catch (Exception ex) {
        UtilWaitThread.sleep(1000);
      }
View Full Code Here

import org.apache.accumulo.trace.instrument.Tracer;

public class GetMasterStats {
  public static void main(String[] args) throws Exception {
    MasterClientService.Iface client = null;
    MasterMonitorInfo stats = null;
    try {
      Instance instance = HdfsZooInstance.getInstance();
      client = MasterClient.getConnectionWithRetry(instance);
      stats = client.getMasterStats(Tracer.traceInfo(), SystemCredentials.get().toThrift(instance));
    } finally {
View Full Code Here

    private String getACUStats() throws Exception {
     
      MasterClientService.Iface client = null;
      try {
        client = MasterClient.getConnectionWithRetry(opts.getInstance());
        MasterMonitorInfo stats = client.getMasterStats(Tracer.traceInfo(), SystemCredentials.get().toThrift(opts.getInstance()));
       
        TableInfo all = new TableInfo();
        Map<String,TableInfo> tableSummaries = new HashMap<String,TableInfo>();
       
        for (TabletServerStatus server : stats.tServerInfo) {
View Full Code Here

    cluster.start();
   
    UtilWaitThread.sleep(30 * 1000);
   
    while (true) {
      MasterMonitorInfo stats = null;
      Credentials creds = new Credentials("root", new PasswordToken(ROOT_PASSWORD));
      Client client = null;
      try {
        client = MasterClient.getConnectionWithRetry(c.getInstance());
        stats = client.getMasterStats(Tracer.traceInfo(), creds.toThrift(c.getInstance()));
View Full Code Here

    c.tableOperations().flush("test_ingest", null, null, false);
    UtilWaitThread.sleep(15 * 1000);
    Credentials creds = new Credentials("root", new PasswordToken(ROOT_PASSWORD));
   
    MasterClientService.Iface client = null;
    MasterMonitorInfo stats = null;
    try {
      client = MasterClient.getConnectionWithRetry(c.getInstance());
      stats = client.getMasterStats(Tracer.traceInfo(), creds.toThrift(c.getInstance()));
    } finally {
      if (client != null)
View Full Code Here

    for (int i = 1; i < TABLES; i++)
      c.tableOperations().compact("test_ingest" + i, null, null, true, false);
    for (int i = 0; i < 30; i++) {
      int count = 0;
      MasterClientService.Iface client = null;
      MasterMonitorInfo stats = null;
      try {
        client = MasterClient.getConnectionWithRetry(c.getInstance());
        stats = client.getMasterStats(Tracer.traceInfo(), creds.toThrift(c.getInstance()));
      } finally {
        if (client != null)
View Full Code Here

  private void checkBalance(Connector c) throws Exception {
    Credentials creds = new Credentials("root", new PasswordToken(ROOT_PASSWORD));
   
    MasterClientService.Iface client = null;
    MasterMonitorInfo stats = null;
    try {
      client = MasterClient.getConnectionWithRetry(c.getInstance());
      stats = client.getMasterStats(Tracer.traceInfo(), creds.toThrift(c.getInstance()));
    } finally {
      if (client != null)
View Full Code Here

  }

  @Override
  public MasterMonitorInfo getMasterStats(TInfo info, TCredentials credentials) throws ThriftSecurityException {
    final MasterMonitorInfo result = new MasterMonitorInfo();

    result.tServerInfo = new ArrayList<TabletServerStatus>();
    result.tableMap = new DefaultMap<String,TableInfo>(new TableInfo());
    for (Entry<TServerInstance,TabletServerStatus> serverEntry : master.tserverStatus.entrySet()) {
      final TabletServerStatus status = serverEntry.getValue();
View Full Code Here

TOP

Related Classes of org.apache.accumulo.core.master.thrift.MasterMonitorInfo

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.