Package org.apache.hadoop.hbase

Examples of org.apache.hadoop.hbase.CoordinatedStateException


  public TableStateManager getTableStateManager() throws InterruptedException,
      CoordinatedStateException {
    try {
      return new ZKTableStateManager(server.getZooKeeper());
    } catch (KeeperException e) {
      throw new CoordinatedStateException(e);
    }
  }
View Full Code Here


      LOG.warn("Moving table " + tableName + " state from " + this.cache.get(tableName)
        + " to " + state);
      try {
        setTableStateInZK(tableName, state);
      } catch (KeeperException e) {
        throw new CoordinatedStateException(e);
      }
    }
  }
View Full Code Here

        return false;
      }
      try {
        setTableStateInZK(tableName, newState);
      } catch (KeeperException e) {
        throw new CoordinatedStateException(e);
      }
      return true;
    }
  }
View Full Code Here

        return false;
      }
      try {
        setTableStateInZK(tableName, newState);
      } catch (KeeperException e) {
        throw new CoordinatedStateException(e);
      }
      return true;
    }
  }
View Full Code Here

      }
      try {
        ZKUtil.deleteNodeFailSilent(this.watcher,
          ZKUtil.joinZNode(this.watcher.tableZNode, tableName.getNameAsString()));
      } catch (KeeperException e) {
        throw new CoordinatedStateException(e);
      }
    }
  }
View Full Code Here

  public Set<TableName> getTablesInStates(ZooKeeperProtos.Table.State... states)
    throws InterruptedIOException, CoordinatedStateException {
    try {
      return getAllTables(states);
    } catch (KeeperException e) {
      throw new CoordinatedStateException(e);
    }
  }
View Full Code Here

        if (deletePermanentState) {
          try {
            ZKUtil.deleteNodeFailSilent(this.watcher,
                ZKUtil.joinZNode(this.watcher.tableZNode, tableName.getNameAsString()));
          } catch (KeeperException e) {
            throw new CoordinatedStateException(e);
          }
        }
      }
    }
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.CoordinatedStateException

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.