| Modifier and Type | Class and Description | 
|---|---|
class  | 
DriverLauncher.CompletedJobHandler
Job driver notifies us that the job had completed successfully. 
 | 
class  | 
DriverLauncher.FailedJobHandler
Job driver notifies us that the job had failed. 
 | 
class  | 
DriverLauncher.RunningJobHandler
Job driver notifies us that the job is running. 
 | 
class  | 
DriverLauncher.RuntimeErrorHandler
Handler an error in the job driver. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
static OptionalImpl<EventHandler<Void>> | 
DriverConfiguration.ON_CLIENT_CLOSED
Event handler for close messages sent by the client. 
 | 
static OptionalImpl<EventHandler<byte[]>> | 
DriverConfiguration.ON_CLIENT_CLOSED_MESSAGE
Event handler for close messages sent by the client. 
 | 
static OptionalImpl<EventHandler<byte[]>> | 
DriverConfiguration.ON_CLIENT_MESSAGE
Event handler for client messages. 
 | 
static OptionalImpl<EventHandler<ActiveContext>> | 
DriverServiceConfiguration.ON_CONTEXT_ACTIVE
Event handler for active context. 
 | 
static OptionalImpl<EventHandler<ActiveContext>> | 
DriverConfiguration.ON_CONTEXT_ACTIVE
Event handler for active context. 
 | 
static OptionalImpl<EventHandler<ClosedContext>> | 
DriverServiceConfiguration.ON_CONTEXT_CLOSED
Event handler for closed context. 
 | 
static OptionalImpl<EventHandler<ClosedContext>> | 
DriverConfiguration.ON_CONTEXT_CLOSED
Event handler for closed context. 
 | 
static OptionalImpl<EventHandler<FailedContext>> | 
DriverServiceConfiguration.ON_CONTEXT_FAILED
Event handler for closed context. 
 | 
static OptionalImpl<EventHandler<FailedContext>> | 
DriverConfiguration.ON_CONTEXT_FAILED
Event handler for closed context. 
 | 
static OptionalImpl<EventHandler<ContextMessage>> | 
DriverServiceConfiguration.ON_CONTEXT_MESSAGE
Event handler for context messages. 
 | 
static OptionalImpl<EventHandler<ContextMessage>> | 
DriverConfiguration.ON_CONTEXT_MESSAGE
Event handler for context messages. 
 | 
static OptionalImpl<EventHandler<DriverRestartCompleted>> | 
DriverConfiguration.ON_DRIVER_RESTART_COMPLETED
Event handler for the event of driver restart completion, default to logging if not bound. 
 | 
static OptionalImpl<EventHandler<ActiveContext>> | 
DriverServiceConfiguration.ON_DRIVER_RESTART_CONTEXT_ACTIVE
Event handler for active context when driver restart. 
 | 
static OptionalImpl<EventHandler<ActiveContext>> | 
DriverConfiguration.ON_DRIVER_RESTART_CONTEXT_ACTIVE
Event handler for active context when driver restart. 
 | 
static OptionalImpl<EventHandler<RunningTask>> | 
DriverServiceConfiguration.ON_DRIVER_RESTART_TASK_RUNNING
Event handler for running tasks in previous evaluator, when driver restarted. 
 | 
static OptionalImpl<EventHandler<RunningTask>> | 
DriverConfiguration.ON_DRIVER_RESTART_TASK_RUNNING
Event handler for running tasks in previous evaluator, when driver restarted. 
 | 
static OptionalImpl<EventHandler<StartTime>> | 
DriverConfiguration.ON_DRIVER_RESTARTED
This event is fired in place of the ON_DRIVER_STARTED when the Driver is in fact restarted after failure. 
 | 
static RequiredImpl<EventHandler<StartTime>> | 
DriverServiceConfiguration.ON_DRIVER_STARTED
The event handler invoked right after the driver boots up. 
 | 
static RequiredImpl<EventHandler<StartTime>> | 
DriverConfiguration.ON_DRIVER_STARTED
The event handler invoked right after the driver boots up. 
 | 
static OptionalImpl<EventHandler<StopTime>> | 
DriverServiceConfiguration.ON_DRIVER_STOP
The event handler invoked right before the driver shuts down. 
 | 
static OptionalImpl<EventHandler<StopTime>> | 
DriverConfiguration.ON_DRIVER_STOP
The event handler invoked right before the driver shuts down. 
 | 
static OptionalImpl<EventHandler<AllocatedEvaluator>> | 
DriverServiceConfiguration.ON_EVALUATOR_ALLOCATED
Event handler for allocated evaluators. 
 | 
static OptionalImpl<EventHandler<AllocatedEvaluator>> | 
DriverConfiguration.ON_EVALUATOR_ALLOCATED
Event handler for allocated evaluators. 
 | 
static OptionalImpl<EventHandler<CompletedEvaluator>> | 
DriverServiceConfiguration.ON_EVALUATOR_COMPLETED
Event handler for completed evaluators. 
 | 
static OptionalImpl<EventHandler<CompletedEvaluator>> | 
DriverConfiguration.ON_EVALUATOR_COMPLETED
Event handler for completed evaluators. 
 | 
static OptionalImpl<EventHandler<FailedEvaluator>> | 
DriverServiceConfiguration.ON_EVALUATOR_FAILED
Event handler for failed evaluators. 
 | 
static OptionalImpl<EventHandler<FailedEvaluator>> | 
DriverConfiguration.ON_EVALUATOR_FAILED
Event handler for failed evaluators. 
 | 
static OptionalImpl<EventHandler<CompletedJob>> | 
ClientConfiguration.ON_JOB_COMPLETED
Handler for the event when a submitted REEF Job is completed. 
 | 
static OptionalImpl<EventHandler<FailedJob>> | 
ClientConfiguration.ON_JOB_FAILED
Handler for the event when a submitted REEF Job has failed. 
 | 
static OptionalImpl<EventHandler<JobMessage>> | 
ClientConfiguration.ON_JOB_MESSAGE
Event handler for messages from the running job. 
 | 
static OptionalImpl<EventHandler<RunningJob>> | 
ClientConfiguration.ON_JOB_RUNNING
Handler for the event when a submitted REEF Job is running. 
 | 
static OptionalImpl<EventHandler<FailedRuntime>> | 
ClientConfiguration.ON_RUNTIME_ERROR
Receives fatal resourcemanager errors. 
 | 
static OptionalImpl<EventHandler<CompletedTask>> | 
DriverServiceConfiguration.ON_TASK_COMPLETED
Event handler for completed tasks. 
 | 
static OptionalImpl<EventHandler<CompletedTask>> | 
DriverConfiguration.ON_TASK_COMPLETED
Event handler for completed tasks. 
 | 
static OptionalImpl<EventHandler<FailedTask>> | 
DriverServiceConfiguration.ON_TASK_FAILED
Event handler for failed tasks. 
 | 
static OptionalImpl<EventHandler<FailedTask>> | 
DriverConfiguration.ON_TASK_FAILED
Event handler for failed tasks. 
 | 
static OptionalImpl<EventHandler<TaskMessage>> | 
DriverServiceConfiguration.ON_TASK_MESSAGE
Event handler for task messages. 
 | 
static OptionalImpl<EventHandler<TaskMessage>> | 
DriverConfiguration.ON_TASK_MESSAGE
Event handler for task messages. 
 | 
static OptionalImpl<EventHandler<RunningTask>> | 
DriverServiceConfiguration.ON_TASK_RUNNING
Event handler for running tasks. 
 | 
static OptionalImpl<EventHandler<RunningTask>> | 
DriverConfiguration.ON_TASK_RUNNING
Event handler for running tasks. 
 | 
static OptionalImpl<EventHandler<SuspendedTask>> | 
DriverServiceConfiguration.ON_TASK_SUSPENDED
Event handler for suspended tasks. 
 | 
static OptionalImpl<EventHandler<SuspendedTask>> | 
DriverConfiguration.ON_TASK_SUSPENDED
Event handler for suspended tasks. 
 | 
static OptionalImpl<EventHandler<Throwable>> | 
ClientConfiguration.ON_WAKE_ERROR
Error handler for events on Wake-spawned threads. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
PreemptionHandler
This EventHandler will receive preemption events from the underlying resourcemanager. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
static OptionalImpl<EventHandler<ContextStart>> | 
ServiceConfiguration.ON_CONTEXT_STARTED
Event handler for context start. 
 | 
static OptionalImpl<EventHandler<ContextStart>> | 
ContextConfiguration.ON_CONTEXT_STARTED
Event handler for context start. 
 | 
static OptionalImpl<EventHandler<ContextStop>> | 
ServiceConfiguration.ON_CONTEXT_STOP
Event handler for context stop. 
 | 
static OptionalImpl<EventHandler<ContextStop>> | 
ContextConfiguration.ON_CONTEXT_STOP
Event handler for context stop. 
 | 
static OptionalImpl<EventHandler<TaskStart>> | 
ServiceConfiguration.ON_TASK_STARTED
Event handlers to be informed right before a Task enters its call() method. 
 | 
static OptionalImpl<EventHandler<TaskStart>> | 
ContextConfiguration.ON_TASK_STARTED
Event handlers to be informed right before a Task enters its call() method. 
 | 
static OptionalImpl<EventHandler<TaskStop>> | 
ServiceConfiguration.ON_TASK_STOP
Event handlers to be informed right after a Task exits its call() method. 
 | 
static OptionalImpl<EventHandler<TaskStop>> | 
ContextConfiguration.ON_TASK_STOP
Event handlers to be informed right after a Task exits its call() method. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
static OptionalImpl<EventHandler<CloseEvent>> | 
TaskConfiguration.ON_CLOSE
Handler for closure requests from the driver. 
 | 
static OptionalImpl<EventHandler<DriverMessage>> | 
TaskConfiguration.ON_MESSAGE
Handler for messages from the driver. 
 | 
static OptionalImpl<EventHandler<SuspendEvent>> | 
TaskConfiguration.ON_SUSPEND
Handler for task suspension. 
 | 
static OptionalImpl<EventHandler<TaskStart>> | 
TaskConfiguration.ON_TASK_STARTED
Event handler to receive TaskStart after the Task.call() method was called. 
 | 
static OptionalImpl<EventHandler<TaskStop>> | 
TaskConfiguration.ON_TASK_STOP
Event handler to receive TaskStop after the Task.call() method returned. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
ContextMessageHandler
Implement this interface to receive messages from the driver in a context. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
LineCounter.ContextActiveHandler  | 
class  | 
LineCounter.TaskCompletedHandler  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
HelloDriver.EvaluatorAllocatedHandler
Handles AllocatedEvaluator: Submit the HelloTask 
 | 
class  | 
HelloDriver.StartHandler
Handles the StartTime event: Request as single Evaluator. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SuspendTestTask.SuspendHandler  | 
| Constructor and Description | 
|---|
BlockingEventHandler(int expectedSize,
                                        EventHandler<Iterable<T>> destination)  | 
LoggingEventHandler(EventHandler<T> downstreamEventHandler)  | 
LoggingEventHandler(String prefix,
                                      EventHandler<T> downstreamEventHandler,
                                      String suffix)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DataLoader.EvaluatorAllocatedHandler  | 
class  | 
DataLoader.EvaluatorFailedHandler  | 
class  | 
DataLoader.StartHandler  | 
class  | 
ResourceRequestHandler  | 
| Modifier and Type | Method and Description | 
|---|---|
Transport | 
TransportFactory.create(int port,
            EventHandler<TransportEvent> clientHandler,
            EventHandler<TransportEvent> serverHandler,
            EventHandler<Exception> exHandler)
Creates a transport 
 | 
Transport | 
TransportFactory.create(int port,
            EventHandler<TransportEvent> clientHandler,
            EventHandler<TransportEvent> serverHandler,
            EventHandler<Exception> exHandler)
Creates a transport 
 | 
Transport | 
TransportFactory.create(int port,
            EventHandler<TransportEvent> clientHandler,
            EventHandler<TransportEvent> serverHandler,
            EventHandler<Exception> exHandler)
Creates a transport 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BindNSToTask  | 
class  | 
NameServiceCloseHandler  | 
class  | 
NetworkServiceClosingHandler  | 
class  | 
UnbindNSFromTask  | 
| Modifier and Type | Method and Description | 
|---|---|
Transport | 
MessagingTransportFactory.create(int port,
            EventHandler<TransportEvent> clientHandler,
            EventHandler<TransportEvent> serverHandler,
            EventHandler<Exception> exHandler)
Creates a transport 
 | 
Transport | 
MessagingTransportFactory.create(int port,
            EventHandler<TransportEvent> clientHandler,
            EventHandler<TransportEvent> serverHandler,
            EventHandler<Exception> exHandler)
Creates a transport 
 | 
Transport | 
MessagingTransportFactory.create(int port,
            EventHandler<TransportEvent> clientHandler,
            EventHandler<TransportEvent> serverHandler,
            EventHandler<Exception> exHandler)
Creates a transport 
 | 
| Constructor and Description | 
|---|
NetworkService(IdentifierFactory factory,
                            int nsPort,
                            String nameServerAddr,
                            int nameServerPort,
                            Codec<T> codec,
                            TransportFactory tpFactory,
                            EventHandler<Message<T>> recvHandler,
                            EventHandler<Exception> exHandler)  | 
NetworkService(IdentifierFactory factory,
                            int nsPort,
                            String nameServerAddr,
                            int nameServerPort,
                            Codec<T> codec,
                            TransportFactory tpFactory,
                            EventHandler<Message<T>> recvHandler,
                            EventHandler<Exception> exHandler)  | 
NetworkService(IdentifierFactory factory,
                            int nsPort,
                            String nameServerAddr,
                            int nameServerPort,
                            int retryCount,
                            int retryTimeout,
                            Codec<T> codec,
                            TransportFactory tpFactory,
                            EventHandler<Message<T>> recvHandler,
                            EventHandler<Exception> exHandler)  | 
NetworkService(IdentifierFactory factory,
                            int nsPort,
                            String nameServerAddr,
                            int nameServerPort,
                            int retryCount,
                            int retryTimeout,
                            Codec<T> codec,
                            TransportFactory tpFactory,
                            EventHandler<Message<T>> recvHandler,
                            EventHandler<Exception> exHandler)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PoisonedAlarmHandler
To be registered on the Clock to handle Alarms. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PoisonedContextStartHandler  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PoisonedTaskStartHandler  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
RunningJobImpl
Implementation of RunningJob. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
JobSubmissionHandler  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DefaultCompletedJobHandler
Default event handler for CompletedJob: Logging it. 
 | 
class  | 
DefaultFailedJobHandler
Default event handler for FailedJob: rethrow the exception. 
 | 
class  | 
DefaultJobMessageHandler
Default event handler for job message: Logging it. 
 | 
class  | 
DefaultRunningJobHandler
Default event handler for RunningJob: Logging it. 
 | 
class  | 
DefaultRuntimeErrorHandler
Default event handler for REEF FailedRuntime: rethrow the exception. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DriverExceptionHandler
Exception handler for exceptions thrown by client code in the Driver. 
 | 
class  | 
DriverStartHandler
This is bound to the start event of the clock and dispatches it to the approriate application code. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
ResourceLaunchHandler  | 
interface  | 
ResourceReleaseHandler  | 
interface  | 
ResourceRequestHandler
The evaluator request handler. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ClientManager
Represents the Client in the Driver. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DefaultClientCloseHandler
Default handler for close messages from the client: Throw an Exception. 
 | 
class  | 
DefaultClientCloseWithMessageHandler
Default handler for close messages from the client: Throw an Exception. 
 | 
class  | 
DefaultClientMessageHandler
Default event handler for Client messages: Logging it. 
 | 
class  | 
DefaultContextActiveHandler
Default handler for ActiveContext: Close it. 
 | 
class  | 
DefaultContextClosureHandler
Default event handler for ClosedContext: Logging it. 
 | 
class  | 
DefaultContextFailureHandler
Default event handler used for FailedContext: It crashes the driver. 
 | 
class  | 
DefaultDriverRestartCompletedHandler
Default handler for driver restart completed event: log it. 
 | 
class  | 
DefaultDriverRestartContextActiveHandler
Default handler for ActiveContext from previous evaluator during driver restart: Close it. 
 | 
class  | 
DefaultDriverRestartTaskRunningHandler
Default event handler for Task Restart TaskRuntime: Logging it. 
 | 
class  | 
DefaultEvaluatorAllocationHandler
Default handler for AllocatedEvaluator: close it. 
 | 
class  | 
DefaultEvaluatorCompletionHandler
Default event handler for CompletedEvaluator: Logging it. 
 | 
class  | 
DefaultEvaluatorFailureHandler
Default event handler used for FailedEvaluator: It crashes the driver. 
 | 
class  | 
DefaultTaskCompletionHandler
Default event handler for CompletedTask: Log it and close the context. 
 | 
class  | 
DefaultTaskFailureHandler
Default event handler used for FailedTask: It crashes the driver. 
 | 
class  | 
DefaultTaskMessageHandler
Default event handler for TaskMessage: Logging it. 
 | 
class  | 
DefaultTaskRunningHandler
Default event handler for TaskRuntime: Logging it. 
 | 
class  | 
DefaultTaskSuspensionHandler
Default event handler used for SuspendedTask: It crashes the driver. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
EvaluatorHeartbeatHandler
Receives heartbeats from all Evaluators and dispatches them to the right EvaluatorManager instance. 
 | 
class  | 
EvaluatorResourceManagerErrorHandler
The error handler receives all resourcemanager errors from all evaluators in the system. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ClockIdlenessSource
Informs the DriverIdleManager of clock idleness. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
NodeDescriptorHandler
Updates the ResourceCatalog with a new Node. 
 | 
class  | 
ResourceAllocationHandler
Handles new resource allocations by adding a new EvaluatorManager. 
 | 
class  | 
ResourceManagerErrorHandler
Informs the client and then shuts down the driver forcefully in case of Resource Manager errors. 
 | 
class  | 
ResourceManagerStatus
Manages the status of the Resource Manager. 
 | 
class  | 
ResourceStatusHandler
A ResourceStatusProto message comes from the ResourceManager layer to indicate what it thinks
 about the current state of a given resource. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PIDStoreStartHandler
This Handler writes the Process ID (PID) to a file with a name given in PID_FILE_NAME to the local working directory. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DefaultContextMessageHandler
Default handler for messages sent by the driver: Crash the context. 
 | 
class  | 
DefaultContextStartHandler
Default handler for ContextStart 
 | 
class  | 
DefaultContextStopHandler
Default event handler for ContextStop 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DefaultCloseHandler
Default implementation for EventHandler 
 | 
class  | 
DefaultDriverMessageHandler
A default implementation of EventHandler 
 | 
class  | 
DefaultSuspendHandler
Default handler for SuspendEvent 
 | 
| Constructor and Description | 
|---|
TaskStartHandlerFailure(EventHandler<TaskStart> handler,
                                              Throwable cause)  | 
TaskStopHandlerFailure(EventHandler<TaskStop> handler,
                                            Throwable cause)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
REEFErrorHandler
The error handler REEF registers with Wake. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BroadCastEventHandler<E>  | 
| Modifier and Type | Method and Description | 
|---|---|
<T> EventHandler<T> | 
RemoteManager.getHandler(String destinationIdentifier,
                    Class<? extends T> messageType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
BroadCastEventHandler.addEventHandler(EventHandler<E> eventHandler)  | 
AutoCloseable | 
RemoteManager.registerErrorHandler(EventHandler<Exception> theHandler)  | 
<T,U extends T>  | 
RemoteManager.registerHandler(Class<U> messageType,
                              EventHandler<RemoteMessage<T>> theHandler)  | 
<T,U extends T>  | 
RemoteManager.registerHandler(String sourceIdentifier,
                              Class<U> messageType,
                              EventHandler<T> theHandler)  | 
| Modifier and Type | Method and Description | 
|---|---|
<T,U extends T>  | 
DispatchingEStage.register(Class<T> type,
                Set<EventHandler<U>> handlers)
Register a new event handler. 
 | 
| Constructor and Description | 
|---|
DispatchingEStage(EventHandler<Throwable> errorHandler,
                                  int numThreads,
                                  String stageName)  | 
| Constructor and Description | 
|---|
BroadCastEventHandler(Collection<EventHandler<E>> handlers)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
HDInsightJobSubmissionHandler
Handles job submission to a HDInsight instance. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
LocalResourceReleaseHandler
Takes Resource Release requests and patches them through to the resource
 manager. 
 | 
| Constructor and Description | 
|---|
ReefRunnableProcessObserver(EventHandler<DriverRuntimeProtocol.ResourceStatusProto> resourceStatusHandler,
                                                      InjectionFuture<ResourceManager> resourceManager)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
YARNResourceLaunchHandler
Resource launch handler for YARN. 
 | 
class  | 
YARNResourceReleaseHandler
ResourceReleaseHandler for YARN. 
 | 
class  | 
YarnResourceRequestHandler
Accepts resource requests from the REEF layer, translates them into requests for YARN and hands them to the
 appropriate handler for those. 
 | 
class  | 
YARNRuntimeStartHandler
Handler of RuntimeStart for the YARN Runtime. 
 | 
class  | 
YARNRuntimeStopHandler
Shuts down the YARN resource manager. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DriverFailOnFail.AllocatedEvaluatorHandler  | 
class  | 
DriverFailOnFail.FailedTaskHandler  | 
class  | 
DriverFailOnFail.StartHandler  | 
class  | 
FailDriverDelayedMsg.ActiveContextHandler  | 
class  | 
FailDriverDelayedMsg.AllocatedEvaluatorHandler  | 
class  | 
FailDriverDelayedMsg.RunningTaskHandler  | 
class  | 
FailDriverDelayedMsg.StartHandler  | 
class  | 
FailDriverDelayedMsg.TaskMessageHandler  | 
class  | 
NoopTask.DriverMessageHandler  | 
class  | 
NoopTask.TaskCloseHandler  | 
class  | 
NoopTask.TaskStopHandler  | 
class  | 
NoopTask.TaskSuspendHandler  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
FailTaskClose
A basic task that just fails when we close it. 
 | 
class  | 
FailTaskMsg
A basic task that just fails when we send it a message. 
 | 
class  | 
FailTaskStart
A basic task that just fails when we invoke it. 
 | 
class  | 
FailTaskStop
A basic task that just fails when we stop it. 
 | 
class  | 
FailTaskStop.CloseEventHandler  | 
class  | 
FailTaskSuspend
A basic task that just fails when we invoke it. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ExpectedTaskFailureHandler
A handler for FailedTask that will throw a DriverSideFailure unless the FailedTask was triggered by an
 ExpectedTaskException in the Task. 
 | 
class  | 
OnDriverStartedAllocateOne
A Driver start handler that requests a single Evaluator of size 64MB. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TaskMessagingDriver.EvaluatorAllocatedHandler  | 
class  | 
TaskMessagingDriver.TaskMessageHandler  | 
class  | 
TaskMessagingDriver.TaskRunningHandler  | 
class  | 
TaskMessagingTask.DriverMessageHandler  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ExceptionHandlingEventHandler<T>
An ExceptionHandler that wraps another one, but catches all exceptions thrown by that one and forwards them
 to an ExceptionHandler. 
 | 
| Constructor and Description | 
|---|
ExceptionHandlingEventHandler(EventHandler<T> wrapped,
                                                          EventHandler<Throwable> exceptionHandler)  | 
ExceptionHandlingEventHandler(EventHandler<T> wrapped,
                                                          EventHandler<Throwable> exceptionHandler)  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
EStage<T>
Stage that executes an event handler 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractEStage<T>
An  
EStage that implements metering | 
| Constructor and Description | 
|---|
Pull2Push(EventHandler<T> output)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BlockingEventHandler<T>
An EventHandler that blocks until a set number of Events has been received. 
 | 
class  | 
BlockingSignalEventHandler<T>
An EventHandler that blocks until a set number of Events has been received. 
 | 
class  | 
ForkPoolStage<T>
This Wake event handling stage uses a  
ForkJoinPool
 to submit tasks. | 
class  | 
IndependentIterationsThreadPoolStage<T>
This stage uses a thread pool to schedule events in parallel. 
 | 
class  | 
LoggingEventHandler<T>
A logging event handler 
 | 
class  | 
LoggingVoidEventHandler
A logging void event handler 
 | 
class  | 
MissingStartHandlerHandler
The EventHandler used as the default for the Clock.StartHandler event. 
 | 
class  | 
MultiEventHandler<T>
Event handler that dispatches an event to a specific handler based on an event class type 
 | 
class  | 
PubSubEventHandler<T>
Event handler that provides publish/subscribe interfaces 
 | 
class  | 
SingleThreadStage<T>
Single thread stage that runs the event handler 
 | 
class  | 
SyncStage<T>
Stage that synchronously executes an event handler 
 | 
class  | 
ThreadPoolStage<T>
Stage that executes an event handler with a thread pool 
 | 
| Modifier and Type | Field and Description | 
|---|---|
EventHandler<L> | 
MergingEventHandler.left  | 
EventHandler<R> | 
MergingEventHandler.right  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
WakeUncaughtExceptionHandler.setErrorHandler(EventHandler<Throwable> errorHandler)  | 
void | 
PubSubEventHandler.subscribe(Class<? extends T> clazz,
                  EventHandler<? extends T> handler)
Subscribes an event handler for an event class type 
 | 
| Constructor and Description | 
|---|
BlockingEventHandler(int expectedSize,
                                        EventHandler<Iterable<T>> destination)  | 
BlockingSignalEventHandler(int expectedSize,
                                                    EventHandler<T> destination)  | 
ForkPoolStage(EventHandler<T> handler,
                          WakeSharedPool sharedPool)  | 
ForkPoolStage(String stageName,
                          EventHandler<T> handler,
                          WakeSharedPool sharedPool)  | 
IndependentIterationsThreadPoolStage(EventHandler<T> handler,
                                                                        int numThreads,
                                                                        int granularity)  | 
MergingEventHandler(EventHandler<MergingEventHandler.Pair<L,R>> destination)  | 
SingleThreadStage(EventHandler<T> handler,
                                  int capacity)
Constructs a single thread stage 
 | 
SingleThreadStage(String name,
                                  EventHandler<T> handler,
                                  int capacity)
Constructs a single thread stage 
 | 
SyncStage(EventHandler<T> handler)
Constructs a synchronous stage 
 | 
SyncStage(String name,
                  EventHandler<T> handler)
Constructs a synchronous stage 
 | 
SyncStage(String name,
                  EventHandler<T> handler,
                  EventHandler<Throwable> errorHandler)
Constructs a synchronous stage 
 | 
SyncStage(String name,
                  EventHandler<T> handler,
                  EventHandler<Throwable> errorHandler)
Constructs a synchronous stage 
 | 
ThreadPoolStage(EventHandler<T> handler,
                              ExecutorService executor)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(EventHandler<T> handler,
                              ExecutorService executor,
                              EventHandler<Throwable> errorHandler)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(EventHandler<T> handler,
                              ExecutorService executor,
                              EventHandler<Throwable> errorHandler)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(EventHandler<T> handler,
                              int numThreads)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(String name,
                              EventHandler<T> handler,
                              ExecutorService executor)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(String name,
                              EventHandler<T> handler,
                              ExecutorService executor,
                              EventHandler<Throwable> errorHandler)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(String name,
                              EventHandler<T> handler,
                              ExecutorService executor,
                              EventHandler<Throwable> errorHandler)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(String name,
                              EventHandler<T> handler,
                              int numThreads)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(String name,
                              EventHandler<T> handler,
                              int numThreads,
                              EventHandler<Throwable> errorHandler)
Constructs a thread-pool stage 
 | 
ThreadPoolStage(String name,
                              EventHandler<T> handler,
                              int numThreads,
                              EventHandler<Throwable> errorHandler)
Constructs a thread-pool stage 
 | 
TimerStage(EventHandler<PeriodicEvent> handler,
                    long period)
Constructs a timer stage with no initial delay 
 | 
TimerStage(EventHandler<PeriodicEvent> handler,
                    long initialDelay,
                    long period)
Constructs a timer stage 
 | 
TimerStage(String name,
                    EventHandler<PeriodicEvent> handler,
                    long period)
Constructs a timer stage with no initial delay 
 | 
TimerStage(String name,
                    EventHandler<PeriodicEvent> handler,
                    long initialDelay,
                    long period)
Constructs a timer stage 
 | 
WakeUncaughtExceptionHandler(EventHandler<Throwable> errorHandler)  | 
| Constructor and Description | 
|---|
MultiEventHandler(Map<Class<? extends T>,EventHandler<? extends T>> map)
Constructs a multi-event handler 
 | 
PubSubEventHandler(Map<Class<? extends T>,List<EventHandler<? extends T>>> clazzToListOfHandlersMap)
Constructs a pub-sub event handler with initial subscribed event handlers 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<T> EventHandler<T> | 
RemoteManager.getHandler(RemoteIdentifier destinationIdentifier,
                    Class<? extends T> messageType)
Returns an event handler that can be used to send messages of type T to the
 given destination. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
AutoCloseable | 
RemoteManager.registerErrorHandler(EventHandler<Exception> theHandler)
Deprecated.  
 | 
<T,U extends T>  | 
RemoteManager.registerHandler(Class<U> messageType,
                              EventHandler<RemoteMessage<T>> theHandler)
Registers the given EventHandler to be called for the given message type
 from any source. 
 | 
<T,U extends T>  | 
RemoteManager.registerHandler(RemoteIdentifier sourceIdentifier,
                              Class<U> messageType,
                              EventHandler<T> theHandler)
Registers the given EventHandler to be invoked when messages of Type T
 arrive from sourceIdentifier. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
OrderedRemoteReceiverStage
Receive incoming events and dispatch to correct handlers in order 
 | 
class  | 
ProxyEventHandler<T>
Proxy of the event handler that runs remotely 
 | 
class  | 
RemoteReceiverStage
Receive incoming events and dispatch to correct handlers 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<T> EventHandler<RemoteEvent<T>> | 
RemoteSenderStage.getHandler()
Returns a new remote sender event handler 
 | 
<T> EventHandler<T> | 
DefaultRemoteManagerImplementation.getHandler(RemoteIdentifier destinationIdentifier,
                    Class<? extends T> messageType)
Returns a proxy event handler for a remote identifier and a message type 
 | 
| Modifier and Type | Method and Description | 
|---|---|
AutoCloseable | 
DefaultRemoteManagerImplementation.registerErrorHandler(EventHandler<Exception> theHandler)
Registers an exception handler and returns a subscription 
 | 
<T,U extends T>  | 
DefaultRemoteManagerImplementation.registerHandler(Class<U> messageType,
                              EventHandler<RemoteMessage<T>> theHandler)
Registers an event handler for a message type and returns a subscription 
 | 
<T,U extends T>  | 
DefaultRemoteManagerImplementation.registerHandler(RemoteIdentifier sourceIdentifier,
                              Class<U> messageType,
                              EventHandler<T> theHandler)
Registers an event handler for a remote identifier and a message type and
 returns a subscription 
 | 
| Constructor and Description | 
|---|
ConnectFutureTask(Callable<T> callable,
                                  EventHandler<ConnectFutureTask<T>> handler)  | 
DefaultRemoteManagerImplementation(String name,
                                                                    String hostAddress,
                                                                    int listeningPort,
                                                                    Codec<T> codec,
                                                                    EventHandler<Throwable> errorHandler,
                                                                    boolean orderingGuarantee,
                                                                    int numberOfTries,
                                                                    int retryTimeout)  | 
OrderedRemoteReceiverStage(EventHandler<RemoteEvent<byte[]>> handler,
                                                    EventHandler<Throwable> errorHandler)
Constructs a ordered remote receiver stage 
 | 
OrderedRemoteReceiverStage(EventHandler<RemoteEvent<byte[]>> handler,
                                                    EventHandler<Throwable> errorHandler)
Constructs a ordered remote receiver stage 
 | 
ProxyEventHandler(RemoteIdentifier myId,
                                  RemoteIdentifier remoteId,
                                  String remoteSinkName,
                                  EventHandler<RemoteEvent<T>> handler,
                                  RemoteSeqNumGenerator seqGen)
Constructs a proxy event handler 
 | 
RemoteReceiverStage(EventHandler<RemoteEvent<byte[]>> handler,
                                      EventHandler<Throwable> errorHandler,
                                      int numThreads)
Constructs a remote receiver stage 
 | 
RemoteReceiverStage(EventHandler<RemoteEvent<byte[]>> handler,
                                      EventHandler<Throwable> errorHandler,
                                      int numThreads)
Constructs a remote receiver stage 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Transport.registerErrorHandler(EventHandler<Exception> handler)
Registers the exception handler 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
NettyMessagingTransport.registerErrorHandler(EventHandler<Exception> handler)
Registers the exception event handler 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SequentialFileReader  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Clock.scheduleAlarm(int offset,
                          EventHandler<Alarm> handler)
Schedule a TimerEvent at the given future offset 
 | 
| Constructor and Description | 
|---|
Alarm(long timestamp,
          EventHandler<Alarm> handler)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
RuntimeClock.registerEventHandler(Class<? extends Time> clazz,
                                        EventHandler<Time> handler)  | 
void | 
RuntimeClock.scheduleAlarm(int offset,
                          EventHandler<Alarm> handler)  | 
void | 
RuntimeClock.scheduleRuntimeAlarm(int offset,
                                        EventHandler<Alarm> handler)  | 
| Constructor and Description | 
|---|
ClientAlarm(long timestamp,
                      EventHandler<Alarm> handler)  | 
RuntimeAlarm(long timestamp,
                        EventHandler<Alarm> handler)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ReefEventStateManager.ActiveContextStateHandler
Receive notification that a new Context is available. 
 | 
class  | 
ReefEventStateManager.AllocatedEvaluatorStateHandler
Receive notification that an Evaluator had been allocated 
 | 
class  | 
ReefEventStateManager.ClientMessageStateHandler
Receive notification from the client. 
 | 
class  | 
ReefEventStateManager.DriverRestartTaskRunningStateHandler
Receive event during driver restart that a task is running in previous evaluator 
 | 
class  | 
ReefEventStateManager.DrivrRestartActiveContextStateHandler
Receive notification that a new Context is available. 
 | 
class  | 
ReefEventStateManager.StartStateHandler
Job Driver is ready and the clock is set up 
 | 
class  | 
ReefEventStateManager.StopStateHandler
Job driver stopped, log the stop time. 
 | 
class  | 
ReefEventStateManager.TaskRunningStateHandler
Receive event when task is running 
 | 
| Constructor and Description | 
|---|
HttpServerReefEventHandler(ReefEventStateManager reefStateManager,
                                                    Set<EventHandler<Void>> clientCloseHandlers,
                                                    String logLevel,
                                                    LoggingScopeFactory loggingScopeFactory,
                                                    REEFFileNames reefFileNames)  | 
Copyright © 2015 The Apache Software Foundation. All rights reserved.