org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher.getConfiguration()方法的使用及代码示例

x33g5p2x  于2022-02-05 转载在 其他  
字(11.9k)|赞(0)|评价(0)|浏览(95)

本文整理了Java中org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher.getConfiguration()方法的一些代码示例,展示了ZooKeeperWatcher.getConfiguration()的具体用法。这些代码示例主要来源于Github/Stackoverflow/Maven等平台,是从一些精选项目中提取出来的代码,具有较强的参考意义,能在一定程度帮忙到你。ZooKeeperWatcher.getConfiguration()方法的具体详情如下:
包路径:org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
类名称:ZooKeeperWatcher
方法名:getConfiguration

ZooKeeperWatcher.getConfiguration介绍

暂无

代码示例

代码示例来源:origin: harbby/presto-connectors

public TableLockChecker(ZooKeeperWatcher zkWatcher, ErrorReporter errorReporter) {
 this.zkWatcher = zkWatcher;
 this.errorReporter = errorReporter;
 expireTimeout = zkWatcher.getConfiguration().getLong(
   TableLockManager.TABLE_LOCK_EXPIRE_TIMEOUT,
   TableLockManager.DEFAULT_TABLE_LOCK_EXPIRE_TIMEOUT_MS);
}

代码示例来源:origin: co.cask.hbase/hbase

private static ArrayList<ACL> createACL(ZooKeeperWatcher zkw, String node) {
 if (isSecureZooKeeper(zkw.getConfiguration())) {
  // Certain znodes are accessed directly by the client,
  // so they must be readable by non-authenticated clients
  if ((node.equals(zkw.baseZNode) == true) ||
    (node.equals(zkw.rootServerZNode) == true) ||
    (node.equals(zkw.masterAddressZNode) == true) ||
    (node.equals(zkw.clusterIdZNode) == true) ||
    (node.equals(zkw.rsZNode) == true) ||
    (node.equals(zkw.backupMasterAddressesZNode) == true) ||
    (node.startsWith(zkw.masterTableZNode) == true) ||
    (node.startsWith(zkw.masterTableZNode92) == true)) {
   return ZooKeeperWatcher.CREATOR_ALL_AND_WORLD_READABLE;
  }
  return Ids.CREATOR_ALL_ACL;
 } else {
  return Ids.OPEN_ACL_UNSAFE;
 }
}

代码示例来源:origin: harbby/presto-connectors

public void fixExpiredTableLocks() throws IOException {
 TableLockManager tableLockManager
  = TableLockManager.createTableLockManager(zkWatcher.getConfiguration(), zkWatcher, null);
 tableLockManager.reapAllExpiredLocks();
}

代码示例来源:origin: harbby/presto-connectors

public HFileArchiveManager(HConnection connection, Configuration conf)
  throws ZooKeeperConnectionException, IOException {
 this.zooKeeper = new ZooKeeperWatcher(conf, "hfileArchiveManager-on-" + connection.toString(),
   connection);
 this.archiveZnode = ZKTableArchiveClient.getArchiveZNode(this.zooKeeper.getConfiguration(),
  this.zooKeeper);
}

代码示例来源:origin: com.aliyun.hbase/alihbase-client

private static ArrayList<ACL> createACL(ZooKeeperWatcher zkw, String node) {
 return createACL(zkw, node, isSecureZooKeeper(zkw.getConfiguration()));
}

代码示例来源:origin: harbby/presto-connectors

private TableHFileArchiveTracker(ZooKeeperWatcher watcher, HFileArchiveTableMonitor monitor) {
 super(watcher);
 watcher.registerListener(this);
 this.monitor = monitor;
 this.archiveHFileZNode = ZKTableArchiveClient.getArchiveZNode(watcher.getConfiguration(),
  watcher);
}

代码示例来源:origin: co.cask.hbase/hbase

private static void getReplicationZnodesDump(ZooKeeperWatcher zkw, StringBuilder sb)
  throws KeeperException {
 String replicationZNodeName = zkw.getConfiguration().get("zookeeper.znode.replication",
  "replication");
 String replicationZnode = joinZNode(zkw.baseZNode, replicationZNodeName);
 if (ZKUtil.checkExists(zkw, replicationZnode) == -1)
  return;
 // do a ls -r on this znode
 List<String> stack = new LinkedList<String>();
 stack.add(replicationZnode);
 do {
  String znodeToProcess = stack.remove(stack.size() - 1);
  sb.append("\n").append(znodeToProcess).append(": ")
    .append(Bytes.toString(ZKUtil.getData(zkw, znodeToProcess)));
  for (String zNodeChild : ZKUtil.listChildrenNoWatch(zkw, znodeToProcess)) {
   stack.add(ZKUtil.joinZNode(znodeToProcess, zNodeChild));
  }
 } while (stack.size() > 0);
}
/**

代码示例来源:origin: com.aliyun.hbase/alihbase-client

/**
 * Appends replication znodes to the passed StringBuilder.
 * @param zkw
 * @param sb
 * @throws KeeperException
 */
private static void getReplicationZnodesDump(ZooKeeperWatcher zkw, StringBuilder sb)
  throws KeeperException {
 String replicationZNodeName = zkw.getConfiguration().get("zookeeper.znode.replication",
  "replication");
 String replicationZnode = joinZNode(zkw.baseZNode, replicationZNodeName);
 if (ZKUtil2.checkExists(zkw, replicationZnode) == -1) return;
 // do a ls -r on this znode
 sb.append("\n").append(replicationZnode).append(": ");
 List<String> children = ZKUtil2.listChildrenNoWatch(zkw, replicationZnode);
 for (String child : children) {
  String znode = joinZNode(replicationZnode, child);
  if (child.equals(zkw.getConfiguration().get("zookeeper.znode.replication.peers", "peers"))) {
   appendPeersZnodes(zkw, znode, sb);
  } else if (child.equals(zkw.getConfiguration().
    get("zookeeper.znode.replication.rs", "rs"))) {
   appendRSZnodes(zkw, znode, sb);
  }
 }
}

代码示例来源:origin: harbby/presto-connectors

private static ArrayList<ACL> createACL(ZooKeeperWatcher zkw, String node) {
 return createACL(zkw, node, isSecureZooKeeper(zkw.getConfiguration()));
}

代码示例来源:origin: harbby/presto-connectors

/**
 * Appends replication znodes to the passed StringBuilder.
 * @param zkw
 * @param sb
 * @throws KeeperException
 */
private static void getReplicationZnodesDump(ZooKeeperWatcher zkw, StringBuilder sb)
  throws KeeperException {
 String replicationZNodeName = zkw.getConfiguration().get("zookeeper.znode.replication",
  "replication");
 String replicationZnode = joinZNode(zkw.baseZNode, replicationZNodeName);
 if (ZKUtil.checkExists(zkw, replicationZnode) == -1) return;
 // do a ls -r on this znode
 sb.append("\n").append(replicationZnode).append(": ");
 List<String> children = ZKUtil.listChildrenNoWatch(zkw, replicationZnode);
 for (String child : children) {
  String znode = joinZNode(replicationZnode, child);
  if (child.equals(zkw.getConfiguration().get("zookeeper.znode.replication.peers", "peers"))) {
   appendPeersZnodes(zkw, znode, sb);
  } else if (child.equals(zkw.getConfiguration().
    get("zookeeper.znode.replication.rs", "rs"))) {
   appendRSZnodes(zkw, znode, sb);
  }
 }
}

代码示例来源:origin: com.aliyun.hbase/alihbase-client

public static ArrayList<ACL> createACL(ZooKeeperWatcher zkw, String node,
                    boolean isSecureZooKeeper) {
 if (!node.startsWith(zkw.baseZNode)) {
  return Ids.OPEN_ACL_UNSAFE;
 }
 if (isSecureZooKeeper) {
  String superUser = zkw.getConfiguration().get("hbase.superuser");
  ArrayList<ACL> acls = new ArrayList<ACL>();
  // add permission to hbase supper user
  if (superUser != null) {
   acls.add(new ACL(Perms.ALL, new Id("sasl", superUser)));
  }
  // Certain znodes are accessed directly by the client,
  // so they must be readable by non-authenticated clients
  if (zkw.isClientReadable(node)) {
   acls.addAll(Ids.CREATOR_ALL_ACL);
   acls.addAll(Ids.READ_ACL_UNSAFE);
  } else {
   acls.addAll(Ids.CREATOR_ALL_ACL);
  }
  return acls;
 } else {
  return Ids.OPEN_ACL_UNSAFE;
 }
}

代码示例来源:origin: harbby/presto-connectors

ArrayList<ACL> acls = new ArrayList<ACL>();
String[] superUsers = zkw.getConfiguration().getStrings(Superusers.SUPERUSER_CONF_KEY);
if (superUsers != null) {
 List<String> groups = new ArrayList<String>();

代码示例来源:origin: com.aliyun.hbase/alihbase-client

/**
 * On master start, we check the znode ACLs under the root directory and set the ACLs properly
 * if needed. If the cluster goes from an unsecure setup to a secure setup, this step is needed
 * so that the existing znodes created with open permissions are now changed with restrictive
 * perms.
 */
public void checkAndSetZNodeAcls() {
 if (!ZKUtil2.isSecureZooKeeper(getConfiguration())) {
  LOG.info("not a secure deployment, proceeding");
  return;
 }
 // Check the base znodes permission first. Only do the recursion if base znode's perms are not
 // correct.
 try {
  List<ACL> actualAcls = recoverableZooKeeper.getAcl(baseZNode, new Stat());
  if (!isBaseZnodeAclSetup(actualAcls)) {
   LOG.info("setting znode ACLs");
   setZnodeAclsRecursive(baseZNode);
  }
 } catch(KeeperException.NoNodeException nne) {
  return;
 } catch(InterruptedException ie) {
  interruptedException(ie);
 } catch (IOException|KeeperException e) {
  LOG.warn("Received exception while checking and setting zookeeper ACLs", e);
 }
}

代码示例来源:origin: com.aliyun.hbase/alihbase-client

private static void appendPeerState(ZooKeeperWatcher zkw, String znodeToProcess,
  StringBuilder sb) throws KeeperException, InvalidProtocolBufferException {
 String peerState = zkw.getConfiguration().get("zookeeper.znode.replication.peers.state",
  "peer-state");
 int pblen = ProtobufUtil.lengthOfPBMagic();
 for (String child : ZKUtil2.listChildrenNoWatch(zkw, znodeToProcess)) {
  if (!child.equals(peerState)) continue;
  String peerStateZnode = ZKUtil2.joinZNode(znodeToProcess, child);
  sb.append("\n").append(peerStateZnode).append(": ");
  byte[] peerStateData;
  try {
   peerStateData = ZKUtil2.getData(zkw, peerStateZnode);
   ZooKeeperProtos.ReplicationState.Builder builder =
     ZooKeeperProtos.ReplicationState.newBuilder();
   ProtobufUtil.mergeFrom(builder, peerStateData, pblen, peerStateData.length - pblen);
   sb.append(builder.getState().name());
  } catch (IOException ipbe) {
   LOG.warn("Got Exception while parsing peer: " + znodeToProcess, ipbe);
  } catch (InterruptedException e) {
   zkw.interruptedException(e);
   return;
  }
 }
}

代码示例来源:origin: harbby/presto-connectors

private static void appendPeerState(ZooKeeperWatcher zkw, String znodeToProcess,
  StringBuilder sb) throws KeeperException, InvalidProtocolBufferException {
 String peerState = zkw.getConfiguration().get("zookeeper.znode.replication.peers.state",
  "peer-state");
 int pblen = ProtobufUtil.lengthOfPBMagic();
 for (String child : ZKUtil.listChildrenNoWatch(zkw, znodeToProcess)) {
  if (!child.equals(peerState)) continue;
  String peerStateZnode = ZKUtil.joinZNode(znodeToProcess, child);
  sb.append("\n").append(peerStateZnode).append(": ");
  byte[] peerStateData;
  try {
   peerStateData = ZKUtil.getData(zkw, peerStateZnode);
   ZooKeeperProtos.ReplicationState.Builder builder =
     ZooKeeperProtos.ReplicationState.newBuilder();
   ProtobufUtil.mergeFrom(builder, peerStateData, pblen, peerStateData.length - pblen);
   sb.append(builder.getState().name());
  } catch (IOException ipbe) {
   LOG.warn("Got Exception while parsing peer: " + znodeToProcess, ipbe);
  } catch (InterruptedException e) {
   zkw.interruptedException(e);
   return;
  }
 }
}

代码示例来源:origin: harbby/presto-connectors

public void checkTableLocks() throws IOException {
 TableLockManager tableLockManager
  = TableLockManager.createTableLockManager(zkWatcher.getConfiguration(), zkWatcher, null);
 final long expireDate = EnvironmentEdgeManager.currentTime() - expireTimeout;
 MetadataHandler handler = new MetadataHandler() {
  @Override
  public void handleMetadata(byte[] ownerMetadata) {
   ZooKeeperProtos.TableLock data = TableLockManager.fromBytes(ownerMetadata);
   String msg = "Table lock acquire attempt found:";
   if (data != null) {
     msg = msg +
      String.format("[tableName=%s:%s, lockOwner=%s, threadId=%s, " +
      "purpose=%s, isShared=%s, createTime=%s]",
      data.getTableName().getNamespace().toStringUtf8(),
      data.getTableName().getQualifier().toStringUtf8(),
      ProtobufUtil.toServerName(data.getLockOwner()), data.getThreadId(),
      data.getPurpose(), data.getIsShared(), data.getCreateTime());
   }
   if (data != null && data.hasCreateTime() && data.getCreateTime() < expireDate) {
    errorReporter.reportError(HBaseFsck.ErrorReporter.ERROR_CODE.EXPIRED_TABLE_LOCK, msg);
   } else {
    errorReporter.print(msg);
   }
  }
 };
 tableLockManager.visitAllLocks(handler);
}

代码示例来源:origin: co.cask.hbase/hbase

boolean runSequentialOnMultiFailure) throws KeeperException {
if (ops == null) return;
boolean useMulti = zkw.getConfiguration().getBoolean(HConstants.ZOOKEEPER_USEMULTI, false);

代码示例来源:origin: harbby/presto-connectors

/**
 * On master start, we check the znode ACLs under the root directory and set the ACLs properly
 * if needed. If the cluster goes from an unsecure setup to a secure setup, this step is needed
 * so that the existing znodes created with open permissions are now changed with restrictive
 * perms.
 */
public void checkAndSetZNodeAcls() {
 if (!ZKUtil.isSecureZooKeeper(getConfiguration())) {
  LOG.info("not a secure deployment, proceeding");
  return;
 }
 // Check the base znodes permission first. Only do the recursion if base znode's perms are not
 // correct.
 try {
  List<ACL> actualAcls = recoverableZooKeeper.getAcl(baseZNode, new Stat());
  if (!isBaseZnodeAclSetup(actualAcls)) {
   LOG.info("setting znode ACLs");
   setZnodeAclsRecursive(baseZNode);
  }
 } catch(KeeperException.NoNodeException nne) {
  return;
 } catch(InterruptedException ie) {
  interruptedException(ie);
 } catch (IOException|KeeperException e) {
  LOG.warn("Received exception while checking and setting zookeeper ACLs", e);
 }
}

代码示例来源:origin: harbby/presto-connectors

boolean runSequentialOnMultiFailure) throws KeeperException {
if (ops == null) return;
boolean useMulti = zkw.getConfiguration().getBoolean(HConstants.ZOOKEEPER_USEMULTI, false);

相关文章