Examples of DaemonThreadFactory


Examples of org.jruby.threading.DaemonThreadFactory

                RubyInstanceConfig.POOL_MIN,
                RubyInstanceConfig.POOL_MAX,
                RubyInstanceConfig.POOL_TTL,
                TimeUnit.SECONDS,
                new SynchronousQueue<Runnable>(),
                new DaemonThreadFactory("JRubyWorker"));
       
        // initialize the root of the class hierarchy completely
        initRoot();

        // Set up the main thread in thread service
View Full Code Here

Examples of org.mule.util.concurrent.DaemonThreadFactory

        }

        if (scheduler == null)
        {
            this.scheduler = new ScheduledThreadPoolExecutor(1);
            scheduler.setThreadFactory(new DaemonThreadFactory(name + "-Monitor", this.getClass().getClassLoader()));
            scheduler.scheduleWithFixedDelay(this, 0, expirationInterval, TimeUnit.MILLISECONDS);
        }
    }
View Full Code Here

Examples of org.mule.util.concurrent.DaemonThreadFactory

        }
        monitors = new ConcurrentHashMap();
        if (scheduler == null)
        {
            this.scheduler = new ScheduledThreadPoolExecutor(1);
            scheduler.setThreadFactory(new DaemonThreadFactory(name + ".expiry.monitor", contextClassLoader));
            scheduler.scheduleWithFixedDelay(this, 0, monitorFrequency,
                                             TimeUnit.MILLISECONDS);
        }
    }
View Full Code Here

Examples of org.neo4j.smack.pipeline.DaemonThreadFactory

        // NETTY
       
        channelFactory =
            new NioServerSocketChannelFactory(
                    Executors.newCachedThreadPool(new DaemonThreadFactory("SocketMaster")),
                    Executors.newCachedThreadPool(new DaemonThreadFactory("SocketSlave")));
        netty = new ServerBootstrap(channelFactory);

        // Set up the event pipeline factory.
        netty.setPipelineFactory(new NettyHttpPipelineFactory(inputPipeline, openChannels));
View Full Code Here

Examples of org.rzo.yajsw.util.DaemonThreadFactory

    connector.getPipeline().addLast("messageEncoder", new MessageEncoder());
    connector.getPipeline().addLast("messageDecoder", new MessageDecoder());

    // pinger is a cycler with high priority threads
    // sends ping messages within a ping interval
    _pinger = new Cycler(getPingInterval(), 0, Executors.newCachedThreadPool(new DaemonThreadFactory("pinger", Thread.MAX_PRIORITY)),
        new Runnable()
        {
          long  start  = System.currentTimeMillis();

          public void run()
View Full Code Here

Examples of org.rzo.yajsw.util.DaemonThreadFactory

    {
      e.printStackTrace();
    }
    InputStreamReader isr = new InputStreamReader(reader);
    final BufferedReader br = new BufferedReader(isr);
    Executor executor = Executors.newCachedThreadPool(new DaemonThreadFactory("test"));
    executor.execute(new Runnable()
    {

      public void run()
      {
View Full Code Here

Examples of voldemort.utils.DaemonThreadFactory

                                    metadata,
                                    servers[nodeId].getStoreRepository(),
                                    new NoopFailureDetector(),
                                    storeFactory,
                                    Executors.newFixedThreadPool(1,
                                                                 new DaemonThreadFactory("voldemort-proxy-put-thread")),
                                    new ProxyPutStats(null));
    }
View Full Code Here

Examples of voldemort.utils.DaemonThreadFactory

        this.endpoint = new InetSocketAddress(port);

        this.selectorManagers = new NioSelectorManager[selectors];
        this.selectorManagerThreadPool = Executors.newFixedThreadPool(selectorManagers.length,
                                                                      new DaemonThreadFactory("voldemort-niosocket-server"));
        this.statusManager = new StatusManager((ThreadPoolExecutor) this.selectorManagerThreadPool);
        this.acceptorThread = new Thread(new Acceptor(), "NioSocketService.Acceptor");
    }
View Full Code Here

Examples of voldemort.utils.DaemonThreadFactory

        } else
            this.dynThrottleLimit = null;

        // create the proxy put thread pool
        this.proxyPutWorkerPool = Executors.newFixedThreadPool(config.getMaxProxyPutThreads(),
                                                               new DaemonThreadFactory("voldemort-proxy-put-thread"));
        this.aggregatedProxyPutStats = new ProxyPutStats(null);
        if(config.isJmxEnabled()) {
            JmxUtils.registerMbean(this.aggregatedProxyPutStats,
                                   JmxUtils.createObjectName("voldemort.store.rebalancing",
                                                             "aggregate-proxy-puts"));
View Full Code Here

Examples of voldemort.utils.DaemonThreadFactory

        super(maxThreads,
              maxThreads,
              threadIdleMs,
              TimeUnit.MILLISECONDS,
              new LinkedBlockingQueue<Runnable>(maxQueuedRequests),
              new DaemonThreadFactory("voldemort-client-thread-"),
              new ThreadPoolExecutor.CallerRunsPolicy());
    }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.