gpt4 book ai didi

org.apache.zookeeper.server.ZooKeeperServer类的使用及代码示例

转载 作者:知者 更新时间:2024-03-17 05:38:40 31 4
gpt4 key购买 nike

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

ZooKeeperServer介绍

[英]This class implements a simple standalone ZooKeeperServer. It sets up the following chain of RequestProcessors to process requests: PrepRequestProcessor -> SyncRequestProcessor -> FinalRequestProcessor
[中]这个类实现了一个简单的独立ZookePerserver。它设置了以下请求处理器链来处理请求:PreRequestProcessor->SyncRequestProcessor->FinalRequestProcessor

代码示例

代码示例来源:origin: alibaba/jstorm

public static Factory mkInprocessZookeeper(String localDir, int port)
    throws IOException, InterruptedException {
  LOG.info("Starting in-process zookeeper at port " + port + " and dir " + localDir);
  File localFile = new File(localDir);
  ZooKeeperServer zk = new ZooKeeperServer(localFile, localFile, 2000);
  Factory factory = new Factory(new InetSocketAddress(port), 0);
  factory.startup(zk);
  return factory;
}

代码示例来源:origin: org.apache.zookeeper/zookeeper

final ZooKeeperServer zkServer = new ZooKeeperServer();
zkServer.registerServerShutdownHandler(
    new ZooKeeperServerShutdownHandler(shutdownLatch));
txnLog.setServerStats(zkServer.serverStats());
zkServer.setTxnLogFactory(txnLog);
zkServer.setTickTime(config.tickTime);
zkServer.setMinSessionTimeout(config.minSessionTimeout);
zkServer.setMaxSessionTimeout(config.maxSessionTimeout);
cnxnFactory = ServerCnxnFactory.createFactory();
cnxnFactory.configure(config.getClientPortAddress(),
    config.getMaxClientCnxns());
cnxnFactory.startup(zkServer);
cnxnFactory.join();
if (zkServer.canShutdown()) {
  zkServer.shutdown(true);

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

/**
 * Kill one back up ZK servers.
 *
 * @throws IOException if waiting for the shutdown of a server fails
 */
public void killOneBackupZooKeeperServer() throws IOException, InterruptedException {
 if (!started || activeZKServerIndex < 0 || standaloneServerFactoryList.size() <= 1) {
  return ;
 }
 int backupZKServerIndex = activeZKServerIndex+1;
 // Shutdown the current active one
 NIOServerCnxnFactory standaloneServerFactory =
  standaloneServerFactoryList.get(backupZKServerIndex);
 int clientPort = clientPortList.get(backupZKServerIndex);
 standaloneServerFactory.shutdown();
 if (!waitForServerDown(clientPort, connectionTimeout)) {
  throw new IOException("Waiting for shutdown of standalone server");
 }
 zooKeeperServers.get(backupZKServerIndex).getZKDatabase().close();
 // remove this backup zk server
 standaloneServerFactoryList.remove(backupZKServerIndex);
 clientPortList.remove(backupZKServerIndex);
 zooKeeperServers.remove(backupZKServerIndex);
 LOG.info("Kill one backup ZK servers in the cluster " +
   "on client port: " + clientPort);
}

代码示例来源:origin: prestodb/presto

public EmbeddedZookeeper(int port)
    throws IOException
{
  this.port = port;
  zkDataDir = Files.createTempDir();
  zkServer = new ZooKeeperServer();
  FileTxnSnapLog ftxn = new FileTxnSnapLog(zkDataDir, zkDataDir);
  zkServer.setTxnLogFactory(ftxn);
  cnxnFactory = NIOServerCnxnFactory.createFactory(new InetSocketAddress(port), 0);
}

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

private ZooKeeperServer setupSessionTracker() throws IOException {
  File tmpDir = ClientBase.createTmpDir();
  ClientBase.setupTestEnv();
  ZooKeeperServer zks = new ZooKeeperServer(tmpDir, tmpDir, 3000);
  zks.setupRequestProcessors();
  firstProcessor = new FirstProcessor(zks, null);
  zks.firstProcessor = firstProcessor;
  // setup session tracker
  zks.createSessionTracker();
  zks.startSessionTracker();
  return zks;
}

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

/**
 * Creates a ZooKeeperServer instance. It sets everything up, but doesn't
 * actually start listening for clients until run() is invoked.
 *
 * @param dataDir the directory to put the data
 */
public ZooKeeperServer(FileTxnSnapLog txnLogFactory, int tickTime,
    int minSessionTimeout, int maxSessionTimeout, ZKDatabase zkDb) {
  serverStats = new ServerStats(this);
  this.txnLogFactory = txnLogFactory;
  this.txnLogFactory.setServerStats(this.serverStats);
  this.zkDb = zkDb;
  this.tickTime = tickTime;
  setMinSessionTimeout(minSessionTimeout);
  setMaxSessionTimeout(maxSessionTimeout);
  listener = new ZooKeeperServerListenerImpl(this);
  readResponseCache = new ResponseCache();
  connThrottle = new BlueThrottle();
  LOG.info("Created server with tickTime " + tickTime
      + " minSessionTimeout " + getMinSessionTimeout()
      + " maxSessionTimeout " + getMaxSessionTimeout()
      + " datadir " + txnLogFactory.getDataDir()
      + " snapdir " + txnLogFactory.getSnapDir());
}

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

ZooKeeperServer server = new ZooKeeperServer(dir, dir, tickTimeToUse);
server.setMinSessionTimeout(configuration.getInt(
    "hbase.zookeeper.property.minSessionTimeout", -1));
server.setMaxSessionTimeout(configuration.getInt(
    "hbase.zookeeper.property.maxSessionTimeout", -1));
NIOServerCnxnFactory standaloneServerFactory;
while (true) {
 try {
  standaloneServerFactory = new NIOServerCnxnFactory();
  standaloneServerFactory.configure(
   new InetSocketAddress(currentClientPort),
   configuration.getInt(HConstants.ZOOKEEPER_MAX_CLIENT_CNXNS,
       HConstants.DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS));
standaloneServerFactory.startup(server);

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

public void testSnapshot() throws Exception {
  File snapDir = new File(testData, "invalidsnap");
  ZooKeeperServer zks = new ZooKeeperServer(snapDir, snapDir, 3000);
  SyncRequestProcessor.setSnapCount(1000);
  final int PORT = Integer.parseInt(HOSTPORT.split(":")[1]);
  ServerCnxnFactory f = ServerCnxnFactory.createFactory(PORT, -1);
  f.startup(zks);
  LOG.info("starting up the zookeeper server .. waiting");
  Assert.assertTrue("waiting for server being up",
    zk.close();
  f.shutdown();
  zks.shutdown();
  Assert.assertTrue("waiting for server down",
        ClientBase.waitForServerDown(HOSTPORT,

代码示例来源:origin: org.apache.atlas/atlas-notification

private String startZk() throws IOException, InterruptedException, URISyntaxException {
  String zkValue = properties.getProperty("zookeeper.connect");
  LOG.info("Starting zookeeper at {}", zkValue);
  URL zkAddress    = getURL(zkValue);
  File snapshotDir = constructDir("zk/txn");
  File logDir      = constructDir("zk/snap");
  factory = NIOServerCnxnFactory.createFactory(new InetSocketAddress(zkAddress.getHost(), zkAddress.getPort()), 1024);
  factory.startup(new ZooKeeperServer(snapshotDir, logDir, 500));
  String ret = factory.getLocalAddress().getAddress().toString();
  LOG.info("Embedded zookeeper for Kafka started at {}", ret);
  return ret;
}

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

@Test
public void testGetSecureClientAddress() throws IOException {
  ZooKeeperServer zks = new ZooKeeperServer();
  /**
   * case 1: When secure client is not configured getSecureClientAddress
   * should return empty string
   */
  ZooKeeperServerBean serverBean = new ZooKeeperServerBean(zks);
  String result = serverBean.getSecureClientPort();
  assertEquals("", result);
  /**
   * case 2: When secure client is configured getSecureClientAddress
   * should return configured SecureClientAddress
   */
  ServerCnxnFactory cnxnFactory = ServerCnxnFactory.createFactory();
  int secureClientPort = 8443;
  InetSocketAddress address = new InetSocketAddress(secureClientPort);
  cnxnFactory.configure(address, 5, true);
  zks.setSecureServerCnxnFactory(cnxnFactory);
  result = serverBean.getSecureClientAddress();
  String ipv4 = "0.0.0.0:" + secureClientPort;
  String ipv6 = "0:0:0:0:0:0:0:0:" + secureClientPort;
  assertTrue(result.equals(ipv4) || result.equals(ipv6));
  // cleanup
  cnxnFactory.shutdown();
}

代码示例来源:origin: alibaba/mdrill

public ServerCnxnFactory mkInprocessZookeeper(String localdir, int port)
    throws IOException, InterruptedException {
  LOG.info("Starting inprocess zookeeper at port " + port + " and dir "
      + localdir);
  File localfile = new File(localdir);
  ZooKeeperServer zk = new ZooKeeperServer(localfile, localfile, 2000);
  ServerCnxnFactory factory =NIOServerCnxnFactory.createFactory( 
      new InetSocketAddress(port),60);
  factory.startup(zk);
  return factory;
}

代码示例来源:origin: debezium/debezium

this.factory = ServerCnxnFactory.createFactory(new InetSocketAddress("localhost", port), 1024);
if ( this.dataDir == null ) {
  try {
  server = new ZooKeeperServer(snapshotDir, logDir, tickTime); 
  factory.startup(server);
  return this;
} catch (InterruptedException e) {

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

zkDb = zs.getZKDatabase();
factory.shutdown();
try {
  zkDb.close();
} catch (IOException ie) {
  LOG.warn("Error closing logs ", ie);
        new InetSocketAddress("127.0.0.1", PortAssignment.unique()),
        new InetSocketAddress("127.0.0.1", PortAssignment.unique()),
        new InetSocketAddress("127.0.0.1", port1)));
peers.put(Long.valueOf(2), new QuorumServer(2,

代码示例来源:origin: stackoverflow.com

int clientPort = 2199; // not standard
 int numConnections = 5000;
 int tickTime = 2000;
 String dataDirectory = System.getProperty("java.io.tmpdir");
 File dir = new File(dataDirectory, "zookeeper").getAbsoluteFile();
 ZooKeeperServer server = new ZooKeeperServer(dir, dir, tickTime);
 ServerCnxnFactory factory = new NIOServerCnxnFactory();
 factory.configure(new InetSocketAddress(clientPort), numConnections);
 factory.startup(server); // start the server.
 // ...shutdown some time later
 factory.shutdown();

代码示例来源:origin: org.deeplearning4j/deeplearning4j-scaleout-zookeeper

public void run() throws Exception {
  
  File dir = new File(dataDirectory, "zookeeper").getAbsoluteFile();
  NIOServerCnxnFactory factory = new NIOServerCnxnFactory();
  
  ZooKeeperServer server = new ZooKeeperServer(dir, dir, tickTime);
  
  factory.setZooKeeperServer(server);
  factory.setMaxClientCnxnsPerHost(numConnections);
  factory.configure(new InetSocketAddress(clientPort), numConnections);
  factory.startup(server);
  
}

代码示例来源:origin: org.wildfly.camel/wildfly-camel-itests-common

public EmbeddedZookeeper(int port, Path baseDir) throws Exception {
  this.port = port;
  zookeeperBaseDir = baseDir;
  zkServer = new ZooKeeperServer();
  File dataDir = zookeeperBaseDir.resolve("log").toFile();
  File snapDir = zookeeperBaseDir.resolve("data").toFile();
  FileTxnSnapLog ftxn = new FileTxnSnapLog(dataDir, snapDir);
  zkServer.setTxnLogFactory(ftxn);
  zkServer.setTickTime(1000);
  connectionFactory = new NIOServerCnxnFactory() {
    @Override
    protected void configureSaslLogin() throws IOException {
      // do nothing
    }
  };
  connectionFactory.configure(new InetSocketAddress("localhost", port), 0);
}

代码示例来源:origin: com.github.sgroschupf/zkclient

private void startSingleZkServer(final int tickTime, final File dataDir, final File dataLogDir, final int port) {
  try {
    _zk = new ZooKeeperServer(dataDir, dataLogDir, tickTime);
    _zk.setMinSessionTimeout(_minSessionTimeout);
    _nioFactory = new NIOServerCnxn.Factory(new InetSocketAddress(port));
    _nioFactory.startup(_zk);
  } catch (IOException e) {
    throw new ZkException("Unable to start single ZooKeeper server.", e);
  } catch (InterruptedException e) {
    throw new ZkInterruptedException(e);
  }
}

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

private void startStandalone() throws IOException {
  logger.info("Starting Embedded ZooKeeper Server");
  final ServerConfig config = new ServerConfig();
  config.readFrom(quorumPeerConfig);
  try {
    transactionLog = new FileTxnSnapLog(new File(config.getDataLogDir()), new File(config.getDataDir()));
    embeddedZkServer = new ZooKeeperServer();
    embeddedZkServer.setTxnLogFactory(transactionLog);
    embeddedZkServer.setTickTime(config.getTickTime());
    embeddedZkServer.setMinSessionTimeout(config.getMinSessionTimeout());
    embeddedZkServer.setMaxSessionTimeout(config.getMaxSessionTimeout());
    connectionFactory = ServerCnxnFactory.createFactory();
    connectionFactory.configure(config.getClientPortAddress(), config.getMaxClientCnxns());
    connectionFactory.startup(embeddedZkServer);
  } catch (InterruptedException e) {
    Thread.currentThread().interrupt();
    logger.warn("Embedded ZooKeeper Server interrupted", e);
  } catch (final IOException ioe) {
    throw new IOException("Failed to start embedded ZooKeeper Server", ioe);
  } catch (final Exception e) {
    throw new RuntimeException("Failed to start embedded ZooKeeper Server", e);
  }
}

代码示例来源:origin: io.fabric8/fabric-zookeeper-spring

public void afterPropertiesSet() throws Exception {
  if( purge ) {
    deleteFilesInDir(getDataLogDir());
    deleteFilesInDir(getDataDir());
  }
  FileTxnSnapLog ftxn = new FileTxnSnapLog(getDataLogDir(), getDataDir());
  zooKeeperServer.setTxnLogFactory(ftxn);
  zooKeeperServer.setTickTime(getTickTime());
  zooKeeperServer.setMinSessionTimeout(getMinSessionTimeout());
  zooKeeperServer.setMaxSessionTimeout(getMaxSessionTimeout());
  connectionFactory = new NIOServerCnxnFactory();
  connectionFactory.configure(getClientPortAddress(), getMaxClientConnections());
  connectionFactory.startup(zooKeeperServer);
}

代码示例来源:origin: org.apache.twill/twill-zookeeper

@Override
protected void startUp() throws Exception {
 ZooKeeperServer zkServer = new ZooKeeperServer();
 FileTxnSnapLog ftxn = new FileTxnSnapLog(dataDir, dataDir);
 zkServer.setTxnLogFactory(ftxn);
 zkServer.setTickTime(tickTime);
 factory = ServerCnxnFactory.createFactory();
 factory.configure(getAddress(port), -1);
 factory.startup(zkServer);
 LOG.info("In memory ZK started: " + getConnectionStr());
}

31 4 0
Copyright 2021 - 2024 cfsdn All Rights Reserved 蜀ICP备2022000587号
广告合作:1813099741@qq.com 6ren.com