Example usage for org.apache.hadoop.yarn.event Dispatcher interface-usage

List of usage examples for org.apache.hadoop.yarn.event Dispatcher interface-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.yarn.event Dispatcher interface-usage.

Usage

From source file org.apache.myriad.state.MockDispatcher.java

/**
 * Mock Dispatcher implementation for unit tests
 */
public class MockDispatcher implements Dispatcher {
    EventHandler<Event> handler = new MockEventHandler();

From source file org.apache.tajo.master.TajoAsyncDispatcher.java

public class TajoAsyncDispatcher extends AbstractService implements Dispatcher {

    private static final Log LOG = LogFactory.getLog(TajoAsyncDispatcher.class);

    private final BlockingQueue<Event> eventQueue;
    private volatile boolean stopped = false;

From source file org.apache.tez.common.AsyncDispatcher.java

/**
 * Dispatches {@link Event}s in a separate thread. Currently only single thread
 * does that. Potentially there could be multiple channels for each event type
 * class and a thread pool can be used to dispatch the events.
 */
@SuppressWarnings({ "rawtypes", "unchecked" })

From source file org.apache.tez.common.AsyncDispatcherConcurrent.java

/**
 * A dispatcher that can schedule events concurrently. Uses a fixed size threadpool 
 * to schedule events. Events that have the same serializing hash will get scheduled
 * on the same thread in the threadpool. This can be used to prevent concurrency issues
 * for events that may not be independently processed.
 */