Package org.apache.cassandra.concurrent

Examples of org.apache.cassandra.concurrent.ThreadFactoryImpl


    runner_ = new DebuggableThreadPoolExecutor( numThreads,
        numThreads,
              Integer.MAX_VALUE,
              TimeUnit.SECONDS,
              new LinkedBlockingQueue<Runnable>(),
              new ThreadFactoryImpl("MEMTABLE-FLUSHER-POOL")
              )
    if(config.getInt("mailboxstress") == 1)
    {
//      stressMailboxWrites();
      return;
View Full Code Here


    {
        FutureTask flushQueuer;

        public MemtableThreadPoolExecutor()
        {
            super(1, 1, Integer.MAX_VALUE, TimeUnit.SECONDS, new LinkedBlockingQueue<Runnable>(), new ThreadFactoryImpl("FAST-MEMTABLE-POOL"));
        }
View Full Code Here

        /* register the stage for the mutations */
        int threadCount = DatabaseDescriptor.getThreadsPerPool();
        consistencyManager_ = new DebuggableThreadPoolExecutor(threadCount,
            threadCount,
                Integer.MAX_VALUE, TimeUnit.SECONDS,
                new LinkedBlockingQueue<Runnable>(), new ThreadFactoryImpl(
                        "CONSISTENCY-MANAGER"));
       
        StageManager.registerStage(StorageService.mutationStage_, new MultiThreadedStage(StorageService.mutationStage_, threadCount));
        StageManager.registerStage(StorageService.readStage_, new MultiThreadedStage(StorageService.readStage_, 2*threadCount));       
        StageManager.registerStage(StorageService.mrStage_, new MultiThreadedStage(StorageService.mrStage_, threadCount));
View Full Code Here

      }
    }
  }

  public DataImporter() throws Throwable {
    tf_ = new ThreadFactoryImpl("LOAD-GENERATOR");
    pool_ = new DebuggableScheduledThreadPoolExecutor(100, tf_);
    fos_ = new FileOutputStream("keys.dat", true);
  }
View Full Code Here

        messageDeserializationExecutor_ = new DebuggableThreadPoolExecutor( maxSize,
                maxSize,
                Integer.MAX_VALUE,
                TimeUnit.SECONDS,
                new LinkedBlockingQueue<Runnable>(),
                new ThreadFactoryImpl("MESSAGING-SERVICE-POOL")
                );
               
        messageSerializerExecutor_ = new DebuggableThreadPoolExecutor( maxSize,
                maxSize,
                Integer.MAX_VALUE,
                TimeUnit.SECONDS,
                new LinkedBlockingQueue<Runnable>(),
                new ThreadFactoryImpl("MESSAGE-SERIALIZER-POOL")
                );
       
        messageDeserializerExecutor_ = new DebuggableThreadPoolExecutor( maxSize,
                maxSize,
                Integer.MAX_VALUE,
                TimeUnit.SECONDS,
                new LinkedBlockingQueue<Runnable>(),
                new ThreadFactoryImpl("MESSAGE-DESERIALIZER-POOL")
                );
       
        streamExecutor_ = new DebuggableThreadPoolExecutor( 1,
                1,
                Integer.MAX_VALUE,
                TimeUnit.SECONDS,
                new LinkedBlockingQueue<Runnable>(),
                new ThreadFactoryImpl("MESSAGE-STREAMING-POOL")
                );
               
        protocol_ = hash(HashingSchemes.MD5, "FB-MESSAGING".getBytes());       
        /* register the response verb handler */
        registerVerbHandlers(MessagingService.responseVerbHandler_, new ResponseVerbHandler());
View Full Code Here

TOP

Related Classes of org.apache.cassandra.concurrent.ThreadFactoryImpl

Copyright © 2018 www.massapicom. 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.