Package | Description |
---|---|
org.apache.reef.client |
Client APIs for REEF.
|
org.apache.reef.driver |
Driver APIs for REEF in terms of Rx.
|
org.apache.reef.driver.context |
Driver Contexts and their configurations.
|
org.apache.reef.driver.restart |
This package provides restart event service handlers.
|
org.apache.reef.driver.task |
Tasks and their configurations.
|
org.apache.reef.evaluator.context |
Evaluator Contexts.
|
org.apache.reef.examples.data.loading |
A line counter example using data loading service.
|
org.apache.reef.examples.data.output |
Example application using the output service.
|
org.apache.reef.examples.group.broadcast |
Broadcast Group Communication example.
|
org.apache.reef.examples.hello |
The Hello REEF example for the HDInsight.
|
org.apache.reef.examples.scheduler.driver |
Task scheduler example driver classes.
|
org.apache.reef.examples.suspend |
Suspend/resume demo.
|
org.apache.reef.examples.utils.wake |
Logging and Blocking event handlers.
|
org.apache.reef.io.data.loading.api |
Data Loading Service API.
|
org.apache.reef.io.network |
TODO: Document.
|
org.apache.reef.io.network.group.api.task |
Elastic Group Communications Task-side API Interfaces.
|
org.apache.reef.io.network.group.impl.driver |
This package contains the implementation of the driver side of the
Group Communication Service using the tree/flat topology.
|
org.apache.reef.io.network.group.impl.operators |
Implementations for Group Communication Operators.
|
org.apache.reef.io.network.group.impl.task |
Implementations for Elastic Group Communications Task-side API.
|
org.apache.reef.io.network.group.impl.utils |
Utilities for group communication.
|
org.apache.reef.io.network.impl |
TODO: Document.
|
org.apache.reef.io.watcher |
Watcher subscribes events and writes them to the destination using a certain EventStream.
|
org.apache.reef.io.watcher.util |
Utility classes for Watcher.
|
org.apache.reef.javabridge.generic |
Generic java bridge driver/client.
|
org.apache.reef.poison |
Fault injection for REEF.
|
org.apache.reef.poison.context |
Fault Injection into REEF contexts.
|
org.apache.reef.poison.task |
Fault Injection into REEF tasks.
|
org.apache.reef.runtime.common.client |
Implementation of the client-side REEF API.
|
org.apache.reef.runtime.common.client.api |
Client-Side Event Handlers to be implemented by a specific resourcemanager.
|
org.apache.reef.runtime.common.client.defaults |
Default implementations for the optional client-side event handlers.
|
org.apache.reef.runtime.common.driver |
Implementation of the Driver-side REEF APIs.
|
org.apache.reef.runtime.common.driver.api |
Driver-Side Event Handlers to be implemented by a specific resource manager.
|
org.apache.reef.runtime.common.driver.client |
Objects representing the Client on the Driver.
|
org.apache.reef.runtime.common.driver.defaults |
Default implementations for the optional driver-side event handlers.
|
org.apache.reef.runtime.common.driver.evaluator |
Driver-Side representations of Evaluators.
|
org.apache.reef.runtime.common.driver.idle |
Contains the Driver idle handling and extension APIs.
|
org.apache.reef.runtime.common.driver.resourcemanager |
Classes that interface with the resourcemanager (Local, YARN, ...) in the Driver.
|
org.apache.reef.runtime.common.evaluator |
Evaluator-side implementation of the REEF API.
|
org.apache.reef.runtime.common.evaluator.context.defaults |
Default implementations for the optional context interfaces.
|
org.apache.reef.runtime.common.evaluator.task.defaults |
Default implementations for the optional task interfaces.
|
org.apache.reef.runtime.common.evaluator.task.exceptions |
Exceptions thrown by Tasks and Task Handlers.
|
org.apache.reef.runtime.common.launch |
Common launch code between Driver and Evaluator.
|
org.apache.reef.runtime.common.utils |
Runtime utilities used by various REEF modules.
|
org.apache.reef.runtime.hdinsight.client |
The client to submit jobs to HDInsight.
|
org.apache.reef.runtime.local.driver |
The resource manager for the local resourcemanager.
|
org.apache.reef.runtime.local.process |
Infrastructure for managing processes.
|
org.apache.reef.runtime.mesos.driver |
Driver-side event handlers for Mesos resourcemanager.
|
org.apache.reef.runtime.mesos.util |
Utility for Mesos runtime.
|
org.apache.reef.runtime.yarn.driver |
The Driver-Side implementation of the YARN adapter for REEF.
|
org.apache.reef.tests.fail.driver |
Tests for Driver-side failures.
|
org.apache.reef.tests.fail.task |
Tests for Tasks fail in various cases.
|
org.apache.reef.tests.library.driver |
Commonly used event handler implementations in our tests.
|
org.apache.reef.tests.messaging.task |
Test message exchange between the Task and the Driver.
|
org.apache.reef.tests.rack.awareness |
Tests for Rack-awareness.
|
org.apache.reef.tests.watcher |
Test reef.io.watcher.
|
org.apache.reef.util |
Utilities for using REEF on Hadoop.
|
org.apache.reef.vortex.evaluator |
Vortex Code that runs as part of REEF Evaluator.
|
org.apache.reef.wake |
Public interfaces and factories for Wake's core API.
|
org.apache.reef.wake.examples.p2p |
A simple pull to push adapter.
|
org.apache.reef.wake.impl |
Wake's implementation.
|
org.apache.reef.wake.remote |
Wake's remote communication.
|
org.apache.reef.wake.remote.impl |
Implementations for Wake's remote communication.
|
org.apache.reef.wake.remote.transport |
Wake's remote transportation.
|
org.apache.reef.wake.remote.transport.netty |
Netty-based remote transport implementation.
|
org.apache.reef.wake.time |
Clock and time-based events(start/stop/alarm) implementation.
|
org.apache.reef.wake.time.event |
Time-based events (start/stop/alarm).
|
org.apache.reef.wake.time.runtime | |
org.apache.reef.wake.time.runtime.event |
Runtime-related Wake events.
|
org.apache.reef.webserver |
HTTP Server component to implement a REST API for the Driver or Evaluators.
|
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>> |
DriverRestartConfiguration.ON_DRIVER_RESTART_COMPLETED
Event handler for the event of driver restart completion, default to logging if not bound.
|
static OptionalImpl<EventHandler<ActiveContext>> |
DriverRestartConfiguration.ON_DRIVER_RESTART_CONTEXT_ACTIVE
Event handler for active context when driver restart.
|
static OptionalImpl<EventHandler<FailedEvaluator>> |
DriverRestartConfiguration.ON_DRIVER_RESTART_EVALUATOR_FAILED
Event handler for the event of driver restart completion, default to logging if not bound.
|
static OptionalImpl<EventHandler<RunningTask>> |
DriverRestartConfiguration.ON_DRIVER_RESTART_TASK_RUNNING
Event handler for running tasks in previous evaluator, when driver restarted.
|
static OptionalImpl<EventHandler<DriverRestarted>> |
DriverServiceConfiguration.ON_DRIVER_RESTARTED
The event handler invoked right after the driver restarts.
|
static OptionalImpl<EventHandler<DriverRestarted>> |
DriverRestartConfiguration.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 | Class and Description |
---|---|
class |
EvaluatorPreservingEvaluatorAllocatedHandler
Records allocated evaluators for recovery on driver restart by using a DriverRuntimeRestartManager.
|
class |
EvaluatorPreservingEvaluatorCompletedHandler
Removes an evaluator from the evaluators to restart after it has completed.
|
class |
EvaluatorPreservingEvaluatorFailedHandler
Removes an evaluator from the evaluators to restart after it has failed.
|
Modifier and Type | Method and Description |
---|---|
void |
DriverRestartManager.onRestart(StartTime startTime,
List<EventHandler<DriverRestarted>> orderedHandlers)
Recovers the list of alive and failed evaluators and inform the driver restart handlers and inform the
evaluator failure handlers based on the specific runtime.
|
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
Handler for ActiveContext.
|
class |
LineCounter.TaskCompletedHandler
Completed task handler.
|
Modifier and Type | Class and Description |
---|---|
class |
OutputServiceDriver.ActiveContextHandler
Handles ActiveContext: Submit the output service demo task.
|
class |
OutputServiceDriver.EvaluatorAllocatedHandler
Handles AllocatedEvaluator: Submit the output service and a context for it.
|
class |
OutputServiceDriver.StartHandler
Handles the StartTime event: Request three Evaluators.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastDriver.ContextActiveHandler
ActiveContext handler.
|
class |
BroadcastDriver.ContextCloseHandler
ClosedContext handler.
|
class |
BroadcastDriver.FailedTaskHandler
FailedTask handler.
|
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.
|
class |
HelloDriverRestart.DriverRestartHandler
Handles Restarts.
|
class |
HelloJVMOptionsDriver.EvaluatorAllocatedHandler
Handles AllocatedEvaluator: Submit the HelloTask with additional JVM Options.
|
class |
HelloJVMOptionsDriver.StartHandler
Handles the StartTime event: Request as single Evaluator.
|
Modifier and Type | Class and Description |
---|---|
class |
SchedulerDriver.ActiveContextHandler
Now it is ready to schedule tasks.
|
class |
SchedulerDriver.CompletedTaskHandler
When a Task completes, the task is marked as finished.
|
class |
SchedulerDriver.EvaluatorAllocatedHandler
Evaluator is allocated.
|
class |
SchedulerDriver.StartHandler
The driver is ready to run.
|
Modifier and Type | Class and Description |
---|---|
class |
SuspendTestTask.SuspendHandler
Handler for suspend event.
|
Constructor and Description |
---|
BlockingEventHandler(int expectedSize,
EventHandler<Iterable<T>> destination) |
LoggingEventHandler(EventHandler<T> downstreamEventHandler) |
LoggingEventHandler(EventHandler<T> downstreamEventHandler,
String format) |
Modifier and Type | Class and Description |
---|---|
class |
DataLoader.EvaluatorAllocatedHandler |
class |
DataLoader.EvaluatorFailedHandler |
class |
DataLoader.StartHandler |
class |
ResourceRequestHandler |
Modifier and Type | Method and Description |
---|---|
<T> ConnectionFactory<T> |
NetworkConnectionService.registerConnectionFactory(Identifier connectionFactoryId,
Codec<T> codec,
EventHandler<Message<T>> eventHandler,
LinkListener<Message<T>> linkListener,
Identifier localEndPointId)
Registers an instance of ConnectionFactory corresponding to the connectionFactoryId.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CommGroupNetworkHandler
The EventHandler that receives the GroupCommunicationMsg.
|
interface |
GroupCommNetworkHandler
The global EventHandler that receives the GroupCommunicationMsg.
|
Modifier and Type | Method and Description |
---|---|
void |
GroupCommNetworkHandler.register(Class<? extends Name<String>> groupName,
EventHandler<GroupCommunicationMessage> commGroupNetworkHandler) |
void |
CommGroupNetworkHandler.register(Class<? extends Name<String>> operName,
EventHandler<GroupCommunicationMessage> handler) |
Modifier and Type | Class and Description |
---|---|
class |
CtrlMsgSender
Event handler that receives ctrl msgs and.
|
class |
ExceptionHandler |
class |
GroupCommMessageHandler
The network handler for the group communcation service on the driver side.
|
class |
GroupCommService.FailedEvaluatorHandler |
class |
GroupCommService.FailedTaskHandler |
class |
GroupCommService.RunningTaskHandler |
class |
TopologyFailedEvaluatorHandler |
class |
TopologyFailedTaskHandler |
class |
TopologyMessageHandler |
class |
TopologyRunningTaskHandler |
class |
TopologyUpdateWaitHandler |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastReceiver<T> |
class |
BroadcastSender<T> |
class |
GatherReceiver<T> |
class |
GatherSender<T> |
class |
ReduceReceiver<T> |
class |
ReduceSender<T> |
class |
ScatterReceiver<T> |
class |
ScatterSender<T> |
Modifier and Type | Class and Description |
---|---|
class |
CommGroupNetworkHandlerImpl |
class |
GroupCommNetworkHandlerImpl |
Modifier and Type | Method and Description |
---|---|
void |
GroupCommNetworkHandlerImpl.register(Class<? extends Name<String>> groupName,
EventHandler<GroupCommunicationMessage> commGroupNetworkHandler) |
void |
CommGroupNetworkHandlerImpl.register(Class<? extends Name<String>> operName,
EventHandler<GroupCommunicationMessage> operHandler) |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastingEventHandler<T> |
Modifier and Type | Method and Description |
---|---|
void |
BroadcastingEventHandler.addHandler(EventHandler<T> handler) |
Modifier and Type | Class and Description |
---|---|
class |
BindNSToTask |
class |
NameServiceCloseHandler |
class |
NetworkConnectionServiceExceptionHandler
Default exception handler.
|
class |
NetworkServiceClosingHandler |
class |
UnbindNSFromTask |
Modifier and Type | Method and Description |
---|---|
<T> ConnectionFactory<T> |
NetworkConnectionServiceImpl.registerConnectionFactory(Identifier connectionFactoryId,
Codec<T> codec,
EventHandler<Message<T>> eventHandler,
LinkListener<Message<T>> linkListener,
Identifier localEndPointId) |
Constructor and Description |
---|
NetworkService(IdentifierFactory factory,
int nsPort,
NameResolver nameResolver,
Codec<T> codec,
TransportFactory tpFactory,
EventHandler<Message<T>> recvHandler,
EventHandler<Exception> exHandler,
LocalAddressProvider localAddressProvider)
Deprecated.
in 0.12. Use Tang to obtain an instance of this instead.
|
NetworkService(IdentifierFactory factory,
int nsPort,
NameResolver nameResolver,
Codec<T> codec,
TransportFactory tpFactory,
EventHandler<Message<T>> recvHandler,
EventHandler<Exception> exHandler,
LocalAddressProvider localAddressProvider)
Deprecated.
in 0.12. Use Tang to obtain an instance of this instead.
|
Modifier and Type | Class and Description |
---|---|
class |
Watcher.ContextActiveHandler |
class |
Watcher.ContextClosedHandler |
class |
Watcher.ContextFailedHandler |
class |
Watcher.DriverRuntimeStartHandler |
class |
Watcher.DriverRuntimeStopHandler |
class |
Watcher.DriverStartHandler |
class |
Watcher.DriverStopHandler |
class |
Watcher.EvaluatorAllocatedHandler |
class |
Watcher.EvaluatorCompletedHandler |
class |
Watcher.EvaluatorFailedHandler |
class |
Watcher.TaskCompletedHandler |
class |
Watcher.TaskFailedHandler |
class |
Watcher.TaskMessageHandler |
class |
Watcher.TaskRunningHandler |
class |
Watcher.TaskSuspendedHandler |
Modifier and Type | Class and Description |
---|---|
class |
RunnableExecutingHandler
Handler that executes Runnable commands.
|
Modifier and Type | Class and Description |
---|---|
class |
JobDriver.ActiveContextHandler
Receive notification that a new Context is available.
|
class |
JobDriver.AllocatedEvaluatorHandler
Handles AllocatedEvaluator: Submit an empty context.
|
class |
JobDriver.ClosedContextHandler
Receive notification that the Context had completed.
|
class |
JobDriver.CompletedEvaluatorHandler
Receive notification that the Evaluator has been shut down.
|
class |
JobDriver.CompletedTaskHandler
Receive notification that the Task has completed successfully.
|
class |
JobDriver.ContextMessageHandler
Receive notification that a ContextMessage has been received.
|
class |
JobDriver.DriverRestartActiveContextHandler
Receive notification that an context is active on Evaluator when the driver restarted.
|
class |
JobDriver.DriverRestartCompletedHandler
Receive notification that driver restart has completed.
|
class |
JobDriver.DriverRestartFailedEvaluatorHandler
Receive notification that the entire Evaluator had failed on Driver Restart.
|
class |
JobDriver.DriverRestartRunningTaskHandler
Receive notification that the Task is running when driver restarted.
|
class |
JobDriver.FailedContextHandler
Receive notification that the Context had failed.
|
class |
JobDriver.FailedEvaluatorHandler
Receive notification that the entire Evaluator had failed.
|
class |
JobDriver.FailedTaskHandler
Handle failed task.
|
class |
JobDriver.RestartHandler
Job driver is restarted after previous crash.
|
class |
JobDriver.RunningTaskHandler
Receive notification that the Task is running.
|
class |
JobDriver.StartHandler
Job Driver is ready and the clock is set up: request the evaluators.
|
class |
JobDriver.SuspendedTaskHandler
Receive notification that the Task has been suspended.
|
class |
JobDriver.TaskMessageHandler
Handler for message received from the Task.
|
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
Fault-injected handler for ContextStart.
|
Modifier and Type | Class and Description |
---|---|
class |
PoisonedTaskStartHandler
Fault-injected handler for TaskStart.
|
Modifier and Type | Class and Description |
---|---|
class |
RunningJobImpl
Implementation of RunningJob.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JobSubmissionHandler
A Handler for JobSubmissionEvent.
|
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 appropriate application code.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ResourceLaunchHandler |
interface |
ResourceManagerStartHandler
Initialize the resource manager.
|
interface |
ResourceManagerStopHandler
Shutdown the resource manager.
|
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 |
DefaultContextMessageHandler
Default event handler for ContextMessage: Logging it.
|
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 |
DefaultContextStartHandler
Default handler for ContextStart.
|
class |
DefaultContextStopHandler
Default event handler for ContextStop.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultCloseHandler
Default implementation for
EventHandler<CloseEvent> . |
class |
DefaultDriverMessageHandler
A default implementation of
EventHandler<DriverMessage> . |
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 |
ProfilingStopHandler
An EventHandler that writes out the profiler results.
|
class |
REEFErrorHandler
The error handler REEF registers with Wake.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadCastEventHandler<E>
Handler for BroadCastEvent which sends event to all handlers in the list.
|
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)
Deprecated.
in 0.14, will be deleted in 0.15
|
<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<ResourceStatusEvent> resourceStatusHandler,
InjectionFuture<ResourceManager> resourceManager) |
Modifier and Type | Class and Description |
---|---|
class |
MesosSchedulerDriverExecutor
Handler for Mesos SchedulerDriver.
|
Modifier and Type | Class and Description |
---|---|
class |
MesosErrorHandler
ErrorHandler for MesosRemoteManager.
|
Modifier and Type | Method and Description |
---|---|
<T> EventHandler<T> |
MesosRemoteManager.getHandler(String destinationIdentifier,
Class<? extends T> messageType) |
Modifier and Type | Method and Description |
---|---|
<T,U extends T> |
MesosRemoteManager.registerHandler(Class<U> messageType,
EventHandler<RemoteMessage<T>> theHandler) |
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
Handler for AllocatedEvaluator.
|
class |
DriverFailOnFail.FailedTaskHandler
Handler for FailedTask.
|
class |
DriverFailOnFail.StartHandler
Handler for StartTime.
|
class |
FailDriverDelayedMsg.ActiveContextHandler
Handler for ActiveContext.
|
class |
FailDriverDelayedMsg.AllocatedEvaluatorHandler
Handler for AllocatedEvaluator.
|
class |
FailDriverDelayedMsg.RunningTaskHandler
Handler for RunningTask.
|
class |
FailDriverDelayedMsg.StartHandler
Handler for StartTime.
|
class |
FailDriverDelayedMsg.TaskMessageHandler
Handler for TaskMessage.
|
class |
NoopTask.DriverMessageHandler
Handler for DriverMessage.
|
class |
NoopTask.TaskCloseHandler
Handler for CloseEvent.
|
class |
NoopTask.TaskStopHandler
Handler for TaskStop.
|
class |
NoopTask.TaskSuspendHandler
Handler for SuspendEvent.
|
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
Handler for CloseEvent.
|
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
Handler for AllocatedEvaluator.
|
class |
TaskMessagingDriver.TaskMessageHandler
Handler for TaskMessage.
|
class |
TaskMessagingDriver.TaskRunningHandler
Handler for RunningTask.
|
class |
TaskMessagingTask.DriverMessageHandler
Handler for DriverMessage.
|
Modifier and Type | Class and Description |
---|---|
class |
OnDriverStartedAllocateOneInRack
A Driver start handler that requests a single Evaluator of size 64MB in the
specified rack.
|
Modifier and Type | Class and Description |
---|---|
class |
FailedContextHandler
Failing handler for ContextStart (throws exception upon start).
|
class |
FailedTaskStartHandler
Failing handler for TaskStart (throws exception upon start).
|
class |
WatcherTestDriver.ContextActivatedHandler
Handler for ActiveContext.
|
class |
WatcherTestDriver.ContextFailedHandler
Handler for FailedContext.
|
class |
WatcherTestDriver.DriverStartedHandler
Handler for StartTime.
|
class |
WatcherTestDriver.EvaluatorAllocatedHandler
Handler for AllocatedEvaluator.
|
class |
WatcherTestDriver.EvaluatorFailedHandler
Handler for FailedEvaluator.
|
class |
WatcherTestDriver.RuntimeStopHandler
Handler for RuntimeStop.
|
class |
WatcherTestDriver.TaskFailedHandler
Handler for FailedTask.
|
class |
WatcherTestDriver.TaskRunningHandler
Handler for RunningTask.
|
class |
WatcherTestDriver.TaskSuspendedHandler
Handler for SuspendedTask.
|
class |
WatcherTestTask.TaskSuspendedHandler
Handler for SuspendEvent.
|
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 | Class and Description |
---|---|
class |
VortexWorker.DriverMessageHandler
Handle requests from Vortex Master.
|
class |
VortexWorker.TaskCloseHandler
Shut down this worker.
|
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 | Method and Description |
---|---|
EventHandler<L> |
MergingEventHandler.getLeft() |
EventHandler<R> |
MergingEventHandler.getRight() |
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)
Create a thread pool with fixed threads.
|
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 |
---|---|
<T> RemoteManager |
RemoteManagerFactory.getInstance(String name,
Codec<T> codec,
EventHandler<Throwable> errorHandler) |
<T> RemoteManager |
RemoteManagerFactory.getInstance(String name,
int listeningPort,
Codec<T> codec,
EventHandler<Throwable> errorHandler) |
<T> RemoteManager |
RemoteManagerFactory.getInstance(String name,
String hostAddress,
int listeningPort,
Codec<T> codec,
EventHandler<Throwable> errorHandler,
boolean orderingGuarantee,
int numberOfTries,
int retryTimeout)
The old constructor of DefaultRemoteManagerImplementation.
|
<T> RemoteManager |
RemoteManagerFactory.getInstance(String name,
String hostAddress,
int listeningPort,
Codec<T> codec,
EventHandler<Throwable> errorHandler,
boolean orderingGuarantee,
int numberOfTries,
int retryTimeout,
LocalAddressProvider localAddressProvider,
TcpPortProvider tcpPortProvider)
The all-out constructor of DefaultRemoteManagerImplementation.
|
AutoCloseable |
RemoteManager.registerErrorHandler(EventHandler<Exception> theHandler)
Deprecated.
before 0.14, will be deleted in 0.15
|
<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 |
DefaultTransportEStage
A default event-based message transporting stage for both client and server.
|
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.
|
Constructor and Description |
---|
ConnectFutureTask(Callable<T> callable,
EventHandler<ConnectFutureTask<T>> handler) |
OrderedRemoteReceiverStage(EventHandler<RemoteEvent<byte[]>> handler,
EventHandler<Throwable> errorHandler)
Constructs an ordered remote receiver stage.
|
OrderedRemoteReceiverStage(EventHandler<RemoteEvent<byte[]>> handler,
EventHandler<Throwable> errorHandler)
Constructs an 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 |
---|---|
Transport |
TransportFactory.newInstance(int port,
EventHandler<TransportEvent> clientHandler,
EventHandler<TransportEvent> serverHandler,
EventHandler<Exception> exHandler)
Creates a transport.
|
Transport |
TransportFactory.newInstance(int port,
EventHandler<TransportEvent> clientHandler,
EventHandler<TransportEvent> serverHandler,
EventHandler<Exception> exHandler)
Creates a transport.
|
Transport |
TransportFactory.newInstance(int port,
EventHandler<TransportEvent> clientHandler,
EventHandler<TransportEvent> serverHandler,
EventHandler<Exception> exHandler)
Creates a transport.
|
void |
Transport.registerErrorHandler(EventHandler<Exception> handler)
Registers the exception handler.
|
Modifier and Type | Method and Description |
---|---|
Transport |
MessagingTransportFactory.newInstance(int port,
EventHandler<TransportEvent> clientHandler,
EventHandler<TransportEvent> serverHandler,
EventHandler<Exception> exHandler)
Creates a transport.
|
Transport |
MessagingTransportFactory.newInstance(int port,
EventHandler<TransportEvent> clientHandler,
EventHandler<TransportEvent> serverHandler,
EventHandler<Exception> exHandler)
Creates a transport.
|
Transport |
MessagingTransportFactory.newInstance(int port,
EventHandler<TransportEvent> clientHandler,
EventHandler<TransportEvent> serverHandler,
EventHandler<Exception> exHandler)
Creates a transport.
|
void |
NettyMessagingTransport.registerErrorHandler(EventHandler<Exception> handler)
Registers the exception event handler.
|
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.DriverRestartActiveContextStateHandler
Receive notification that a new Context is available.
|
class |
ReefEventStateManager.DriverRestartHandler
Job Driver has been restarted.
|
class |
ReefEventStateManager.DriverRestartTaskRunningStateHandler
Receive event during driver restart that a task is running in previous evaluator.
|
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,
InjectionFuture<ProgressProvider> progressProvider) |
Copyright © 2016 The Apache Software Foundation. All rights reserved.