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

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

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

ZooKeeperWatcher.<init>介绍

[英]Instantiate a ZooKeeper connection and watcher.
[中]实例化ZooKeeper连接和监视程序。

代码示例

代码示例来源:origin: apache/kylin

private String getHBaseMasterUrl() throws IOException, KeeperException {
  String host = conf.get("hbase.master.info.bindAddress");
  if (host.equals("0.0.0.0")) {
    host = MasterAddressTracker.getMasterAddress(new ZooKeeperWatcher(conf, null, null)).getHostname();
  }
  String port = conf.get("hbase.master.info.port");
  return "http://" + host + ":" + port + "/";
}

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

/**
 * Closes the current ZKW (if not null) and creates a new one
 * @throws IOException If anything goes wrong connecting
 */
public void reloadZkWatcher() throws IOException {
 if (zkw != null) zkw.close();
 zkw = new ZooKeeperWatcher(conf,
   "connection to cluster: " + id, this);    
}

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

private ZooKeeperWatcher createZooKeeperWatcher() throws IOException {
 return new ZooKeeperWatcher(getConf(), "hbase Fsck", new Abortable() {
  @Override
  public void abort(String why, Throwable e) {
   LOG.error(why, e);
   System.exit(1);
  }
  @Override
  public boolean isAborted() {
   return false;
  }
 });
}

代码示例来源:origin: NGDATA/lilyproject

/**
 * Gets a ZooKeeperWatcher.
 */
public static ZooKeeperWatcher getZooKeeperWatcher(
    HBaseTestingUtility TEST_UTIL) throws ZooKeeperConnectionException,
    IOException {
  ZooKeeperWatcher zkw = new ZooKeeperWatcher(TEST_UTIL.getConfiguration(),
      "unittest", new Abortable() {
    boolean aborted = false;
    @Override
    public void abort(String why, Throwable e) {
      aborted = true;
      throw new RuntimeException("Fatal ZK error, why=" + why, e);
    }
    @Override
    public boolean isAborted() {
      return aborted;
    }
  });
  return zkw;
}

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

private ZooKeeperWatcher createZooKeeperWatcher() throws IOException {
 // This Abortable doesn't 'abort'... it just logs.
 return new ZooKeeperWatcher(connection.getConfiguration(), "ReplicationAdmin", new Abortable() {
  @Override
  public void abort(String why, Throwable e) {
   LOG.error(why, e);
   // We used to call system.exit here but this script can be embedded by other programs that
   // want to do replication stuff... so inappropriate calling System.exit. Just log for now.
  }
  @Override
  public boolean isAborted() {
   return false;
  }
 });
}

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

public static VHostMapListener getInstance(String root, Configuration conf) {
  HConnectionKey connectionKey = new HConnectionKey(conf);
  VHostMapListener instance = null;
  synchronized (VHOST_INSTANCES){
    instance = VHOST_INSTANCES.get(connectionKey);
    if (instance == null) {
      try {
        instance = new VHostMapListener(root,
            new ZooKeeperWatcher(conf, "VHostMapListener", null));
        VHOST_INSTANCES.put(connectionKey,instance);
      } catch (IOException e) {
        LOG.warn("vhostmap listener create failed,will not enable pub-conn.");
      }
    }
  }
  return instance;
}

代码示例来源:origin: org.apache.kylin/kylin-tool

private String getHBaseMasterUrl() throws IOException, KeeperException {
  String host = conf.get("hbase.master.info.bindAddress");
  if (host.equals("0.0.0.0")) {
    host = MasterAddressTracker.getMasterAddress(new ZooKeeperWatcher(conf, null, null)).getHostname();
  }
  String port = conf.get("hbase.master.info.port");
  return "http://" + host + ":" + port + "/";
}

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

/**
 * Get the ZooKeeper instance for this TableServers instance.
 *
 * If ZK has not been initialized yet, this will connect to ZK.
 * @returns zookeeper reference
 * @throws ZooKeeperConnectionException if there's a problem connecting to zk
 */
public synchronized ZooKeeperWatcher getZooKeeperWatcher()
  throws ZooKeeperConnectionException {
 if(zooKeeper == null) {
  try {
   this.zooKeeper = new ZooKeeperWatcher(conf, "hconnection", this);
  } catch(ZooKeeperConnectionException zce) {
   throw zce;
  } catch (IOException e) {
   throw new ZooKeeperConnectionException("An error is preventing" +
     " HBase from connecting to ZooKeeper", e);
  }
 }
 return zooKeeper;
}

代码示例来源: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: co.cask.hbase/hbase

@Override
public void setConf(Configuration config) {
 // If replication is disabled, keep all members null
 if (!config.getBoolean(HConstants.REPLICATION_ENABLE_KEY, false)) {
  return;
 }
 // Make my own Configuration.  Then I'll have my own connection to zk that
 // I can close myself when comes time.
 Configuration conf = new Configuration(config);
 super.setConf(conf);
 try {
  ZooKeeperWatcher zkw = new ZooKeeperWatcher(conf, "replicationLogCleaner", null);
  this.zkHelper = new ReplicationZookeeper(this, conf, zkw);
 } catch (KeeperException e) {
  LOG.error("Error while configuring " + this.getClass().getName(), e);
 } catch (IOException e) {
  LOG.error("Error while configuring " + this.getClass().getName(), e);
 }
 refreshHLogsAndSearch(null);
}

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

/**
 * Create an archive tracker for the passed in server
 * @param conf to read for zookeeper connection information
 * @return ZooKeeper tracker to monitor for this server if this server should archive hfiles for a
 *         given table
 * @throws IOException If a unexpected exception occurs
 * @throws ZooKeeperConnectionException if we can't reach zookeeper
 */
public static TableHFileArchiveTracker create(Configuration conf)
  throws ZooKeeperConnectionException, IOException {
 ZooKeeperWatcher zkw = new ZooKeeperWatcher(conf, "hfileArchiveCleaner", null);
 return create(zkw, new HFileArchiveTableMonitor());
}

代码示例来源:origin: XiaoMi/themis

public ZookeeperWorkerRegister(Configuration conf) throws IOException {
 super(conf);
 try {
  clientNameStr = constructClientName();
  clusterName = conf.get("hbase.cluster.name");
  aliveClientParentPath = getAliveClientParentPath();
  aliveClientPath = getAliveClientPath();
  watcher = new ZooKeeperWatcher(conf, clientNameStr, new TimeoutOrDeletedHandler(),
    false);
  clientTracker = new ClientTracker(watcher);
  LOG.info("create ZookeeperWorkerRegister, clientPath=" + aliveClientParentPath);
 } catch (Exception e) {
  LOG.error("init ZookeeperWorkerRegister fail", e);
  throw new IOException(e);
 }
}

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

@Override
public void setConf(Configuration config) {
 // If replication is disabled, keep all members null
 if (!config.getBoolean(HConstants.REPLICATION_ENABLE_KEY,
   HConstants.REPLICATION_ENABLE_DEFAULT)) {
  LOG.warn("Not configured - allowing all wals to be deleted");
  return;
 }
 // Make my own Configuration.  Then I'll have my own connection to zk that
 // I can close myself when comes time.
 Configuration conf = new Configuration(config);
 super.setConf(conf);
 try {
  this.zkw = new ZooKeeperWatcher(conf, "replicationLogCleaner", null);
  this.replicationQueues = ReplicationFactory.getReplicationQueuesClient(zkw, conf, this);
  this.replicationQueues.init();
 } catch (ReplicationException e) {
  LOG.error("Error while configuring " + this.getClass().getName(), e);
 } catch (IOException e) {
  LOG.error("Error while configuring " + this.getClass().getName(), e);
 }
}

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

/**
  * Get the authentication token of the user for the cluster specified in the configuration
  * @return null if the user does not have the token, otherwise the auth token for the cluster.
  */
 private static Token<AuthenticationTokenIdentifier> getAuthToken(Configuration conf, User user)
   throws IOException, InterruptedException {
  ZooKeeperWatcher zkw = new ZooKeeperWatcher(conf, "TokenUtil-getAuthToken", null);
  try {
   String clusterId = ZKClusterId.readClusterIdZNode(zkw);
   if (clusterId == null) {
    throw new IOException("Failed to get cluster ID");
   }
   return new AuthenticationTokenSelector().selectToken(new Text(clusterId), user.getTokens());
  } catch (KeeperException e) {
   throw new IOException(e);
  } finally {
   zkw.close();
  }
 }
}

代码示例来源:origin: ucarGroup/DataLink

public ReplicateHRegionServer(ReplicationConfig replicationConfig, ArrayBlockingQueue<HRecordChunk> queue)
    throws IOException, InterruptedException {
  this.replicationConfig = replicationConfig;
  this.queue = queue;
  this.zkClient = initZkClient();
  this.hbaseConf = initHbaseConf();
  this.rpcServer = initRpcServer();
  this.zkWatcher = new ZooKeeperWatcher(hbaseConf, this.serverName.toString(), null);
}

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

/**
 * get the regions of a given table.
 *
 * @param tableName the name of the table
 * @return Ordered list of {@link HRegionInfo}.
 * @throws IOException
 */
@Override
public List<HRegionInfo> getTableRegions(final TableName tableName)
throws IOException {
 ZooKeeperWatcher zookeeper =
  new ZooKeeperWatcher(conf, ZK_IDENTIFIER_PREFIX + connection.toString(),
   new ThrowableAbortable());
 List<HRegionInfo> Regions = null;
 try {
  Regions = MetaTableAccessor.getTableRegions(zookeeper, connection, tableName, true);
 } finally {
  zookeeper.close();
 }
 return Regions;
}

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

/**
 * Closes the current ZKW (if not null) and creates a new one
 * @throws IOException If anything goes wrong connecting
 */
void reloadZkWatcher() throws IOException {
 if (zkw != null) zkw.close();
 zkw = new ZooKeeperWatcher(ctx.getConfiguration(),
   "connection to cluster: " + ctx.getPeerId(), this);
 getZkw().registerListener(new PeerRegionServerListener(this));
}

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

private static void resetAcls(final Configuration conf, boolean eraseAcls)
  throws Exception {
 ZooKeeperWatcher zkw = new ZooKeeperWatcher(conf, "ZkAclReset", null);
 try {
  LOG.info((eraseAcls ? "Erase" : "Set") + " HBase ACLs for " +
       zkw.getQuorum() + " " + zkw.getBaseZNode());
  resetAcls(zkw, zkw.getBaseZNode(), eraseAcls);
 } finally {
  zkw.close();
 }
}

代码示例来源:origin: XiaoMi/themis

@Override
public void initEnv() throws IOException {
 super.initEnv();
 TestLockCleaner.setConfigForLockCleaner(conf);
 cpClient = new ThemisCoprocessorClient(connection);
 lockCleaner = new LockCleaner(conf, connection, mockRegister, cpClient);
 zkw = new ZooKeeperWatcher(conf, "deleteNode", null);
}

代码示例来源:origin: XiaoMi/themis

@Test
public void testSetExpiredTsToZk() throws Exception {
 long ts = System.currentTimeMillis() - 10l * 86400 * 1000;
 ThemisMasterObserver masterObserver = new ThemisMasterObserver();
 masterObserver.zk = new ZooKeeperWatcher(conf, "test", null, true);
 masterObserver.themisExpiredTsZNodePath = ThemisMasterObserver.getThemisExpiredTsZNodePath(masterObserver.zk);
 masterObserver.setExpiredTsToZk(ts);
 Assert.assertEquals(ts, ThemisMasterObserver.getThemisExpiredTsFromZk(masterObserver.zk));
 
 // test get data from not-exist path
 Assert.assertEquals(Long.MIN_VALUE,
  ThemisMasterObserver.getThemisExpiredTsFromZk(masterObserver.zk,
   masterObserver.themisExpiredTsZNodePath + "/" + System.currentTimeMillis()));
 masterObserver.zk.close();
}

相关文章