Java Code Examples for com.alipay.sofa.jraft.option.NodeOptions#setEnableMetrics()
The following examples show how to use
com.alipay.sofa.jraft.option.NodeOptions#setEnableMetrics() .
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example 1
Source File: AtomicRangeGroup.java From sofa-jraft with Apache License 2.0 | 5 votes |
public AtomicRangeGroup(String dataPath, String groupId, PeerId serverId, long minSlot, long maxSlot, NodeOptions nodeOptions, RpcServer rpcServer) throws IOException { // Init file path FileUtils.forceMkdir(new File(dataPath)); this.minSlot = minSlot; this.maxSlot = maxSlot; // Init statemachine this.fsm = new AtomicStateMachine(); // Set statemachine to bootstrap options nodeOptions.setFsm(this.fsm); nodeOptions.setEnableMetrics(true); nodeOptions.getRaftOptions().setReplicatorPipeline(true); nodeOptions.getRaftOptions().setSync(true); nodeOptions.getRaftOptions().setReadOnlyOptions(ReadOnlyOption.ReadOnlySafe); // Set the data path // Log, required nodeOptions.setLogUri(dataPath + File.separator + "log"); // Metadata, required nodeOptions.setRaftMetaUri(dataPath + File.separator + "raft_meta"); // Snapshot, not required, but recommend nodeOptions.setSnapshotUri(dataPath + File.separator + "snapshot"); // Init raft group service framework this.raftGroupService = new RaftGroupService(groupId, serverId, nodeOptions, rpcServer); // Startup node this.node = this.raftGroupService.start(); final ConsoleReporter reporter = ConsoleReporter.forRegistry(node.getNodeMetrics().getMetricRegistry()) .convertRatesTo(TimeUnit.SECONDS).convertDurationsTo(TimeUnit.MILLISECONDS).build(); reporter.start(60, TimeUnit.SECONDS); }
Example 2
Source File: TestCluster.java From sofa-jraft with Apache License 2.0 | 4 votes |
public boolean start(final Endpoint listenAddr, final boolean emptyPeers, final int snapshotIntervalSecs, final boolean enableMetrics, final SnapshotThrottle snapshotThrottle, final RaftOptions raftOptions, final int priority) throws IOException { if (this.serverMap.get(listenAddr.toString()) != null) { return true; } final NodeOptions nodeOptions = new NodeOptions(); nodeOptions.setElectionTimeoutMs(this.electionTimeoutMs); nodeOptions.setEnableMetrics(enableMetrics); nodeOptions.setSnapshotThrottle(snapshotThrottle); nodeOptions.setSnapshotIntervalSecs(snapshotIntervalSecs); if (raftOptions != null) { nodeOptions.setRaftOptions(raftOptions); } final String serverDataPath = this.dataPath + File.separator + listenAddr.toString().replace(':', '_'); FileUtils.forceMkdir(new File(serverDataPath)); nodeOptions.setLogUri(serverDataPath + File.separator + "logs"); nodeOptions.setRaftMetaUri(serverDataPath + File.separator + "meta"); nodeOptions.setSnapshotUri(serverDataPath + File.separator + "snapshot"); nodeOptions.setElectionPriority(priority); final MockStateMachine fsm = new MockStateMachine(listenAddr); nodeOptions.setFsm(fsm); if (!emptyPeers) { nodeOptions.setInitialConf(new Configuration(this.peers, this.learners)); } final RpcServer rpcServer = RaftRpcServerFactory.createRaftRpcServer(listenAddr); final RaftGroupService server = new RaftGroupService(this.name, new PeerId(listenAddr, 0, priority), nodeOptions, rpcServer); this.lock.lock(); try { if (this.serverMap.put(listenAddr.toString(), server) == null) { final Node node = server.start(); this.fsms.put(new PeerId(listenAddr, 0), fsm); this.nodes.add((NodeImpl) node); return true; } } finally { this.lock.unlock(); } return false; }
Example 3
Source File: TestCluster.java From sofa-jraft with Apache License 2.0 | 4 votes |
public boolean start(final Endpoint listenAddr, final boolean emptyPeers, final int snapshotIntervalSecs, final boolean enableMetrics, final SnapshotThrottle snapshotThrottle, final RaftOptions raftOptions) throws IOException { if (this.serverMap.get(listenAddr.toString()) != null) { return true; } final NodeOptions nodeOptions = new NodeOptions(); nodeOptions.setElectionTimeoutMs(this.electionTimeoutMs); nodeOptions.setEnableMetrics(enableMetrics); nodeOptions.setSnapshotThrottle(snapshotThrottle); nodeOptions.setSnapshotIntervalSecs(snapshotIntervalSecs); if (raftOptions != null) { nodeOptions.setRaftOptions(raftOptions); } final String serverDataPath = this.dataPath + File.separator + listenAddr.toString().replace(':', '_'); FileUtils.forceMkdir(new File(serverDataPath)); nodeOptions.setLogUri(serverDataPath + File.separator + "logs"); nodeOptions.setRaftMetaUri(serverDataPath + File.separator + "meta"); nodeOptions.setSnapshotUri(serverDataPath + File.separator + "snapshot"); final MockStateMachine fsm = new MockStateMachine(listenAddr); nodeOptions.setFsm(fsm); if (!emptyPeers) { nodeOptions.setInitialConf(new Configuration(this.peers, this.learners)); } final RpcServer rpcServer = RaftRpcServerFactory.createRaftRpcServer(listenAddr); final RaftGroupService server = new RaftGroupService(this.name, new PeerId(listenAddr, 0), nodeOptions, rpcServer); this.lock.lock(); try { if (this.serverMap.put(listenAddr.toString(), server) == null) { final Node node = server.start(); this.fsms.put(new PeerId(listenAddr, 0), fsm); this.nodes.add((NodeImpl) node); return true; } } finally { this.lock.unlock(); } return false; }
Example 4
Source File: TestCluster.java From sofa-jraft with Apache License 2.0 | 4 votes |
public boolean start(final Endpoint listenAddr, final boolean emptyPeers, final int snapshotIntervalSecs, final boolean enableMetrics, final SnapshotThrottle snapshotThrottle, final RaftOptions raftOptions, final int priority) throws IOException { if (this.serverMap.get(listenAddr.toString()) != null) { return true; } final NodeOptions nodeOptions = new NodeOptions(); nodeOptions.setElectionTimeoutMs(this.electionTimeoutMs); nodeOptions.setEnableMetrics(enableMetrics); nodeOptions.setSnapshotThrottle(snapshotThrottle); nodeOptions.setSnapshotIntervalSecs(snapshotIntervalSecs); nodeOptions.setServiceFactory(this.raftServiceFactory); if (raftOptions != null) { nodeOptions.setRaftOptions(raftOptions); } final String serverDataPath = this.dataPath + File.separator + listenAddr.toString().replace(':', '_'); FileUtils.forceMkdir(new File(serverDataPath)); nodeOptions.setLogUri(serverDataPath + File.separator + "logs"); nodeOptions.setRaftMetaUri(serverDataPath + File.separator + "meta"); nodeOptions.setSnapshotUri(serverDataPath + File.separator + "snapshot"); nodeOptions.setElectionPriority(priority); final MockStateMachine fsm = new MockStateMachine(listenAddr); nodeOptions.setFsm(fsm); if (!emptyPeers) { nodeOptions.setInitialConf(new Configuration(this.peers, this.learners)); } final RpcServer rpcServer = RaftRpcServerFactory.createRaftRpcServer(listenAddr); final RaftGroupService server = new RaftGroupService(this.name, new PeerId(listenAddr, 0, priority), nodeOptions, rpcServer); this.lock.lock(); try { if (this.serverMap.put(listenAddr.toString(), server) == null) { final Node node = server.start(); this.fsms.put(new PeerId(listenAddr, 0), fsm); this.nodes.add((NodeImpl) node); return true; } } finally { this.lock.unlock(); } return false; }
Example 5
Source File: TestCluster.java From sofa-jraft with Apache License 2.0 | 4 votes |
public boolean start(final Endpoint listenAddr, final boolean emptyPeers, final int snapshotIntervalSecs, final boolean enableMetrics, final SnapshotThrottle snapshotThrottle, final RaftOptions raftOptions) throws IOException { if (this.serverMap.get(listenAddr.toString()) != null) { return true; } final NodeOptions nodeOptions = new NodeOptions(); nodeOptions.setElectionTimeoutMs(this.electionTimeoutMs); nodeOptions.setEnableMetrics(enableMetrics); nodeOptions.setSnapshotThrottle(snapshotThrottle); nodeOptions.setSnapshotIntervalSecs(snapshotIntervalSecs); nodeOptions.setServiceFactory(this.raftServiceFactory); if (raftOptions != null) { nodeOptions.setRaftOptions(raftOptions); } final String serverDataPath = this.dataPath + File.separator + listenAddr.toString().replace(':', '_'); FileUtils.forceMkdir(new File(serverDataPath)); nodeOptions.setLogUri(serverDataPath + File.separator + "logs"); nodeOptions.setRaftMetaUri(serverDataPath + File.separator + "meta"); nodeOptions.setSnapshotUri(serverDataPath + File.separator + "snapshot"); final MockStateMachine fsm = new MockStateMachine(listenAddr); nodeOptions.setFsm(fsm); if (!emptyPeers) { nodeOptions.setInitialConf(new Configuration(this.peers, this.learners)); } final RpcServer rpcServer = RaftRpcServerFactory.createRaftRpcServer(listenAddr); final RaftGroupService server = new RaftGroupService(this.name, new PeerId(listenAddr, 0), nodeOptions, rpcServer); this.lock.lock(); try { if (this.serverMap.put(listenAddr.toString(), server) == null) { final Node node = server.start(); this.fsms.put(new PeerId(listenAddr, 0), fsm); this.nodes.add((NodeImpl) node); return true; } } finally { this.lock.unlock(); } return false; }
Example 6
Source File: RaftServer.java From sofa-registry with Apache License 2.0 | 4 votes |
private NodeOptions initNodeOptions(RaftServerConfig raftServerConfig) { NodeOptions nodeOptions = new NodeOptions(); nodeOptions.setElectionTimeoutMs(raftServerConfig.getElectionTimeoutMs()); nodeOptions.setDisableCli(false); nodeOptions.setSnapshotIntervalSecs(raftServerConfig.getSnapshotIntervalSecs()); nodeOptions.setInitialConf(initConf); nodeOptions.setFsm(this.fsm); nodeOptions.setLogUri(dataPath + File.separator + "log"); nodeOptions.setRaftMetaUri(dataPath + File.separator + "raft_meta"); nodeOptions.setSnapshotUri(dataPath + File.separator + "snapshot"); if (raftServerConfig.isEnableMetrics()) { nodeOptions.setEnableMetrics(raftServerConfig.isEnableMetrics()); } // See https://github.com/sofastack/sofa-jraft/pull/156 final BlockBasedTableConfig conf = new BlockBasedTableConfig() // // Begin to use partitioned index filters // https://github.com/facebook/rocksdb/wiki/Partitioned-Index-Filters#how-to-use-it .setIndexType(IndexType.kTwoLevelIndexSearch) // .setFilter(new BloomFilter(16, false)) // .setPartitionFilters(true) // .setMetadataBlockSize(8 * SizeUnit.KB) // .setCacheIndexAndFilterBlocks(false) // .setCacheIndexAndFilterBlocksWithHighPriority(true) // .setPinL0FilterAndIndexBlocksInCache(true) // // End of partitioned index filters settings. .setBlockSize(4 * SizeUnit.KB)// .setBlockCacheSize(raftServerConfig.getRockDBCacheSize() * SizeUnit.MB) // .setCacheNumShardBits(8); StorageOptionsFactory.registerRocksDBTableFormatConfig(RocksDBLogStorage.class, conf); return nodeOptions; }