Package | Description |
---|---|
org.apache.reef.client.parameters |
Named parameters for the REEF client API.
|
org.apache.reef.driver.context |
Driver Contexts and their configurations.
|
org.apache.reef.driver.parameters |
Named parameters used by the Driver.
|
org.apache.reef.driver.task |
Tasks and their configurations.
|
org.apache.reef.evaluator.context.parameters |
Named parameters used by the Evaluator.
|
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.bgd.operatornames |
Parameter names used to identify the various operators used in BGD.
|
org.apache.reef.examples.group.bgd.parameters |
Parameters for BGD.
|
org.apache.reef.examples.group.broadcast |
Broadcast Group Communication example.
|
org.apache.reef.examples.group.broadcast.parameters |
Parameters for Broadcast group communication.
|
org.apache.reef.examples.library |
A library for distributed shell example.
|
org.apache.reef.examples.pool |
Allocate N evaluators, submit M tasks to them, and measure the time.
|
org.apache.reef.examples.scheduler.client |
Task scheduler example client classes.
|
org.apache.reef.examples.suspend |
Suspend/resume demo.
|
org.apache.reef.io.checkpoint |
Checkpoints that provide APIs and implementations to store and retrieve the state of a task.
|
org.apache.reef.io.data.loading.api |
Data Loading Service API.
|
org.apache.reef.io.data.loading.impl |
Implementations of Data Loading Service.
|
org.apache.reef.io.data.output |
Data Output Service.
|
org.apache.reef.io.network.group.api.driver |
Elastic Group Communications Driver-side API Interfaces.
|
org.apache.reef.io.network.group.api.operators |
Provides the interfaces for MPI style group communication operations.
|
org.apache.reef.io.network.group.api.task |
Elastic Group Communications Task-side API Interfaces.
|
org.apache.reef.io.network.group.impl.config.parameters |
Parameters for Elastic Group Communications.
|
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.network.impl.config |
TODO: Document.
|
org.apache.reef.io.network.naming |
TODO: Document.
|
org.apache.reef.io.network.naming.parameters |
TODO: Document.
|
org.apache.reef.io.parameters |
Parameters for reef-common.src.main.java.org.apache.reef.io.
|
org.apache.reef.io.storage.ram |
Implementations for RAM-based storage service.
|
org.apache.reef.io.watcher |
Watcher subscribes events and writes them to the destination using a certain EventStream.
|
org.apache.reef.io.watcher.param |
Parameters for Watcher.
|
org.apache.reef.javabridge.generic |
Generic java bridge driver/client.
|
org.apache.reef.poison.params |
Parameters of fault injections.
|
org.apache.reef.runtime.common |
REEF implementation.
|
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.parameters |
Parameters used by client.
|
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.evaluator |
Driver-Side representations of Evaluators.
|
org.apache.reef.runtime.common.driver.parameters |
Parameters for the driver.
|
org.apache.reef.runtime.common.evaluator.parameters |
Parameters used by Evaluator.
|
org.apache.reef.runtime.common.launch.parameters |
Parameters of the Launcher.
|
org.apache.reef.runtime.common.parameters |
Parameters used by runtime.
|
org.apache.reef.runtime.hdinsight.parameters |
Parameters for HDInsight connection.
|
org.apache.reef.runtime.local.client.parameters |
Parameters of the local runtime.
|
org.apache.reef.runtime.mesos.client.parameters |
Client-side parameters for Mesos job submission.
|
org.apache.reef.runtime.mesos.driver.parameters |
Driver-side parameters for Mesos job submission.
|
org.apache.reef.runtime.mesos.evaluator.parameters |
Evaluator-side parameters for Mesos job.
|
org.apache.reef.runtime.standalone.client.parameters |
Parameters of the standalone runtime.
|
org.apache.reef.runtime.yarn.client.parameters |
Client-side parameters for YARN job submission.
|
org.apache.reef.runtime.yarn.driver.parameters |
Driver-side parameters of YARN job submission.
|
org.apache.reef.tang |
Public interfaces and factories for Tang's core API.
|
org.apache.reef.tang.examples.timer |
A more complicated version of the Timer example, including delegating
interfaces to default implementations.
|
org.apache.reef.tang.formats |
Tang format classes encode and decode information that Tang gathers at
runtime.
|
org.apache.reef.tang.implementation.java |
Private implementation classes that configure and inject code written
in Java.
|
org.apache.reef.tang.util |
Utilities for Tang.
|
org.apache.reef.tests.driver |
Tests whether a Driver can successfully be launched and shut down.
|
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.rack.awareness |
Tests for Rack-awareness.
|
org.apache.reef.tests.watcher |
Test reef.io.watcher.
|
org.apache.reef.tests.yarn.failure |
Tests for YARN failures.
|
org.apache.reef.util.logging |
Logging handler for clr bridge.
|
org.apache.reef.vortex.driver |
Vortex Code that runs as part of REEF Driver.
|
org.apache.reef.wake |
Public interfaces and factories for Wake's core API.
|
org.apache.reef.wake.remote |
Wake's remote communication.
|
org.apache.reef.wake.remote.ports.parameters |
Parameters for TCP port selection.
|
org.apache.reef.wake.time |
Clock and time-based events(start/stop/alarm) implementation.
|
org.apache.reef.webserver |
HTTP Server component to implement a REST API for the Driver or Evaluators.
|
Modifier and Type | Class and Description |
---|---|
class |
DriverConfigurationProviders
Configuration provides whose Configurations will be mixed into the Driver Configuration.
|
class |
JobCompletedHandler
Event handler for CompletedJob.
|
class |
JobFailedHandler
Client EventHandler triggered on remote job failure.
|
class |
JobMessageHandler
Client EventHandler that gets messages from the Driver.
|
class |
JobRunningHandler
Client EventHandler triggered when the REEF job is running.
|
class |
ResourceManagerErrorHandler
Client EventHandler triggered on resource manager error.
|
Modifier and Type | Class and Description |
---|---|
static class |
ContextConfiguration.DriverReconnect
Implementation for re-connecting to driver after driver restart.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientCloseHandlers
Handles close requests from the client.
|
class |
ClientCloseWithMessageHandlers
Handles client close requests.
|
class |
ClientMessageHandlers
Handles message from the Client.
|
class |
ContextActiveHandlers
Handler for ActiveContext.
|
class |
ContextClosedHandlers
Handler for ClosedContext.
|
class |
ContextFailedHandlers
Handler for FailedContext.
|
class |
ContextMessageHandlers
Context message handler.
|
class |
DriverIdentifier
Driver Identifier.
|
class |
DriverIdleSources
Sources considered when making an idleness decision.
|
class |
DriverJobSubmissionDirectory
Job submission directory.
|
class |
DriverLocalFiles
Files to be made accessible on the Driver only.
|
class |
DriverLocalLibraries
Libraries to be made accessible on the Driver only.
|
class |
DriverMemory
Driver RAM allocation in MB.
|
class |
DriverRestartCompletedHandlers
Handler for event that all evaluators have checked back in after driver restart and that the restart is completed.
|
class |
DriverRestartContextActiveHandlers
Handler for ActiveContext during a driver restart.
|
class |
DriverRestartEvaluatorRecoverySeconds
Represents the amount of time in seconds that the driver restart waits for evaluators to report back.
|
class |
DriverRestartFailedEvaluatorHandlers
The
NamedParameter for Evaluators that have failed on Driver Restart. |
class |
DriverRestartHandler
The EventHandler invoked on Driver restart.
|
class |
DriverRestartTaskRunningHandlers
Handler for RunningTask events during a Driver restart.
|
class |
DriverStartHandler
Called once the Driver is completely setup.
|
class |
EvaluatorAllocatedHandlers
Called when an allocated evaluator is given to the client.
|
class |
EvaluatorCompletedHandlers
Called when an exception occurs on a running evaluator.
|
class |
EvaluatorConfigurationProviders
Configuration provides whose Configurations will be mixed into the Evaluator Configuration.
|
class |
EvaluatorDispatcherThreads
Number of threads allocated per evaluator to dispatch events from that Evaluator.
|
class |
EvaluatorFailedHandlers
Called when an exception occurs on a running evaluator.
|
class |
FailDriverOnEvaluatorLogErrors
Whether to fail driver on Evaluator preservation log errors.
|
class |
JobGlobalFiles
Files to be made accessible on the Driver and all Evaluators.
|
class |
JobGlobalLibraries
Libraries to be made accessible on the Driver and all Evaluators.
|
class |
JobSubmissionDirectory
Deprecated.
in 0.14. Use org.apache.reef.runtime.yarn.driver.parameters.JobSubmissionDirectory.
|
class |
MaxApplicationSubmissions
Whether the resource manager should preserve evaluators on job driver failure.
|
class |
ResourceManagerPreserveEvaluators
Whether the resource manager should preserve evaluators on job driver failure.
|
class |
ServiceContextActiveHandlers
Handler for ActiveContext.
|
class |
ServiceContextClosedHandlers
Handler for ClosedContext.
|
class |
ServiceContextFailedHandlers
Handler for FailedContext.
|
class |
ServiceContextMessageHandlers
Context message handler.
|
class |
ServiceDriverRestartCompletedHandlers
Service handler for driver restart completed event.
|
class |
ServiceDriverRestartContextActiveHandlers
Handler for ActiveContext received during driver restart.
|
class |
ServiceDriverRestartedHandlers
Service Handler for driver restarts.
|
class |
ServiceDriverRestartFailedEvaluatorHandlers
Service handler for driver restart evaluator failed event.
|
class |
ServiceDriverRestartTaskRunningHandlers
Running task handler during driver restart.
|
class |
ServiceEvaluatorAllocatedHandlers
Called when an allocated evaluator is given to the client.
|
class |
ServiceEvaluatorCompletedHandlers
Called when an exception occurs on a running evaluator.
|
class |
ServiceEvaluatorFailedHandlers
Called when an exception occurs on a running evaluator.
|
class |
ServiceTaskCompletedHandlers
Completed task handler.
|
class |
ServiceTaskFailedHandlers
Task failure handler.
|
class |
ServiceTaskMessageHandlers
Task message handler.
|
class |
ServiceTaskRunningHandlers
Running task handler.
|
class |
ServiceTaskSuspendedHandlers
Suspended task handler.
|
class |
TaskCompletedHandlers
Completed task handler.
|
class |
TaskFailedHandlers
Task failure handler.
|
class |
TaskMessageHandlers
Task message handler.
|
class |
TaskRunningHandlers
Running task handler.
|
class |
TaskSuspendedHandlers
Suspended task handler.
|
Modifier and Type | Class and Description |
---|---|
class |
TaskConfigurationOptions.CloseHandler
The event handler that receives the close event.
|
static class |
TaskConfigurationOptions.Identifier
The Identifier of the Task.
|
class |
TaskConfigurationOptions.Memento
The memento to be used for the Task.
|
class |
TaskConfigurationOptions.MessageHandler
The event handler that receives messages from the driver.
|
class |
TaskConfigurationOptions.StartHandlers
The set of event handlers for the TaskStart event.
|
class |
TaskConfigurationOptions.StopHandlers
The set of event handlers for the TaskStop event.
|
class |
TaskConfigurationOptions.SuspendHandler
The event handler that receives the suspend event.
|
class |
TaskConfigurationOptions.TaskMessageSources
TaskMessageSource instances.
|
Modifier and Type | Class and Description |
---|---|
class |
ContextIdentifier
Context identifier.
|
class |
ContextMessageSources
The set of ContextMessageSource implementations called during heartbeats.
|
class |
ContextStartHandlers
The set of event handlers for the ContextStart event.
|
class |
ContextStopHandlers
The set of event handlers for the ContextStop event.
|
class |
Services
A set of classes to be instantiated and shared as singletons within this context and all child context.
|
Modifier and Type | Class and Description |
---|---|
static class |
DataLoadingREEF.InputDir
Input path.
|
static class |
DataLoadingREEF.Local
Command line parameter = true to run locally, or false to run on YARN.
|
static class |
DataLoadingREEF.TimeOut
Number of minutes before timeout.
|
Modifier and Type | Class and Description |
---|---|
static class |
OutputServiceREEF.Local
Command line parameter = true to run locally, or false to run on YARN.
|
static class |
OutputServiceREEF.OutputDir
Command line parameter = path of the output directory.
|
static class |
OutputServiceREEF.TimeOut
Command line parameter = number of minutes before timeout.
|
Modifier and Type | Class and Description |
---|---|
class |
ControlMessageBroadcaster
Used to identify the broadcast operator for control flow messages.
|
class |
DescentDirectionBroadcaster
Name of the broadcast operator used to send descent directions during linesearch.
|
class |
LineSearchEvaluationsReducer
Name of the reducer used to aggregate line search results.
|
class |
LossAndGradientReducer
Name used for the Reduce operator for loss and gradient aggregation.
|
class |
MinEtaBroadcaster
The name of the MinEta broadcast operator.
|
class |
ModelAndDescentDirectionBroadcaster
Name of the broadcast operator used to send a model and descent direction during line search.
|
class |
ModelBroadcaster
The name of the broadcast operator used for model broadcasts.
|
Modifier and Type | Class and Description |
---|---|
class |
AllCommunicationGroup
Communication group name.
|
class |
EnableRampup
Maximum Number of Iterations.
|
class |
Eps
Break criterion for the optimizer.
|
class |
Eta
Break criterion for the optimizer.
|
class |
EvaluatorMemory
The memory used for each Evaluator.
|
class |
InputDir
The input folder of the learner.
|
class |
Iterations
Maximum Number of Iterations.
|
class |
Lambda
The regularization constant.
|
class |
LossFunctionType |
class |
MinParts
Maximum Number of Iterations.
|
class |
ModelDimensions
The dimensionality of the model learned.
|
class |
NumberOfReceivers |
class |
NumSplits
Number of splits.
|
class |
ProbabilityOfFailure
Break criterion for the optimizer.
|
class |
ProbabilityOfSuccessfulIteration
Break criterion for the optimizer.
|
class |
Timeout
Timeout.
|
Modifier and Type | Class and Description |
---|---|
static class |
BroadcastREEF.InputDir
Input path.
|
static class |
BroadcastREEF.Local
Command line parameter = true to run locally, or false to run on YARN.
|
Modifier and Type | Class and Description |
---|---|
class |
Dimensions |
class |
FailureProbability |
class |
ModelReceiveAckReducer
Reduce operator name for model receive acknowledgement.
|
Modifier and Type | Class and Description |
---|---|
class |
Command
Command line parameter: a command to run.
|
Modifier and Type | Class and Description |
---|---|
static class |
Launch.Delay
Command line parameter: number of experiments to run.
|
static class |
Launch.JobId
Command line parameter = Numeric ID for the job.
|
static class |
Launch.NumEvaluators
Command line parameter: number of Evaluators to request.
|
static class |
Launch.NumTasks
Command line parameter: number of Tasks to run.
|
static class |
Launch.Piggyback
Command line parameter = true to submit task and context in one request.
|
Modifier and Type | Class and Description |
---|---|
static class |
SchedulerREEF.Retain
Command line parameter = true to reuse evaluators,.
|
Modifier and Type | Class and Description |
---|---|
static class |
Control.Command
Command: 'suspend' or 'resume'.
|
static class |
Control.TaskId
Task id.
|
static class |
Launch.NumCycles
Command line parameter: number of iterations to run.
|
static class |
SuspendClientControl.Port
Port for suspend/resume control commands.
|
Modifier and Type | Class and Description |
---|---|
static class |
RandomNameCNS.PREFIX
The prefix used for the random names returned.
|
static class |
SimpleNamingService.CheckpointName
Prefix for checkpoints.
|
Modifier and Type | Class and Description |
---|---|
static class |
DataLoadingRequestBuilder.LoadDataIntoMemory |
static class |
DataLoadingRequestBuilder.NumberOfDesiredSplits |
Modifier and Type | Class and Description |
---|---|
static class |
DistributedDataSetPartitionSerializer.DistributedDataSetPartitions
Allows to specify a set of distributed data set partitions.
|
static class |
InputSplitExternalConstructor.SerializedInputSplit |
static class |
JobConfExternalConstructor.InputFormatClass |
static class |
JobConfExternalConstructor.InputPath |
Modifier and Type | Class and Description |
---|---|
static class |
TaskOutputService.OutputPath
Path of the directory where output files are created.
|
Modifier and Type | Method and Description |
---|---|
CommunicationGroupDriver |
CommunicationGroupDriver.addBroadcast(Class<? extends Name<String>> operatorName,
BroadcastOperatorSpec spec)
Add the broadcast operator specified by the.
|
CommunicationGroupDriver |
CommunicationGroupDriver.addGather(Class<? extends Name<String>> operatorName,
GatherOperatorSpec spec)
Add the gather operator specified by
operatorName and spec . |
CommunicationGroupDriver |
CommunicationGroupDriver.addReduce(Class<? extends Name<String>> operatorName,
ReduceOperatorSpec spec)
Add the reduce operator specified by the.
|
CommunicationGroupDriver |
CommunicationGroupDriver.addScatter(Class<? extends Name<String>> operatorName,
ScatterOperatorSpec spec)
Add the scatter operator specified by
operatorName and spec . |
CommunicationGroupDriver |
GroupCommDriver.newCommunicationGroup(Class<? extends Name<String>> groupName,
Class<? extends Topology> topologyClass,
int numberOfTasks,
int customFanOut)
Create a new communication group with the specified name, topology implementation,
the minimum number of tasks needed in this group before
communication can start, and a custom fanOut.
|
CommunicationGroupDriver |
GroupCommDriver.newCommunicationGroup(Class<? extends Name<String>> groupName,
int numberOfTasks)
Create a new communication group with the specified name.
|
CommunicationGroupDriver |
GroupCommDriver.newCommunicationGroup(Class<? extends Name<String>> groupName,
int numberOfTasks,
int customFanOut)
Create a new communication group with the specified name,
the minimum number of tasks needed in this group before
communication can start, and a custom fanOut.
|
Modifier and Type | Method and Description |
---|---|
Class<? extends Name<String>> |
GroupCommOperator.getGroupName() |
Class<? extends Name<String>> |
AbstractGroupCommOperator.getGroupName() |
Class<? extends Name<String>> |
GroupCommOperator.getOperName() |
Class<? extends Name<String>> |
AbstractGroupCommOperator.getOperName() |
Modifier and Type | Method and Description |
---|---|
Class<? extends Name<String>> |
OperatorTopologyStruct.getGroupName() |
Class<? extends Name<String>> |
CommunicationGroupClient.getName() |
Class<? extends Name<String>> |
OperatorTopologyStruct.getOperName() |
Modifier and Type | Method and Description |
---|---|
void |
CommGroupNetworkHandler.addTopologyElement(Class<? extends Name<String>> operName) |
Broadcast.Receiver |
CommunicationGroupClient.getBroadcastReceiver(Class<? extends Name<String>> operatorName)
The broadcast receiver configured on this communication group.
|
Broadcast.Sender |
CommunicationGroupClient.getBroadcastSender(Class<? extends Name<String>> operatorName)
The broadcast sender configured on this communication group.
|
CommunicationGroupClient |
GroupCommClient.getCommunicationGroup(Class<? extends Name<String>> groupName) |
Gather.Receiver |
CommunicationGroupClient.getGatherReceiver(Class<? extends Name<String>> operatorName)
Return the gather receiver configured on this communication group.
|
Gather.Sender |
CommunicationGroupClient.getGatherSender(Class<? extends Name<String>> operatorName)
Return the gather sender configured on this communication group.
|
Reduce.Receiver |
CommunicationGroupClient.getReduceReceiver(Class<? extends Name<String>> operatorName)
The reduce receiver configured on this communication group.
|
Reduce.Sender |
CommunicationGroupClient.getReduceSender(Class<? extends Name<String>> operatorName)
The reduce sender configured on this communication group.
|
Scatter.Receiver |
CommunicationGroupClient.getScatterReceiver(Class<? extends Name<String>> operatorName)
Return the scatter receiver configured on this communication group.
|
Scatter.Sender |
CommunicationGroupClient.getScatterSender(Class<? extends Name<String>> operatorName)
Return the scatter sender configured on this communication group.
|
void |
GroupCommNetworkHandler.register(Class<? extends Name<String>> groupName,
EventHandler<GroupCommunicationMessage> commGroupNetworkHandler) |
void |
CommGroupNetworkHandler.register(Class<? extends Name<String>> operName,
EventHandler<GroupCommunicationMessage> handler) |
byte[] |
CommGroupNetworkHandler.waitForTopologyChanges(Class<? extends Name<String>> operName) |
GroupCommunicationMessage |
CommGroupNetworkHandler.waitForTopologyUpdate(Class<? extends Name<String>> operName) |
Modifier and Type | Class and Description |
---|---|
class |
CommGroupMessageHandler
Name class of the comm group message handler.
|
class |
CommGroupNameClass
NamedParameter wrapper for the name class of the comm group.
|
class |
CommGroupNumTask
Name class of the number of tasks in the comm group.
|
class |
CommunicationGroupName |
class |
DataCodec |
class |
DriverIdentifierGroupComm |
class |
GroupCommFailedEvalHandler
Name class of group comm failed evaluator handler.
|
class |
GroupCommFailedTaskHandler
Name class of group comm failed task handler.
|
class |
GroupCommRunningTaskHandler
Name class of group comm running task handler.
|
class |
GroupCommSenderStage
Name class of group comm sender stage.
|
class |
OperatorName
Name of the operator.
|
class |
OperatorNameClass
NamedParameter wrapper for the name class of the operator.
|
class |
ReduceFunctionParam
The reduce function class that is associated with a reduce operator.
|
class |
SerializedGroupConfigs |
class |
SerializedOperConfigs
Serialized operator configurations.
|
class |
TaskVersion |
class |
TopologyClass
NamedParameter for topology implementation.
|
class |
TreeTopologyFanOut
The fan out for the tree topology.
|
Modifier and Type | Method and Description |
---|---|
Class<? extends Name<String>> |
IndexedMsg.getOperName() |
Modifier and Type | Method and Description |
---|---|
CommunicationGroupDriver |
CommunicationGroupDriverImpl.addBroadcast(Class<? extends Name<String>> operatorName,
BroadcastOperatorSpec spec) |
CommunicationGroupDriver |
CommunicationGroupDriverImpl.addGather(Class<? extends Name<String>> operatorName,
GatherOperatorSpec spec) |
void |
GroupCommMessageHandler.addHandler(Class<? extends Name<String>> groupName,
BroadcastingEventHandler<GroupCommunicationMessage> handler)
Deprecated.
in 0.14.
|
void |
GroupCommMessageHandler.addHandler(Class<? extends Name<String>> groupName,
SingleThreadStage<GroupCommunicationMessage> stage) |
CommunicationGroupDriver |
CommunicationGroupDriverImpl.addReduce(Class<? extends Name<String>> operatorName,
ReduceOperatorSpec spec) |
CommunicationGroupDriver |
CommunicationGroupDriverImpl.addScatter(Class<? extends Name<String>> operatorName,
ScatterOperatorSpec spec) |
Topology |
TopologyFactory.getNewInstance(Class<? extends Name<String>> operatorName,
Class<? extends Topology> topologyClass)
Instantiates a new Topology instance.
|
CommunicationGroupDriver |
CommunicationGroupDriverFactory.getNewInstance(Class<? extends Name<String>> groupName,
Class<? extends Topology> topologyClass,
BroadcastingEventHandler<GroupCommunicationMessage> commGroupMessageHandler,
int numberOfTasks,
int customFanOut)
Deprecated.
in 0.14.
Instantiates a new CommunicationGroupDriver instance.
|
CommunicationGroupDriver |
CommunicationGroupDriverFactory.getNewInstance(Class<? extends Name<String>> groupName,
Class<? extends Topology> topologyClass,
int numberOfTasks,
int customFanOut)
Instantiates a new CommunicationGroupDriver instance.
|
CommunicationGroupDriver |
GroupCommDriverImpl.newCommunicationGroup(Class<? extends Name<String>> groupName,
Class<? extends Topology> topologyClass,
int numberOfTasks,
int customFanOut) |
CommunicationGroupDriver |
GroupCommDriverImpl.newCommunicationGroup(Class<? extends Name<String>> groupName,
int numberOfTasks) |
CommunicationGroupDriver |
GroupCommDriverImpl.newCommunicationGroup(Class<? extends Name<String>> groupName,
int numberOfTasks,
int customFanOut) |
Constructor and Description |
---|
CommunicationGroupDriverImpl(Class<? extends Name<String>> groupName,
ConfigurationSerializer confSerializer,
EStage<GroupCommunicationMessage> senderStage,
BroadcastingEventHandler<RunningTask> groupCommRunningTaskHandler,
BroadcastingEventHandler<FailedTask> groupCommFailedTaskHandler,
BroadcastingEventHandler<FailedEvaluator> groupCommFailedEvaluatorHandler,
BroadcastingEventHandler<GroupCommunicationMessage> commGroupMessageHandler,
String driverId,
int numberOfTasks,
int fanOut)
Deprecated.
in 0.14. Use Tang to obtain an instance of this instead.
|
FlatTopology(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operatorName,
String driverId,
int numberOfTasks)
Deprecated.
in 0.14. Use Tang to obtain an instance of this instead.
|
FlatTopology(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operatorName,
String driverId,
int numberOfTasks)
Deprecated.
in 0.14. Use Tang to obtain an instance of this instead.
|
TaskNodeImpl(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operatorName,
String taskId,
String driverId,
boolean isRoot) |
TaskNodeImpl(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operatorName,
String taskId,
String driverId,
boolean isRoot) |
TaskNodeStatusImpl(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String taskId,
TaskNode node) |
TaskNodeStatusImpl(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String taskId,
TaskNode node) |
TopologyUpdateWaitHandler(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String driverId,
int driverVersion,
String dstId,
int dstVersion,
String qualifiedName,
byte[] data)
The handler will wait for all nodes to acquire topoLock
and send TopologySetup msg.
|
TopologyUpdateWaitHandler(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String driverId,
int driverVersion,
String dstId,
int dstVersion,
String qualifiedName,
byte[] data)
The handler will wait for all nodes to acquire topoLock
and send TopologySetup msg.
|
TreeTopology(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operatorName,
String driverId,
int numberOfTasks,
int fanOut)
Deprecated.
in 0.14. Use Tang to obtain an instance of this instead.
|
TreeTopology(EStage<GroupCommunicationMessage> senderStage,
Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operatorName,
String driverId,
int numberOfTasks,
int fanOut)
Deprecated.
in 0.14. Use Tang to obtain an instance of this instead.
|
Modifier and Type | Method and Description |
---|---|
Class<? extends Name<String>> |
ScatterSender.getGroupName() |
Class<? extends Name<String>> |
ScatterReceiver.getGroupName() |
Class<? extends Name<String>> |
ReduceSender.getGroupName() |
Class<? extends Name<String>> |
ReduceReceiver.getGroupName() |
Class<? extends Name<String>> |
GatherSender.getGroupName() |
Class<? extends Name<String>> |
GatherReceiver.getGroupName() |
Class<? extends Name<String>> |
BroadcastSender.getGroupName() |
Class<? extends Name<String>> |
BroadcastReceiver.getGroupName() |
Class<? extends Name<String>> |
ScatterSender.getOperName() |
Class<? extends Name<String>> |
ScatterReceiver.getOperName() |
Class<? extends Name<String>> |
ReduceSender.getOperName() |
Class<? extends Name<String>> |
ReduceReceiver.getOperName() |
Class<? extends Name<String>> |
GatherSender.getOperName() |
Class<? extends Name<String>> |
GatherReceiver.getOperName() |
Class<? extends Name<String>> |
BroadcastSender.getOperName() |
Class<? extends Name<String>> |
BroadcastReceiver.getOperName() |
Modifier and Type | Method and Description |
---|---|
Class<? extends Name<String>> |
OperatorTopologyStructImpl.getGroupName() |
Class<? extends Name<String>> |
CommunicationGroupClientImpl.getName() |
Class<? extends Name<String>> |
OperatorTopologyStructImpl.getOperName() |
Modifier and Type | Method and Description |
---|---|
void |
CommGroupNetworkHandlerImpl.addTopologyElement(Class<? extends Name<String>> operName) |
Broadcast.Receiver |
CommunicationGroupClientImpl.getBroadcastReceiver(Class<? extends Name<String>> operatorName) |
Broadcast.Sender |
CommunicationGroupClientImpl.getBroadcastSender(Class<? extends Name<String>> operatorName) |
CommunicationGroupClient |
GroupCommClientImpl.getCommunicationGroup(Class<? extends Name<String>> groupName) |
Gather.Receiver |
CommunicationGroupClientImpl.getGatherReceiver(Class<? extends Name<String>> operatorName) |
Gather.Sender |
CommunicationGroupClientImpl.getGatherSender(Class<? extends Name<String>> operatorName) |
Reduce.Receiver |
CommunicationGroupClientImpl.getReduceReceiver(Class<? extends Name<String>> operatorName) |
Reduce.Sender |
CommunicationGroupClientImpl.getReduceSender(Class<? extends Name<String>> operatorName) |
Scatter.Receiver |
CommunicationGroupClientImpl.getScatterReceiver(Class<? extends Name<String>> operatorName) |
Scatter.Sender |
CommunicationGroupClientImpl.getScatterSender(Class<? extends Name<String>> operatorName) |
void |
GroupCommNetworkHandlerImpl.register(Class<? extends Name<String>> groupName,
EventHandler<GroupCommunicationMessage> commGroupNetworkHandler) |
void |
CommGroupNetworkHandlerImpl.register(Class<? extends Name<String>> operName,
EventHandler<GroupCommunicationMessage> operHandler) |
byte[] |
CommGroupNetworkHandlerImpl.waitForTopologyChanges(Class<? extends Name<String>> operName) |
GroupCommunicationMessage |
CommGroupNetworkHandlerImpl.waitForTopologyUpdate(Class<? extends Name<String>> operName) |
Constructor and Description |
---|
OperatorTopologyImpl(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String selfId,
String driverId,
Sender sender,
int version) |
OperatorTopologyImpl(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String selfId,
String driverId,
Sender sender,
int version) |
OperatorTopologyStructImpl(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String selfId,
String driverId,
Sender sender,
int version) |
OperatorTopologyStructImpl(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
String selfId,
String driverId,
Sender sender,
int version) |
Modifier and Type | Method and Description |
---|---|
static Class<? extends Name<String>> |
Utils.getClass(String className) |
Modifier and Type | Method and Description |
---|---|
static GroupCommunicationMessage |
Utils.bldVersionedGCM(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
ReefNetworkGroupCommProtos.GroupCommMessage.Type msgType,
String from,
int srcVersion,
String to,
int dstVersion,
byte[]... data) |
static GroupCommunicationMessage |
Utils.bldVersionedGCM(Class<? extends Name<String>> groupName,
Class<? extends Name<String>> operName,
ReefNetworkGroupCommProtos.GroupCommMessage.Type msgType,
String from,
int srcVersion,
String to,
int dstVersion,
byte[]... data) |
Modifier and Type | Class and Description |
---|---|
static class |
NetworkServiceParameters.NetworkServiceCodec |
static class |
NetworkServiceParameters.NetworkServiceExceptionHandler |
static class |
NetworkServiceParameters.NetworkServiceHandler |
static class |
NetworkServiceParameters.NetworkServiceIdentifierFactory |
static class |
NetworkServiceParameters.NetworkServicePort |
static class |
NetworkServiceParameters.NetworkServiceTransportFactory |
static class |
NetworkServiceParameters.TaskId |
Modifier and Type | Class and Description |
---|---|
class |
NetworkConnectionServiceIdFactory |
class |
NetworkConnectionServicePort |
Modifier and Type | Class and Description |
---|---|
class |
NameServerParameters.NameServerAddr |
class |
NameServerParameters.NameServerIdentifierFactory |
class |
NameServerParameters.NameServerPort |
Modifier and Type | Class and Description |
---|---|
class |
NameResolverCacheTimeout |
class |
NameResolverIdentifierFactory |
class |
NameResolverNameServerAddr |
class |
NameResolverNameServerPort |
class |
NameResolverRetryCount |
class |
NameResolverRetryTimeout |
Modifier and Type | Class and Description |
---|---|
class |
TempFileRootFolder
Directory for temp files.
|
Modifier and Type | Class and Description |
---|---|
static class |
CodecRamMap.RamMapCodec |
Modifier and Type | Class and Description |
---|---|
static class |
FileEventStream.Path |
Modifier and Type | Class and Description |
---|---|
class |
EventStreams
Set of EventStreams.
|
Modifier and Type | Class and Description |
---|---|
static class |
Launch.DriverIdentifier
Command line parameter, driver identifier.
|
static class |
Launch.DriverJobSubmissionDirectory
Command line parameter, job submission directory, if set, user should guarantee its uniqueness.
|
static class |
Launch.DriverMemoryInMb
Command line parameter, driver memory, in MB.
|
static class |
Launch.Local
Command line parameter = true to run locally, or false to run on YARN.
|
static class |
Launch.NumRuns
Command line parameter: number of experiments to run.
|
static class |
Launch.Submit
Command line parameter = true to submit the job with driver config, or false to write config to current directory.
|
static class |
Launch.WaitTimeForDriver
Command line parameter, number of seconds to wait till driver finishes ,
= -1 : waits forever
= 0: exit immediately without wait for driver.
|
Modifier and Type | Class and Description |
---|---|
class |
CrashProbability
The probability with which a crash will occur.
|
class |
CrashTimeout
The time window after ContextStart in which the crash will occur.
|
Modifier and Type | Class and Description |
---|---|
static class |
REEFLauncher.ProfilingEnabled
Parameter which enables profiling.
|
Modifier and Type | Class and Description |
---|---|
static class |
REEFImplementation.DriverRemoteIdentifier
The driver remote identifier.
|
Modifier and Type | Class and Description |
---|---|
static class |
ClientRuntimeParameters.RuntimeErrorHandlerRID
The runtime error handler RID.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientPresent
A Tang named parameter that indicates whether or not a client (handler for the various Job events) is present.
|
Modifier and Type | Class and Description |
---|---|
static class |
DriverRuntimeConfigurationOptions.JobControlHandler
Handler called when a job control message is received by the client.
|
Modifier and Type | Class and Description |
---|---|
static class |
RuntimeParameters.NodeDescriptorHandler
The node descriptor handler that stub runtimes send along node information.
|
static class |
RuntimeParameters.ResourceAllocationHandler
The resource allocation handler that stub runtimes send along allocated resources e.g., containers.
|
static class |
RuntimeParameters.ResourceStatusHandler
The resource status handler.
|
static class |
RuntimeParameters.RuntimeStatusHandler
The resourcemanager status handler.
|
Modifier and Type | Class and Description |
---|---|
static class |
EvaluatorManager.EvaluatorDescriptorName
The Evaluator Host.
|
static class |
EvaluatorManager.EvaluatorIdentifier
The Evaluator Identifier.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientRemoteIdentifier
The client remote identifier.
|
class |
DriverProcessMemory
The driver process memory.
|
class |
EvaluatorTimeout
The evaluator timeout (how long to wait before deciding an evaluator is dead.
|
class |
JobIdentifier
The job identifier.
|
Modifier and Type | Class and Description |
---|---|
class |
ApplicationIdentifier
The RM application/job identifier.
|
class |
DriverRemoteIdentifier
The identifier used by the Evaluator to connect back to the Driver.
|
class |
EvaluatorIdentifier
The evaluator identifier.
|
class |
HeartbeatPeriod
The evaluator heartbeat period in ms.
|
class |
InitialTaskConfiguration
An initial task to launch on startup.
|
class |
RootContextConfiguration
The evaluator root context configuration.
|
class |
RootServiceConfiguration
The service configuration for the root context.
|
Modifier and Type | Class and Description |
---|---|
class |
ClockConfigurationPath
The path to the clock configuration.
|
class |
DriverLaunchCommandPrefix
List of strings to be prepended to driver launch command (I.E.
|
class |
ErrorHandlerRID
The error handler remote identifier.
|
class |
LaunchID
The launch identifier.
|
Modifier and Type | Class and Description |
---|---|
class |
DeleteTempFiles
Whether or not to delete the temporary files created during Driver and Evaluator submission.
|
class |
JVMHeapSlack
The fraction of the container memory NOT to use for the Java Heap.
|
Modifier and Type | Class and Description |
---|---|
class |
AzureStorageAccountContainerName
The Storage account container name to be used by Azure.
|
class |
AzureStorageAccountKey
The Storage account key to be used by Azure.
|
class |
AzureStorageAccountName
The Storage account to be used by Azure.
|
class |
AzureStorageBaseFolder
The folder to use as the base folder for storing the JARs.
|
class |
HDInsightInstanceURL
The password to be used for connecting to hdinsight.
|
class |
HDInsightPassword
The password to be used for connecting to hdinsight.
|
class |
HDInsightUsername
The username to be used for connecting to hdinsight.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultMemorySize
The size of the default container returned in MB.
|
class |
DefaultNumberOfCores
The number of the default core.
|
class |
MaxNumberOfEvaluators
The maximum number of evaluators to allow to run at once.
|
class |
RackNames
The name of the default racks available in the local runtime.
|
class |
RootFolder
The folder where logs etc.
|
Modifier and Type | Class and Description |
---|---|
class |
MasterIp
The ip address of Mesos Master.
|
Modifier and Type | Class and Description |
---|---|
class |
MesosMasterIp
The ip address of Mesos Master.
|
class |
MesosSlavePort
The port number of Mesos Slave.
|
Modifier and Type | Class and Description |
---|---|
class |
MesosExecutorId
Mesos Executor's id.
|
Modifier and Type | Class and Description |
---|---|
class |
NodeListFilePath
The file which will contain information of remote nodes.
|
Modifier and Type | Class and Description |
---|---|
class |
JobPriority
The priority of the submitted job.
|
class |
JobQueue
The queue to submit a job to.
|
Modifier and Type | Class and Description |
---|---|
class |
JobSubmissionDirectoryPrefix
The job submission directory.
|
class |
YarnEvaluatorPreserver
The Evaluator Preserver to use on YARN, defaults to DFS.
|
class |
YarnHeartbeatPeriod
How often we talk to YARN.
|
Modifier and Type | Method and Description |
---|---|
<T> JavaConfigurationBuilder |
JavaConfigurationBuilder.bindList(Class<? extends Name<List<T>>> iface,
List impl)
Binds a specific list to a named parameter.
|
JavaConfigurationBuilder |
JavaConfigurationBuilder.bindNamedParameter(Class<? extends Name<?>> name,
String value)
Set the value of a named parameter.
|
<T> JavaConfigurationBuilder |
JavaConfigurationBuilder.bindNamedParameter(Class<? extends Name<T>> iface,
Class<? extends T> impl) |
<T> JavaConfigurationBuilder |
JavaConfigurationBuilder.bindSetEntry(Class<? extends Name<Set<T>>> iface,
Class<? extends T> impl) |
<T> JavaConfigurationBuilder |
JavaConfigurationBuilder.bindSetEntry(Class<? extends Name<Set<T>>> iface,
String value) |
<T> void |
Injector.bindVolatileParameter(Class<? extends Name<T>> iface,
T inst) |
<U> U |
Injector.getNamedInstance(Class<? extends Name<U>> iface)
Gets the value stored for the given named parameter.
|
boolean |
Injector.isParameterSet(Class<? extends Name<?>> name) |
Modifier and Type | Class and Description |
---|---|
static class |
Timer.Seconds |
Modifier and Type | Method and Description |
---|---|
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindList(Class<? extends Name<List<T>>> iface,
Impl<List> opt) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindList(Class<? extends Name<List<T>>> iface,
List list) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindList(Class<? extends Name<List<T>>> iface,
Param<List> opt) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindNamedParameter(Class<? extends Name<T>> iface,
Class<? extends T> impl) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindNamedParameter(Class<? extends Name<T>> iface,
Impl<? extends T> opt) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindNamedParameter(Class<? extends Name<T>> name,
Param<T> opt) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindNamedParameter(Class<? extends Name<T>> name,
String value) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindSetEntry(Class<? extends Name<Set<T>>> iface,
Class<? extends T> impl) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindSetEntry(Class<? extends Name<Set<T>>> iface,
Impl<? extends T> opt) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindSetEntry(Class<? extends Name<Set<T>>> iface,
Param<? extends T> opt) |
<T> ConfigurationModuleBuilder |
ConfigurationModuleBuilder.bindSetEntry(Class<? extends Name<Set<T>>> iface,
String impl) |
CommandLine |
CommandLine.registerShortNameOfClass(Class<? extends Name<?>> c) |
Modifier and Type | Method and Description |
---|---|
<T> JavaConfigurationBuilder |
JavaConfigurationBuilderImpl.bindList(Class<? extends Name<List<T>>> iface,
List implList)
Binding list method for JavaConfigurationBuilder.
|
JavaConfigurationBuilder |
JavaConfigurationBuilderImpl.bindNamedParameter(Class<? extends Name<?>> name,
String value) |
<T> JavaConfigurationBuilder |
JavaConfigurationBuilderImpl.bindNamedParameter(Class<? extends Name<T>> iface,
Class<? extends T> impl) |
<T> JavaConfigurationBuilder |
JavaConfigurationBuilderImpl.bindSetEntry(Class<? extends Name<Set<T>>> iface,
Class<? extends T> impl) |
<T> JavaConfigurationBuilder |
JavaConfigurationBuilderImpl.bindSetEntry(Class<? extends Name<Set<T>>> iface,
String value) |
<T> void |
InjectorImpl.bindVolatileParameter(Class<? extends Name<T>> cl,
T o) |
static <T> NamedParameterNode<T> |
JavaNodeFactory.createNamedParameterNode(Node parent,
Class<? extends Name<T>> clazz,
Type argClass)
XXX: This method assumes that all generic types have exactly one type parameter.
|
<T> T |
InjectorImpl.getNamedInstance(Class<? extends Name<T>> clazz) |
<T> T |
InjectorImpl.getNamedParameter(Class<? extends Name<T>> clazz) |
boolean |
InjectorImpl.isParameterSet(Class<? extends Name<?>> name) |
Modifier and Type | Class and Description |
---|---|
class |
ValidateConfiguration.ClassHierarchyIn |
class |
ValidateConfiguration.ConfigurationIn |
class |
ValidateConfiguration.ConfigurationOut |
class |
ValidateConfiguration.Target |
Modifier and Type | Class and Description |
---|---|
static class |
RuntimeNameTestConfiguration.RuntimeName
The runtime name.
|
Modifier and Type | Class and Description |
---|---|
static class |
FailDriver.FailMsgClassName
Name of the message class to specify the failing message handler.
|
Modifier and Type | Class and Description |
---|---|
static class |
Driver.FailTaskName
Name of the message class to specify the failing message handler.
|
Modifier and Type | Class and Description |
---|---|
class |
RackNameParameter
Rack name.
|
Modifier and Type | Class and Description |
---|---|
class |
IsTaskSuspended
Boolean value, true = task is suspended.
|
Modifier and Type | Class and Description |
---|---|
static class |
FailureREEF.Local
Command line parameter = true to run locally, or false to run on YARN.
|
static class |
FailureREEF.TimeOut
Number of minutes before timeout.
|
Modifier and Type | Class and Description |
---|---|
class |
LogLevelName
Name of a log Level as a string such as "INFO", "FINE".
|
Modifier and Type | Class and Description |
---|---|
class |
VortexWorkerConf.NumOfThreads
Worker Threads.
|
Modifier and Type | Class and Description |
---|---|
static class |
StageConfiguration.Capacity
The capacity for the stage.
|
static class |
StageConfiguration.ErrorHandler
The error handler for the stage.
|
static class |
StageConfiguration.NumberOfThreads
The number of threads for the stage.
|
static class |
StageConfiguration.StageExecutorService
The executor service for the stage.
|
static class |
StageConfiguration.StageHandler
The event handler for the stage.
|
static class |
StageConfiguration.StageName
The stage name.
|
static class |
StageConfiguration.StageObserver
The observer for the stage.
|
static class |
StageConfiguration.TimerInitialDelay
The initial delay for periodic events of the timer stage.
|
static class |
StageConfiguration.TimerPeriod
The period for periodic events of the timer stage.
|
static class |
WakeParameters.ExecutorShutdownTimeout
Executor shutdown timeout.
|
static class |
WakeParameters.MaxFrameLength
Maximum frame length unit.
|
static class |
WakeParameters.RemoteSendTimeout
Remote send timeout.
|
Modifier and Type | Class and Description |
---|---|
static class |
RemoteConfiguration.ErrorHandler
The event handler to be used for throwables.
|
static class |
RemoteConfiguration.HostAddress
The host address to be used for messages.
|
static class |
RemoteConfiguration.ManagerName
The name of the remote manager.
|
static class |
RemoteConfiguration.MessageCodec
The codec to be used for messages.
|
static class |
RemoteConfiguration.NumberOfTries
The number of tries.
|
static class |
RemoteConfiguration.OrderingGuarantee
Whether or not to use the message ordering guarantee.
|
static class |
RemoteConfiguration.Port
The port to be used for messages.
|
static class |
RemoteConfiguration.RemoteClientStage
Client stage for messaging transport.
|
static class |
RemoteConfiguration.RemoteServerStage
Server stage for messaging transport.
|
static class |
RemoteConfiguration.RetryTimeout
The timeout of connection retrying.
|
Modifier and Type | Class and Description |
---|---|
class |
TcpPortRangeBegin
First tcp port number to try.
|
class |
TcpPortRangeCount
Number of tcp ports in the range.
|
class |
TcpPortRangeTryCount
Max number tries for port numbers.
|
Modifier and Type | Class and Description |
---|---|
static class |
Clock.IdleHandler
Bind this to an event handler to statically subscribe to the IdleClock Event.
|
static class |
Clock.RuntimeStartHandler
Bind this to an event handler to statically subscribe to the RuntimeStart Event.
|
static class |
Clock.RuntimeStopHandler
Bind this to an event handler to statically subscribe to the RuntimeStart Event.
|
static class |
Clock.StartHandler
Bind this to an event handler to statically subscribe to the StartTime Event.
|
static class |
Clock.StopHandler
Bind this to an event handler to statically subscribe to the StopTime Event.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpEventHandlers
HttpEventHandlers.
|
Copyright © 2016 The Apache Software Foundation. All rights reserved.