Examples of NamedThreadFactory


Examples of org.apache.cassandra.concurrent.NamedThreadFactory

    private static class CompactionExecutor extends ThreadPoolExecutor
    {
        protected CompactionExecutor(int minThreads, int maxThreads, String name, BlockingQueue<Runnable> queue)
        {
            super(minThreads, maxThreads, 60, TimeUnit.SECONDS, queue, new NamedThreadFactory(name, Thread.MIN_PRIORITY));
            allowCoreThreadTimeOut(true);
        }
View Full Code Here

Examples of org.apache.cassandra.concurrent.NamedThreadFactory

    private static class CompactionExecutor extends ThreadPoolExecutor
    {

        protected CompactionExecutor(int minThreads, int maxThreads, String name, BlockingQueue<Runnable> queue)
        {
            super(minThreads, maxThreads, 60, TimeUnit.SECONDS, queue, new NamedThreadFactory(name, Thread.MIN_PRIORITY));
            allowCoreThreadTimeOut(true);
        }
View Full Code Here

Examples of org.apache.cassandra.concurrent.NamedThreadFactory

    private static class CompactionExecutor extends ThreadPoolExecutor
    {

        protected CompactionExecutor(int minThreads, int maxThreads, String name, BlockingQueue<Runnable> queue)
        {
            super(minThreads, maxThreads, 60, TimeUnit.SECONDS, queue, new NamedThreadFactory(name, Thread.MIN_PRIORITY));
            allowCoreThreadTimeOut(true);
        }
View Full Code Here

Examples of org.apache.cassandra.concurrent.NamedThreadFactory

        private volatile long totalBytesCompacted = 0L;
        private volatile long totalCompactionsCompleted = 0L;

        protected CompactionExecutor(int minThreads, int maxThreads, String name, BlockingQueue<Runnable> queue)
        {
            super(minThreads, maxThreads, 60, TimeUnit.SECONDS, queue, new NamedThreadFactory(name, Thread.MIN_PRIORITY));
            allowCoreThreadTimeOut(true);
        }
View Full Code Here

Examples of org.apache.drill.exec.rpc.NamedThreadFactory

  private final BitCom bitCom;
  private final DrillConfig config;
  boolean useIP = false;
 
  public ServiceEngine(BitComHandler bitComWorker, UserWorker userWorker, BootStrapContext context){
    this.userServer = new UserServer(context.getAllocator().getUnderlyingAllocator(), new NioEventLoopGroup(1, new NamedThreadFactory("UserServer-")), userWorker);
    this.bitCom = new BitComImpl(context, bitComWorker);
    this.config = context.getConfig();
  }
View Full Code Here

Examples of org.apache.hadoop.hbase.hbql.util.NamedThreadFactory

        this.threadPoolExecutor = new LocalThreadPoolExecutor(minThreadCount,
                                                              maxThreadCount,
                                                              keepAliveSecs,
                                                              TimeUnit.SECONDS,
                                                              backingQueue,
                                                              new NamedThreadFactory(name),
                                                              new LocalCallerRunsPolicy());
        this.completionQueue = new CompletionQueue<T>(completionQueueSize);
    }
View Full Code Here

Examples of org.apache.jackrabbit.core.data.util.NamedThreadFactory

        void upload() throws DataStoreException {
            long startTime = System.currentTimeMillis();
            LOG.info(" Uploading [{}] using [{}] threads.", files.size(), threads);
            ExecutorService executor = Executors.newFixedThreadPool(threads,
                new NamedThreadFactory("backend-file-upload-worker"));
            int partitionSize = files.size() / (threads);
            int startIndex = 0;
            int endIndex = partitionSize;
            for (int i = 1; i <= threads; i++) {
                List<File> partitionFileList = Collections.unmodifiableList(files.subList(
View Full Code Here

Examples of org.apache.james.util.concurrent.NamedThreadFactory

    private int totalTasks;
    private MBeanServer mbeanServer;
    private String mbeanName;
   
    public JMXEnabledOrderedMemoryAwareThreadPoolExecutor(int corePoolSize, long maxChannelMemorySize, long maxTotalMemorySize, String jmxPath, String name) {
        super(corePoolSize, maxChannelMemorySize, maxTotalMemorySize, 30, TimeUnit.SECONDS, new NamedThreadFactory(name));
        this.jmxPath = jmxPath;
        registerMBean();
    }
View Full Code Here

Examples of org.apache.lucene.util.NamedThreadFactory

  private final int[] starts;

  /** Creates a {@link Searchable} which searches <i>searchables</i> with the default
   * executor service (a cached thread pool). */
  public ParallelMultiSearcher(Searchable... searchables) throws IOException {
    this(Executors.newCachedThreadPool(new NamedThreadFactory(ParallelMultiSearcher.class.getSimpleName())), searchables);
  }
View Full Code Here

Examples of org.apache.lucene.util.NamedThreadFactory

        ex = null;
      } else {
        threads = _TestUtil.nextInt(random, 1, 8);
        ex = new ThreadPoolExecutor(threads, threads, 0L, TimeUnit.MILLISECONDS,
            new LinkedBlockingQueue<Runnable>(),
            new NamedThreadFactory("LuceneTestCase"));
      }
      if (ex != null) {
       if (VERBOSE) {
        System.out.println("NOTE: newSearcher using ExecutorService with " + threads + " threads");
       }
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.