Search in sources :

Example 1 with AffinityNamedThreadFactory

use of io.dingodb.store.row.util.concurrent.AffinityNamedThreadFactory in project dingo by dingodb.

the class DefaultDingoRowStore method init.

@Override
public synchronized boolean init(final DingoRowStoreOptions opts) {
    if (this.started) {
        LOG.info("[DefaultDingoRowStore] already started.");
        return true;
    }
    DescriberManager.getInstance().addDescriber(RouteTable.getInstance());
    this.opts = opts;
    // init placement driver
    final PlacementDriverOptions pdOpts = opts.getPlacementDriverOptions();
    final String clusterName = opts.getClusterName();
    Requires.requireNonNull(pdOpts, "opts.placementDriverOptions");
    Requires.requireNonNull(clusterName, "opts.clusterName");
    if (Strings.isBlank(pdOpts.getInitialServerList())) {
        // if blank, extends parent's value
        pdOpts.setInitialServerList(opts.getInitialServerList());
    }
    if (pdOpts.isFake()) {
        this.pdClient = new FakePlacementDriverClient(opts.getClusterId(), clusterName);
    } else {
        this.pdClient = new RemotePlacementDriverClient(opts.getClusterId(), clusterName);
    }
    if (!this.pdClient.init(pdOpts)) {
        LOG.error("Fail to init [PlacementDriverClient].");
        return false;
    }
    // init compress strategies
    ZipStrategyManager.init(opts);
    // init store engine
    final StoreEngineOptions stOpts = opts.getStoreEngineOptions();
    if (stOpts != null) {
        stOpts.setInitialServerList(opts.getInitialServerList());
        this.storeEngine = new StoreEngine(this.pdClient, this.stateListenerContainer);
        if (!this.storeEngine.init(stOpts)) {
            LOG.error("Fail to init [StoreEngine].");
            return false;
        }
    }
    final Endpoint selfEndpoint = this.storeEngine == null ? null : this.storeEngine.getSelfEndpoint();
    final RpcOptions rpcOpts = opts.getRpcOptions();
    Requires.requireNonNull(rpcOpts, "opts.rpcOptions");
    this.dingoRowStoreRpcService = new DefaultDingoRowStoreRpcService(this.pdClient, selfEndpoint) {

        @Override
        public Endpoint getLeader(final String regionId, final boolean forceRefresh, final long timeoutMillis) {
            final Endpoint leader = getLeaderByRegionEngine(regionId);
            if (leader != null) {
                return leader;
            }
            return super.getLeader(regionId, forceRefresh, timeoutMillis);
        }
    };
    if (!this.dingoRowStoreRpcService.init(rpcOpts)) {
        LOG.error("Fail to init [DingoRowStoreRpcService].");
        return false;
    }
    this.failoverRetries = opts.getFailoverRetries();
    this.futureTimeoutMillis = opts.getFutureTimeoutMillis();
    this.onlyLeaderRead = opts.isOnlyLeaderRead();
    if (opts.isUseParallelKVExecutor()) {
        final int numWorkers = Utils.cpus();
        final int bufSize = numWorkers << 4;
        final String name = "parallel-kv-executor";
        final ThreadFactory threadFactory = Constants.THREAD_AFFINITY_ENABLED ? new AffinityNamedThreadFactory(name, true) : new NamedThreadFactory(name, true);
        this.kvDispatcher = new TaskDispatcher(bufSize, numWorkers, WaitStrategyType.LITE_BLOCKING_WAIT, threadFactory);
    }
    this.batchingOpts = opts.getBatchingOptions();
    if (this.batchingOpts.isAllowBatching()) {
        this.getBatching = new GetBatching(KeyEvent::new, "get_batching", new GetBatchingHandler("get", false));
        this.getBatchingOnlySafe = new GetBatching(KeyEvent::new, "get_batching_only_safe", new GetBatchingHandler("get_only_safe", true));
        this.putBatching = new PutBatching(KVEvent::new, "put_batching", new PutBatchingHandler("put"));
    }
    LOG.info("[DefaultDingoRowStore] start successfully, options: {}.", opts);
    return this.started = true;
}
Also used : ThreadFactory(java.util.concurrent.ThreadFactory) AffinityNamedThreadFactory(io.dingodb.store.row.util.concurrent.AffinityNamedThreadFactory) NamedThreadFactory(io.dingodb.raft.util.NamedThreadFactory) PlacementDriverOptions(io.dingodb.store.row.options.PlacementDriverOptions) AffinityNamedThreadFactory(io.dingodb.store.row.util.concurrent.AffinityNamedThreadFactory) NamedThreadFactory(io.dingodb.raft.util.NamedThreadFactory) RemotePlacementDriverClient(io.dingodb.store.row.client.pd.RemotePlacementDriverClient) Endpoint(io.dingodb.raft.util.Endpoint) StoreEngine(io.dingodb.store.row.StoreEngine) RpcOptions(io.dingodb.store.row.options.RpcOptions) Endpoint(io.dingodb.raft.util.Endpoint) TaskDispatcher(io.dingodb.store.row.util.concurrent.disruptor.TaskDispatcher) FakePlacementDriverClient(io.dingodb.store.row.client.pd.FakePlacementDriverClient) StoreEngineOptions(io.dingodb.store.row.options.StoreEngineOptions) AffinityNamedThreadFactory(io.dingodb.store.row.util.concurrent.AffinityNamedThreadFactory)

Aggregations

Endpoint (io.dingodb.raft.util.Endpoint)1 NamedThreadFactory (io.dingodb.raft.util.NamedThreadFactory)1 StoreEngine (io.dingodb.store.row.StoreEngine)1 FakePlacementDriverClient (io.dingodb.store.row.client.pd.FakePlacementDriverClient)1 RemotePlacementDriverClient (io.dingodb.store.row.client.pd.RemotePlacementDriverClient)1 PlacementDriverOptions (io.dingodb.store.row.options.PlacementDriverOptions)1 RpcOptions (io.dingodb.store.row.options.RpcOptions)1 StoreEngineOptions (io.dingodb.store.row.options.StoreEngineOptions)1 AffinityNamedThreadFactory (io.dingodb.store.row.util.concurrent.AffinityNamedThreadFactory)1 TaskDispatcher (io.dingodb.store.row.util.concurrent.disruptor.TaskDispatcher)1 ThreadFactory (java.util.concurrent.ThreadFactory)1