congrats Icon
New! Announcing Tabnine Chat Beta
Learn More
Tabnine Logo
WorkerOptions
Code IndexAdd Tabnine to your IDE (free)

How to use
WorkerOptions
in
com.obsidiandynamics.worker

Best Java code snippets using com.obsidiandynamics.worker.WorkerOptions (Showing top 14 results out of 315)

origin: com.obsidiandynamics.blackstrom/blackstrom-core

public SingleNodeQueueLedger(Config config) {
 maxYields = config.maxYields;
 thread = WorkerThread.builder()
   .withOptions(new WorkerOptions()
          .daemon()
          .withName(SingleNodeQueueLedger.class, Integer.toHexString(System.identityHashCode(this))))
   .onCycle(this::cycle)
   .buildAndStart();
}

origin: com.obsidiandynamics.fulcrum/fulcrum-worker

WorkerThread(WorkerOptions options, 
       WorkerCycle onCycle, 
       WorkerStartup onStartup, 
       WorkerShutdown onShutdown, 
       WorkerExceptionHandler onUncaughtException) {
 this.worker = onCycle;
 this.onStartup = onStartup;
 this.onShutdown = onShutdown;
 this.onUncaughtException = onUncaughtException;
 driver = new Thread(this::run);
 
 if (options.getName() != null) {
  driver.setName(options.getName());
 }
 
 driver.setDaemon(options.isDaemon());
 driver.setPriority(options.getPriority());
}

origin: com.obsidiandynamics.fulcrum/fulcrum-worker

/**
 *  Helper for naming the thread by taking the simple name of the given class (i.e. {@link Class#getSimpleName()})
 *  and concatenating hyphen-delimited {@code nameFrags}.<p>
 *  
 *  Example 1: {@code withName(Reaper.class)} results in {@code Reaper}.<br>
 *  Example 2: {@code withName(Reaper.class, "collector", 0)} results in {@code Reaper-collector-0}.<br>
 *  
 *  @param cls The class name.
 *  @param nameFrags The name fragments.
 *  @return This {@link WorkerOptions} instance for fluent chaining.
 */
public WorkerOptions withName(Class<?> cls, Object... nameFrags) {
 final String name = new Concat()
   .append(cls.getSimpleName())
   .when(nameFrags.length > 0).append(new Concat().append("-").appendArray("-", nameFrags))
   .toString();
 return withName(name);
}
origin: com.obsidiandynamics.fulcrum/fulcrum-scheduler

public TaskScheduler(String threadName) {
 executor = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(threadName))
   .onCycle(this::cycle)
   .build();
}

origin: com.obsidiandynamics.fulcrum/fulcrum-flow

public Flow(FiringStrategy.Factory firingStrategyFactory, String threadName) {
 executor = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(threadName))
   .onCycle(firingStrategyFactory.create(this, tail))
   .buildAndStart();
}

origin: com.obsidiandynamics.jackdaw/jackdaw-core

public AsyncReceiver(Consumer<K, V> consumer, int pollTimeoutMillis, String threadName, 
           RecordHandler<K, V> recordHandler, ExceptionHandler exceptionHandler) {
 this.consumer = consumer;
 this.pollTimeoutMillis = pollTimeoutMillis;
 this.recordHandler = recordHandler;
 this.exceptionHandlerHandler = exceptionHandler;
 thread = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(threadName))
   .onCycle(this::cycle)
   .onShutdown(this::shutdown)
   .buildAndStart();
}

origin: com.obsidiandynamics.jackdaw/jackdaw-core

public ConsumerPipe(ConsumerPipeConfig config, RecordHandler<K, V> handler, String threadName) {
 this.handler = handler;
 if (config.isAsync()) {
  mustExist(threadName, "Thread name cannot be null");
  queue = new LinkedBlockingQueue<>(config.getBacklogBatches());
  thread = WorkerThread.builder()
    .withOptions(new WorkerOptions().daemon().withName(threadName))
    .onCycle(this::cycle)
    .buildAndStart();
 } else {
  queue = null;
  thread = null;
 }
}

origin: com.obsidiandynamics.meteor/meteor-core

DefaultReceiver(Subscriber subscriber, RecordHandler recordHandler, int pollTimeoutMillis) {
 this.subscriber = subscriber;
 this.recordHandler = recordHandler;
 this.pollTimeoutMillis = pollTimeoutMillis;
 pollerThread = WorkerThread.builder()
   .withOptions(new WorkerOptions()
          .daemon()
          .withName(Receiver.class, subscriber.getConfig().getStreamConfig().getName(), "poller"))
   .onCycle(this::pollerCycle)
   .buildAndStart();
}

origin: com.obsidiandynamics.blackstrom/blackstrom-core

@Override
public void attach(MessageHandler handler) {
 if (handler.getGroupId() != null && ! groups.add(handler.getGroupId())) return;
 
 final WorkerThread thread = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(MultiNodeQueueLedger.class, handler.getGroupId()))
   .onCycle(new NodeWorker(handler, handler.getGroupId(), queue.consumer()))
   .buildAndStart();
 threads.add(thread);
}

origin: com.obsidiandynamics.blackstrom/blackstrom-core

public MonitorEngine(MonitorAction action, String groupId, MonitorEngineConfig config) {
 this.groupId = groupId;
 trackingEnabled = config.isTrackingEnabled();
 gcIntervalMillis = config.getGCInterval();
 outcomeLifetimeMillis = config.getOutcomeLifetime();
 timeoutIntervalMillis = config.getTimeoutInterval();
 metadataEnabled = config.isMetadataEnabled();
 this.action = action;
 
 if (trackingEnabled) {
  gcThread = WorkerThread.builder()
    .withOptions(new WorkerOptions()
           .daemon()
           .withName(MonitorEngine.class, groupId, "gc", Integer.toHexString(System.identityHashCode(this))))
    .onCycle(this::gcCycle)
    .buildAndStart();
 } else {
  gcThread = null;
 }
 
 timeoutThread = WorkerThread.builder()
   .withOptions(new WorkerOptions()
          .daemon()
          .withName(MonitorEngine.class, groupId, "timeout", Integer.toHexString(System.identityHashCode(this))))
   .onCycle(this::timeoutCycle)
   .buildAndStart();
}

origin: com.obsidiandynamics.jackdaw/jackdaw-core

public ProducerPipe(ProducerPipeConfig config, Producer<K, V> producer, String threadName, ExceptionHandler exceptionHandler) {
 this.producer = producer;
 this.exceptionHandler = exceptionHandler;
 if (config.isAsync()) {
  queue = new NodeQueue<>();
  queueConsumer = queue.consumer();
  thread = WorkerThread.builder()
    .withOptions(new WorkerOptions().daemon().withName(threadName))
    .onCycle(this::cycle)
    .buildAndStart();
 } else {
  queue = null;
  queueConsumer = null;
  thread = null;
 }
}

origin: com.obsidiandynamics.hazelq/hazelq-elect

public Election(ElectionConfig config, IMap<String, byte[]> leases) {
 this.config = config;
 final Retry retry = new Retry()
   .withExceptionClass(HazelcastException.class)
   .withAttempts(Integer.MAX_VALUE)
   .withBackoff(100)
   .withFaultHandler(config.getZlg()::w)
   .withErrorHandler(config.getZlg()::e);
 this.leases = new RetryableMap<>(retry, leases);
 registry = new Registry();
 
 scavengerThread = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(Election.class, "scavenger"))
   .onCycle(this::scavegerCycle)
   .build();
}

origin: com.obsidiandynamics.meteor/meteor-elect

public Election(ElectionConfig config, IMap<String, byte[]> leases) {
 this.config = config;
 final Retry retry = new Retry()
   .withExceptionMatcher(isA(HazelcastException.class))
   .withAttempts(Integer.MAX_VALUE)
   .withBackoff(100)
   .withFaultHandler(config.getZlg()::w)
   .withErrorHandler(config.getZlg()::e);
 this.leases = new RetryableMap<>(retry, leases);
 registry = new Registry();
 
 scavengerThread = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(Election.class, "scavenger"))
   .onCycle(this::scavegerCycle)
   .build();
}

origin: com.obsidiandynamics.meteor/meteor-core

DefaultPublisher(HazelcastInstance instance, PublisherConfig config) {
 this.instance = instance;
 this.config = config;
 final StreamConfig streamConfig = config.getStreamConfig();
 final Retry retry = new Retry()
   .withExceptionMatcher(isA(HazelcastException.class))
   .withAttempts(Integer.MAX_VALUE)
   .withBackoff(100)
   .withFaultHandler(config.getZlg()::w)
   .withErrorHandler(config.getZlg()::e);
 buffer = new RetryableRingbuffer<>(retry, StreamHelper.getRingbuffer(instance, streamConfig));
 
 publishThread = WorkerThread.builder()
   .withOptions(new WorkerOptions().daemon().withName(Publisher.class, streamConfig.getName(), "publisher"))
   .onCycle(this::publisherCycle)
   .buildAndStart();
}

com.obsidiandynamics.workerWorkerOptions

Most used methods

  • withName
  • <init>
  • daemon
    A shortcut way of calling withDaemon(true).
  • getName
  • getPriority
  • isDaemon
  • withDaemon

Popular in Java

  • Making http requests using okhttp
  • getSupportFragmentManager (FragmentActivity)
  • scheduleAtFixedRate (ScheduledExecutorService)
  • onCreateOptionsMenu (Activity)
  • Pointer (com.sun.jna)
    An abstraction for a native pointer data type. A Pointer instance represents, on the Java side, a na
  • BigInteger (java.math)
    An immutable arbitrary-precision signed integer.FAST CRYPTOGRAPHY This implementation is efficient f
  • SocketTimeoutException (java.net)
    This exception is thrown when a timeout expired on a socket read or accept operation.
  • UnknownHostException (java.net)
    Thrown when a hostname can not be resolved.
  • Scheduler (org.quartz)
    This is the main interface of a Quartz Scheduler. A Scheduler maintains a registry of org.quartz.Job
  • LoggerFactory (org.slf4j)
    The LoggerFactory is a utility class producing Loggers for various logging APIs, most notably for lo
  • Best plugins for Eclipse
Tabnine Logo
  • Products

    Search for Java codeSearch for JavaScript code
  • IDE Plugins

    IntelliJ IDEAWebStormVisual StudioAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimGoLandRubyMineEmacsJupyter NotebookJupyter LabRiderDataGripAppCode
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogTabnine AcademyTerms of usePrivacy policyJava Code IndexJavascript Code Index
Get Tabnine for your IDE now