当前位置: 首页>>代码示例>>Java>>正文


Java ZooKeeperServerMain类代码示例

本文整理汇总了Java中org.apache.zookeeper.server.ZooKeeperServerMain的典型用法代码示例。如果您正苦于以下问题:Java ZooKeeperServerMain类的具体用法?Java ZooKeeperServerMain怎么用?Java ZooKeeperServerMain使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。


ZooKeeperServerMain类属于org.apache.zookeeper.server包,在下文中一共展示了ZooKeeperServerMain类的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: initializeAndRun

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
protected void initializeAndRun(String[] args)
    throws ConfigException, IOException
{
    QuorumPeerConfig config = new QuorumPeerConfig();
    if (args.length == 1) {
        config.parse(args[0]);
    }

    // Start and schedule the the purge task
    DatadirCleanupManager purgeMgr = new DatadirCleanupManager(config
            .getDataDir(), config.getDataLogDir(), config
            .getSnapRetainCount(), config.getPurgeInterval());
    purgeMgr.start();

    if (args.length == 1 && config.servers.size() > 0) {
        runFromConfig(config);
    } else {
        LOG.warn("Either no config or no quorum defined in config, running "
                + " in standalone mode");
        // there is only server in the quorum -- run as standalone
        ZooKeeperServerMain.main(args);
    }
}
 
开发者ID:l294265421,项目名称:ZooKeeper,代码行数:24,代码来源:QuorumPeerMain.java

示例2: initializeAndRun

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
protected void initializeAndRun(String[] args)
    throws ConfigException, IOException, AdminServerException
{
    QuorumPeerConfig config = new QuorumPeerConfig();
    if (args.length == 1) {
        config.parse(args[0]);
    }

    // Start and schedule the the purge task
    DatadirCleanupManager purgeMgr = new DatadirCleanupManager(config
            .getDataDir(), config.getDataLogDir(), config
            .getSnapRetainCount(), config.getPurgeInterval());
    purgeMgr.start();

    if (args.length == 1 && config.isDistributed()) {
        runFromConfig(config);
    } else {
        LOG.warn("Either no config or no quorum defined in config, running "
                + " in standalone mode");
        // there is only server in the quorum -- run as standalone
        ZooKeeperServerMain.main(args);
    }
}
 
开发者ID:didichuxing2,项目名称:https-github.com-apache-zookeeper,代码行数:24,代码来源:QuorumPeerMain.java

示例3: startZkLocal

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
private static void startZkLocal() throws Exception {
    final File zkTmpDir = File.createTempFile("zookeeper", "test");
    if (zkTmpDir.delete() && zkTmpDir.mkdir()) {
        Properties zkProperties = new Properties();
        zkProperties.setProperty("dataDir", zkTmpDir.getAbsolutePath());
        zkProperties.setProperty("clientPort", String.valueOf(ZK_PORT));

        ServerConfig configuration = new ServerConfig();
        QuorumPeerConfig quorumConfiguration = new QuorumPeerConfig();
        quorumConfiguration.parseProperties(zkProperties);
        configuration.readFrom(quorumConfiguration);

        new Thread() {
            public void run() {
                try {
                    new ZooKeeperServerMain().runFromConfig(configuration);
                } catch (IOException e) {
                    System.out.println("Start of Local ZooKeeper Failed");
                    e.printStackTrace(System.err);
                }
            }
        }.start();
    } else {
        System.out.println("Failed to delete or create data dir for Zookeeper");
    }
}
 
开发者ID:osswangxining,项目名称:iotplatform,代码行数:27,代码来源:KafkaDemoClient.java

示例4: initializeAndRun

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
protected void initializeAndRun(String[] args)
    throws ConfigException, IOException
{
    QuorumPeerConfig config = new QuorumPeerConfig();
    if (args.length == 1) {
        config.parse(args[0]);
    }

    if (args.length == 1 && config.servers.size() > 0) {
        runFromConfig(config);
    } else {
        LOG.warn("Either no config or no quorum defined in config, running "
                + " in standalone mode");
        // there is only server in the quorum -- run as standalone
        ZooKeeperServerMain.main(args);
    }
}
 
开发者ID:gerritjvv,项目名称:bigstreams,代码行数:18,代码来源:QuorumPeerMain.java

示例5: initializeAndRun

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
protected void initializeAndRun(String[] args)
    throws ConfigException, IOException
{
	/**
	 * 解析配置文件,默认的配置文件为上一级目录
	 * config/zookeeper.properties或者config/zookeeper.cfg
	 */
    QuorumPeerConfig config = new QuorumPeerConfig();
    if (args.length == 1) {
        config.parse(args[0]);
    }
    /**
     * 启动安排清除任务,定时清理历史数据(事务日志,以及快照数据)
     * since3.4.0
     */
    // Start and schedule the the purge task
    DatadirCleanupManager purgeMgr = new DatadirCleanupManager(config
            .getDataDir(), config.getDataLogDir(), config
            .getSnapRetainCount(), config.getPurgeInterval());
    purgeMgr.start();
    
    /**
     * 重要点
     * 解析服务器配置地址列表,判断是集群,还是单机模式
     */
    // 集群分支
    if (args.length == 1 && config.servers.size() > 0) {
        runFromConfig(config);
    } else {
    	// 单机分支,standalone(机器里的单身狗;我就是一个孤独患者,有何不可?)
        LOG.warn("Either no config or no quorum defined in config, running "
                + " in standalone mode");
        // there is only server in the quorum -- run as standalone
        //骚气的代码,太露骨了!
        ZooKeeperServerMain.main(args);
    }
}
 
开发者ID:maoling,项目名称:fuck_zookeeper,代码行数:38,代码来源:QuorumPeerMain.java

示例6: runZKServer

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
private static void runZKServer(QuorumPeerConfig zkConfig) throws UnknownHostException, IOException {
  if (zkConfig.isDistributed()) {
    QuorumPeerMain qp = new QuorumPeerMain();
    qp.runFromConfig(zkConfig);
  } else {
    ZooKeeperServerMain zk = new ZooKeeperServerMain();
    ServerConfig serverConfig = new ServerConfig();
    serverConfig.readFrom(zkConfig);
    zk.runFromConfig(serverConfig);
  }
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:12,代码来源:HQuorumPeer.java

示例7: run

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
public void run() throws Exception {
    pidFileLocker.lock();

    server = new ZooKeeperServerMain();
    QuorumPeerConfig qp = new QuorumPeerConfig();
    qp.parseProperties(configuration);
    ServerConfig sc = new ServerConfig();
    sc.readFrom(qp);
    server.runFromConfig(sc);

}
 
开发者ID:diennea,项目名称:herddb,代码行数:12,代码来源:ZooKeeperMainWrapper.java

示例8: initializeAndRun

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
protected void initializeAndRun(String[] args)
    throws ConfigException, IOException
{
    QuorumPeerConfig config = new QuorumPeerConfig();
    if (args.length == 1) {
        // 解析zoo.cfg配置文件
        config.parse(args[0]);
    }

    // Start and schedule the the purge task
    // 自动清理管理
    DatadirCleanupManager purgeMgr = new DatadirCleanupManager(config
            .getDataDir(), config.getDataLogDir(), config
            .getSnapRetainCount(), config.getPurgeInterval());
    // 启动并调度自动清理任务
    purgeMgr.start();

    if (args.length == 1 && config.servers.size() > 0) {
        // 集群方式启动
        runFromConfig(config);
    } else {
        LOG.warn("Either no config or no quorum defined in config, running "
                + " in standalone mode");
        // there is only server in the quorum -- run as standalone
        ZooKeeperServerMain.main(args);
    }
}
 
开发者ID:txazo,项目名称:zookeeper,代码行数:28,代码来源:QuorumPeerMain.java

示例9: stopZooKeeper

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
/**
 * Stops the zookeeper instance listening on the passed port
 * @param port the listening port of the target zookeeper instance
 */
public static void stopZooKeeper(final int port) {
	final ZooKeeperServerMain zoo = zooKeeperServers.remove(port);
	if(zoo!=null) {
		PrivateAccessor.invoke(zoo, "shutdown");
	}
}
 
开发者ID:nickman,项目名称:HeliosStreams,代码行数:11,代码来源:BaseTest.java

示例10: runFlinkZkQuorumPeer

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
/**
 * Runs a ZooKeeper {@link QuorumPeer} if further peers are configured or a single
 * {@link ZooKeeperServer} if no further peers are configured.
 *
 * @param zkConfigFile ZooKeeper config file 'zoo.cfg'
 * @param peerId       ID for the 'myid' file
 */
public static void runFlinkZkQuorumPeer(String zkConfigFile, int peerId) throws Exception {

	Properties zkProps = new Properties();

	try (InputStream inStream = new FileInputStream(new File(zkConfigFile))) {
		zkProps.load(inStream);
	}

	LOG.info("Configuration: " + zkProps);

	// Set defaults for required properties
	setRequiredProperties(zkProps);

	// Write peer id to myid file
	writeMyIdToDataDir(zkProps, peerId);

	// The myid file needs to be written before creating the instance. Otherwise, this
	// will fail.
	QuorumPeerConfig conf = new QuorumPeerConfig();
	conf.parseProperties(zkProps);

	if (conf.isDistributed()) {
		// Run quorum peer
		LOG.info("Running distributed ZooKeeper quorum peer (total peers: {}).",
				conf.getServers().size());

		QuorumPeerMain qp = new QuorumPeerMain();
		qp.runFromConfig(conf);
	}
	else {
		// Run standalone
		LOG.info("Running standalone ZooKeeper quorum peer.");

		ZooKeeperServerMain zk = new ZooKeeperServerMain();
		ServerConfig sc = new ServerConfig();
		sc.readFrom(conf);
		zk.runFromConfig(sc);
	}
}
 
开发者ID:axbaretto,项目名称:flink,代码行数:47,代码来源:FlinkZooKeeperQuorumPeer.java

示例11: start

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
public void start() throws Exception {

        mainsingle = new ZooKeeperServerMain();

        thread = new Thread("zkservermainrunner") {
            @Override
            public void run() {
                try {
                    ServerConfig cc = new ServerConfig();
                    cc.readFrom(config);
                    mainsingle.runFromConfig(cc);
                    System.out.println("ZK server died");
                } catch (Throwable t) {
                    t.printStackTrace();
                }
            }
        };
        thread.start();

        this.cnxnFactory = getServerConnectionFactory();
        if (cnxnFactory != null) {
            final ZooKeeperServer zkServer = getZooKeeperServer(cnxnFactory);
            if (zkServer != null) {
                synchronized (zkServer) {
                    if (!zkServer.isRunning()) {
                        zkServer.wait();
                    }
                }
            }
        }

    }
 
开发者ID:diennea,项目名称:majordodo,代码行数:33,代码来源:TestingZookeeperServerEmbedded.java

示例12: getServerConnectionFactory

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
private ServerCnxnFactory getServerConnectionFactory() throws Exception {
    Field cnxnFactoryField = ZooKeeperServerMain.class.getDeclaredField("cnxnFactory");
    cnxnFactoryField.setAccessible(true);
    ServerCnxnFactory cnxnFactory;

    // Wait until the cnxnFactory field is non-null or up to 1s, whichever comes first.
    long startTime = System.currentTimeMillis();
    do {
        cnxnFactory = (ServerCnxnFactory) cnxnFactoryField.get(mainsingle);
    } while ((cnxnFactory == null) && ((System.currentTimeMillis() - startTime) < 10000));

    return cnxnFactory;
}
 
开发者ID:diennea,项目名称:majordodo,代码行数:14,代码来源:TestingZookeeperServerEmbedded.java

示例13: init

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
@Override
public void init() {
	
	LOG.info("ZooStandalone init called!");
	
	@SuppressWarnings("unused")
	ZooStandalone zoo = new ZooStandalone();
	System.setProperty("jute.maxbuffer", "104857600");

	String[] args = ZooArguments;
	QuorumPeerConfig config = new QuorumPeerConfig();

	if (args.length == 1) {
		try {
			config.parse(args[0]);
		} catch (ConfigException e) {
			LOG.error("Error parsing configuration file!");
		}
	}

	// Start and schedule the the purge task
	DatadirCleanupManager purgeMgr = new DatadirCleanupManager(
			config.getDataDir(), config.getDataLogDir(),
			config.getSnapRetainCount(), config.getPurgeInterval());
	purgeMgr.start();
	LOG.info("No quorum defined in config, running "
			+ " in standalone mode");
	ZooKeeperServerMain.main(args);

}
 
开发者ID:pgaref,项目名称:ACaZoo,代码行数:31,代码来源:ZooStandalone.java

示例14: initializeAndRun

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
protected void initializeAndRun(String[] args) throws ConfigException,
		IOException {

	/*
	 * pgaref
	 */
	args = ZooArguments;
	QuorumPeerConfig config = new QuorumPeerConfig();
	Thread mymod = new Thread(new Myclass(1));

	if (args.length == 1) {
		config.parse(args[0]);
	}

	// Start and schedule the the purge task
	DatadirCleanupManager purgeMgr = new DatadirCleanupManager(
			config.getDataDir(), config.getDataLogDir(),
			config.getSnapRetainCount(), config.getPurgeInterval());
	purgeMgr.start();
	mymod.start();
	if (args.length == 1 && config.servers.size() > 0) {
		runFromConfig(config);
	} else {
		LOG.warn("Either no config or no quorum defined in config, running "
				+ " in standalone mode");
		// there is only server in the quorum -- run as standalone

		ZooKeeperServerMain.main(args);

	}
	mymod.start();
}
 
开发者ID:pgaref,项目名称:ACaZoo,代码行数:33,代码来源:QuorumPeerMain.java

示例15: start

import org.apache.zookeeper.server.ZooKeeperServerMain; //导入依赖的package包/类
public void start() {
  if (zkRun == null) return;

  zkThread = new Thread() {
    @Override
    public void run() {
      try {
        if (zkProps.getServers().size() > 1) {
          QuorumPeerMain zkServer = new QuorumPeerMain();
          zkServer.runFromConfig(zkProps);
        } else {
          ServerConfig sc = new ServerConfig();
          sc.readFrom(zkProps);
          ZooKeeperServerMain zkServer = new ZooKeeperServerMain();
          zkServer.runFromConfig(sc);
        }
        log.info("ZooKeeper Server exited.");
      } catch (Exception e) {
        log.error("ZooKeeper Server ERROR", e);
        throw new SolrException(SolrException.ErrorCode.SERVER_ERROR, e);
      }
    }
  };

  if (zkProps.getServers().size() > 1) {
    log.info("STARTING EMBEDDED ENSEMBLE ZOOKEEPER SERVER at port " + zkProps.getClientPortAddress().getPort());
  } else {
    log.info("STARTING EMBEDDED STANDALONE ZOOKEEPER SERVER at port " + zkProps.getClientPortAddress().getPort());
  }

  zkThread.setDaemon(true);
  zkThread.start();
  try {
    Thread.sleep(500); // pause for ZooKeeper to start
  } catch (Exception e) {
    log.error("STARTING ZOOKEEPER", e);
  }
}
 
开发者ID:europeana,项目名称:search,代码行数:39,代码来源:SolrZkServer.java


注:本文中的org.apache.zookeeper.server.ZooKeeperServerMain类示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。