| 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.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.multi.client.parameters | Parameters for the multi runtime. | 
| org.apache.reef.runtime.multi.driver.parameters | Parameters for multi runtime driver. | 
| 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.evaluator.failure | Tests for Evaluator failures. | 
| org.apache.reef.tests.evaluator.failure.parameters | Parameters for  FailureDriver. | 
| 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.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  | DriverConfigurationProvidersConfiguration provides whose Configurations will be mixed into the Driver Configuration. | 
| class  | JobCompletedHandlerEvent handler for CompletedJob. | 
| class  | JobFailedHandlerClient EventHandler triggered on remote job failure. | 
| class  | JobMessageHandlerClient EventHandler that gets messages from the Driver. | 
| class  | JobRunningHandlerClient EventHandler triggered when the REEF job is running. | 
| class  | JobSubmittedHandlerHandler for the SubmittedJob event. | 
| class  | ResourceManagerErrorHandlerClient EventHandler triggered on resource manager error. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | ContextConfiguration.DriverReconnectImplementation for re-connecting to driver after driver restart. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientCloseHandlersHandles close requests from the client. | 
| class  | ClientCloseWithMessageHandlersHandles client close requests. | 
| class  | ClientMessageHandlersHandles message from the Client. | 
| class  | ContextActiveHandlersHandler for ActiveContext. | 
| class  | ContextClosedHandlersHandler for ClosedContext. | 
| class  | ContextFailedHandlersHandler for FailedContext. | 
| class  | ContextMessageHandlersContext message handler. | 
| class  | DriverIdentifierDriver Identifier. | 
| class  | DriverIdleSourcesSources considered when making an idleness decision. | 
| class  | DriverIsUnmanagedIf true, run Driver in unmanaged mode. | 
| class  | DriverJobSubmissionDirectoryJob submission directory. | 
| class  | DriverLocalFilesFiles to be made accessible on the Driver only. | 
| class  | DriverLocalLibrariesLibraries to be made accessible on the Driver only. | 
| class  | DriverMemoryDriver RAM allocation in MB. | 
| class  | DriverRestartCompletedHandlersHandler for event that all evaluators have checked back in after driver restart and that the restart is completed. | 
| class  | DriverRestartContextActiveHandlersHandler for ActiveContext during a driver restart. | 
| class  | DriverRestartEvaluatorRecoverySecondsRepresents the amount of time in seconds that the driver restart waits for evaluators to report back. | 
| class  | DriverRestartFailedEvaluatorHandlersThe  NamedParameterfor Evaluators that have failed on Driver Restart. | 
| class  | DriverRestartHandlerThe EventHandler invoked on Driver restart. | 
| class  | DriverRestartTaskRunningHandlersHandler for RunningTask events during a Driver restart. | 
| class  | DriverStartHandlerCalled once the Driver is completely setup. | 
| class  | EvaluatorAllocatedHandlersCalled when an allocated evaluator is given to the client. | 
| class  | EvaluatorCompletedHandlersCalled when an exception occurs on a running evaluator. | 
| class  | EvaluatorConfigurationProvidersConfiguration provides whose Configurations will be mixed into the Evaluator Configuration. | 
| class  | EvaluatorDispatcherThreadsNumber of threads allocated per evaluator to dispatch events from that Evaluator. | 
| class  | EvaluatorFailedHandlersCalled when an exception occurs on a running evaluator. | 
| class  | FailDriverOnEvaluatorLogErrorsWhether to fail driver on Evaluator preservation log errors. | 
| class  | JobGlobalFilesFiles to be made accessible on the Driver and all Evaluators. | 
| class  | JobGlobalLibrariesLibraries to be made accessible on the Driver and all Evaluators. | 
| class  | MaxApplicationSubmissionsWhether the resource manager should preserve evaluators on job driver failure. | 
| class  | ResourceManagerPreserveEvaluatorsWhether the resource manager should preserve evaluators on job driver failure. | 
| class  | ServiceContextActiveHandlersHandler for ActiveContext. | 
| class  | ServiceContextClosedHandlersHandler for ClosedContext. | 
| class  | ServiceContextFailedHandlersHandler for FailedContext. | 
| class  | ServiceContextMessageHandlersContext message handler. | 
| class  | ServiceDriverRestartCompletedHandlersService handler for driver restart completed event. | 
| class  | ServiceDriverRestartContextActiveHandlersHandler for ActiveContext received during driver restart. | 
| class  | ServiceDriverRestartedHandlersService Handler for driver restarts. | 
| class  | ServiceDriverRestartFailedEvaluatorHandlersService handler for driver restart evaluator failed event. | 
| class  | ServiceDriverRestartTaskRunningHandlersRunning task handler during driver restart. | 
| class  | ServiceEvaluatorAllocatedHandlersCalled when an allocated evaluator is given to the client. | 
| class  | ServiceEvaluatorCompletedHandlersCalled when an exception occurs on a running evaluator. | 
| class  | ServiceEvaluatorFailedHandlersCalled when an exception occurs on a running evaluator. | 
| class  | ServiceTaskCompletedHandlersCompleted task handler. | 
| class  | ServiceTaskFailedHandlersTask failure handler. | 
| class  | ServiceTaskMessageHandlersTask message handler. | 
| class  | ServiceTaskRunningHandlersRunning task handler. | 
| class  | ServiceTaskSuspendedHandlersSuspended task handler. | 
| class  | TaskCompletedHandlersCompleted task handler. | 
| class  | TaskFailedHandlersTask failure handler. | 
| class  | TaskMessageHandlersTask message handler. | 
| class  | TaskRunningHandlersRunning task handler. | 
| class  | TaskSuspendedHandlersSuspended task handler. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TaskConfigurationOptions.CloseHandlerThe event handler that receives the close event. | 
| static class  | TaskConfigurationOptions.IdentifierThe Identifier of the Task. | 
| class  | TaskConfigurationOptions.MementoThe memento to be used for the Task. | 
| class  | TaskConfigurationOptions.MessageHandlerThe event handler that receives messages from the driver. | 
| class  | TaskConfigurationOptions.StartHandlersThe set of event handlers for the TaskStart event. | 
| class  | TaskConfigurationOptions.StopHandlersThe set of event handlers for the TaskStop event. | 
| class  | TaskConfigurationOptions.SuspendHandlerThe event handler that receives the suspend event. | 
| class  | TaskConfigurationOptions.TaskMessageSourcesTaskMessageSource instances. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ContextIdentifierContext identifier. | 
| class  | ContextMessageSourcesThe set of ContextMessageSource implementations called during heartbeats. | 
| class  | ContextStartHandlersThe set of event handlers for the ContextStart event. | 
| class  | ContextStopHandlersThe set of event handlers for the ContextStop event. | 
| class  | ServicesA 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.InputDirInput path. | 
| static class  | DataLoadingREEF.LocalCommand line parameter = true to run locally, or false to run on YARN. | 
| static class  | DataLoadingREEF.TimeOutNumber of minutes before timeout. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | OutputServiceREEF.LocalCommand line parameter = true to run locally, or false to run on YARN. | 
| static class  | OutputServiceREEF.OutputDirCommand line parameter = path of the output directory. | 
| static class  | OutputServiceREEF.TimeOutCommand line parameter = number of minutes before timeout. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ControlMessageBroadcasterUsed to identify the broadcast operator for control flow messages. | 
| class  | DescentDirectionBroadcasterName of the broadcast operator used to send descent directions during linesearch. | 
| class  | LineSearchEvaluationsReducerName of the reducer used to aggregate line search results. | 
| class  | LossAndGradientReducerName used for the Reduce operator for loss and gradient aggregation. | 
| class  | MinEtaBroadcasterThe name of the MinEta broadcast operator. | 
| class  | ModelAndDescentDirectionBroadcasterName of the broadcast operator used to send a model and descent direction during line search. | 
| class  | ModelBroadcasterThe name of the broadcast operator used for model broadcasts. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AllCommunicationGroupCommunication group name. | 
| class  | EnableRampupMaximum Number of Iterations. | 
| class  | EpsBreak criterion for the optimizer. | 
| class  | EtaBreak criterion for the optimizer. | 
| class  | EvaluatorMemoryThe memory used for each Evaluator. | 
| class  | InputDirThe input folder of the learner. | 
| class  | IterationsMaximum Number of Iterations. | 
| class  | LambdaThe regularization constant. | 
| class  | LossFunctionType | 
| class  | MinPartsMaximum Number of Iterations. | 
| class  | ModelDimensionsThe dimensionality of the model learned. | 
| class  | NumberOfReceivers | 
| class  | NumSplitsNumber of splits. | 
| class  | ProbabilityOfFailureBreak criterion for the optimizer. | 
| class  | ProbabilityOfSuccessfulIterationBreak criterion for the optimizer. | 
| class  | TimeoutTimeout. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | BroadcastREEF.InputDirInput path. | 
| static class  | BroadcastREEF.LocalCommand line parameter = true to run locally, or false to run on YARN. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | Dimensions | 
| class  | FailureProbability | 
| class  | ModelReceiveAckReducerReduce operator name for model receive acknowledgement. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CommandCommand line parameter: a command to run, e.g. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | Launch.DelayCommand line parameter: number of experiments to run. | 
| static class  | Launch.JobIdCommand line parameter = Numeric ID for the job. | 
| static class  | Launch.NumEvaluatorsCommand line parameter: number of Evaluators to request. | 
| static class  | Launch.NumTasksCommand line parameter: number of Tasks to run. | 
| static class  | Launch.PiggybackCommand line parameter = true to submit task and context in one request. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | SchedulerREEF.RetainCommand line parameter = true to reuse evaluators,. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | Control.CommandCommand: 'suspend' or 'resume'. | 
| static class  | Control.TaskIdTask id. | 
| static class  | Launch.NumCyclesCommand line parameter: number of iterations to run. | 
| static class  | SuspendClientControl.PortPort for suspend/resume control commands. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | RandomNameCNS.LengthOfRandomSuffixNumber of alphanumeric characters in the random part of a checkpoint name. | 
| static class  | RandomNameCNS.PREFIXThe prefix used for the random names returned. | 
| static class  | SimpleNamingService.CheckpointNamePrefix 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.DistributedDataSetPartitionsAllows 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.OutputPathPath 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  operatorNameandspec. | 
| 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  operatorNameandspec. | 
| 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  | CommGroupMessageHandlerName class of the comm group message handler. | 
| class  | CommGroupNameClassNamedParameter wrapper for the name class of the comm group. | 
| class  | CommGroupNumTaskName class of the number of tasks in the comm group. | 
| class  | CommunicationGroupName | 
| class  | DataCodec | 
| class  | DriverIdentifierGroupComm | 
| class  | GroupCommFailedEvalHandlerName class of group comm failed evaluator handler. | 
| class  | GroupCommFailedTaskHandlerName class of group comm failed task handler. | 
| class  | GroupCommRunningTaskHandlerName class of group comm running task handler. | 
| class  | GroupCommSenderStageName class of group comm sender stage. | 
| class  | OperatorNameName of the operator. | 
| class  | OperatorNameClassNamedParameter wrapper for the name class of the operator. | 
| class  | ReduceFunctionParamThe reduce function class that is associated with a reduce operator. | 
| class  | SerializedGroupConfigs | 
| class  | SerializedOperConfigsSerialized operator configurations. | 
| class  | TaskVersion | 
| class  | TopologyClassNamedParameter for topology implementation. | 
| class  | TreeTopologyFanOutThe 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,
                    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,
                            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. | 
| 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. | 
| 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  | TempFileRootFolderDirectory 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  | EventStreamsSet of EventStreams. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | Launch.DriverIdentifierCommand line parameter, driver identifier. | 
| static class  | Launch.DriverJobSubmissionDirectoryCommand line parameter, job submission directory, if set, user should guarantee its uniqueness. | 
| static class  | Launch.DriverMemoryInMbCommand line parameter, driver memory, in MB. | 
| static class  | Launch.LocalCommand line parameter = true to run locally, or false to run on YARN. | 
| static class  | Launch.NumRunsCommand line parameter: number of experiments to run. | 
| static class  | Launch.SubmitCommand line parameter = true to submit the job with driver config, or false to write config to current directory. | 
| static class  | Launch.WaitTimeForDriverCommand 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  | CrashProbabilityThe probability with which a crash will occur. | 
| class  | CrashTimeoutThe time window after ContextStart in which the crash will occur. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | REEFImplementation.DriverRemoteIdentifierThe driver remote identifier. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | ClientRuntimeParameters.RuntimeErrorHandlerRIDThe runtime error handler RID. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientPresentA 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.JobControlHandlerHandler called when a job control message is received by the client. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | RuntimeParameters.NodeDescriptorHandlerThe node descriptor handler that stub runtimes send along node information. | 
| static class  | RuntimeParameters.ResourceAllocationHandlerThe resource allocation handler that stub runtimes send along allocated resources e.g., containers. | 
| static class  | RuntimeParameters.ResourceStatusHandlerThe resource status handler. | 
| static class  | RuntimeParameters.RuntimeStatusHandlerThe resourcemanager status handler. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | EvaluatorManager.EvaluatorDescriptorNameThe Evaluator Host. | 
| static class  | EvaluatorManager.EvaluatorIdentifierThe Evaluator Identifier. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientRemoteIdentifierThe client remote identifier. | 
| class  | DefinedRuntimesThe defined runtimes for the job driver. | 
| class  | DriverProcessMemoryThe driver process memory. | 
| class  | EvaluatorIdlenessThreadPoolSizeThe number of Threads in a Driver to verify the completion of Evaluators. | 
| class  | EvaluatorIdlenessWaitInMillisecondsThe number of Threads in a Driver to verify the completion of Evaluators. | 
| class  | EvaluatorTimeoutThe evaluator timeout (how long to wait before deciding an evaluator is dead. | 
| class  | JobIdentifierThe job identifier. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ApplicationIdentifierThe RM application/job identifier. | 
| class  | DriverRemoteIdentifierThe identifier used by the Evaluator to connect back to the Driver. | 
| class  | EvaluatorConfigurationThe evaluator configuration. | 
| class  | EvaluatorIdentifierThe evaluator identifier. | 
| class  | HeartbeatPeriodThe evaluator heartbeat period in ms. | 
| class  | InitialTaskConfigurationAn initial task to launch on startup. | 
| class  | RootContextConfigurationThe evaluator root context configuration. | 
| class  | RootServiceConfigurationThe service configuration for the root context. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClockConfigurationPathThe path to the clock configuration. | 
| class  | DriverLaunchCommandPrefixList of strings to be prepended to driver launch command (I.E. | 
| class  | ErrorHandlerRIDThe error handler remote identifier. | 
| class  | LaunchIDThe launch identifier. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DeleteTempFilesWhether or not to delete the temporary files created during Driver and Evaluator submission. | 
| class  | JVMHeapSlackThe fraction of the container memory NOT to use for the Java Heap. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AzureStorageAccountContainerNameThe Storage account container name to be used by Azure. | 
| class  | AzureStorageAccountKeyThe Storage account key to be used by Azure. | 
| class  | AzureStorageAccountNameThe Storage account to be used by Azure. | 
| class  | AzureStorageBaseFolderThe folder to use as the base folder for storing the JARs. | 
| class  | HDInsightInstanceURLThe password to be used for connecting to hdinsight. | 
| class  | HDInsightPasswordThe password to be used for connecting to hdinsight. | 
| class  | HDInsightUsernameThe username to be used for connecting to hdinsight. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DefaultMemorySizeThe size of the default container returned in MB. | 
| class  | DefaultNumberOfCoresThe number of the default core. | 
| class  | MaxNumberOfEvaluatorsThe maximum number of evaluators to allow to run at once. | 
| class  | RackNamesThe name of the default racks available in the local runtime. | 
| class  | RootFolderThe folder where logs etc. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MasterIpThe ip address of Mesos Master. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MesosMasterIpThe ip address of Mesos Master. | 
| class  | MesosSlavePortThe port number of Mesos Slave. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MesosExecutorIdMesos Executor's id. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DefaultRuntimeNameSerialized tang configuration for a runtime. | 
| class  | RuntimeNamesSerialized tang configuration for a runtime. | 
| class  | SerializedRuntimeDefinitionSerialized MultiRuntimeDefinition. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RuntimeNameSerialized tang configuration for a runtime. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NodeFolderThe folder where required jar files shall be stored. | 
| class  | NodeInfoSetInformation of remote nodes available in the standalone runtime. | 
| class  | NodeListFilePathThe file which will contain information of remote nodes. | 
| class  | SshPortNumThe port number to access the remote nodes. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JobPriorityThe priority of the submitted job. | 
| class  | JobQueueThe queue to submit a job to. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FileSystemUrlThe file system URL. | 
| class  | JobSubmissionDirectoryThe job submission directory. | 
| class  | JobSubmissionDirectoryPrefixThe job submission directory. | 
| class  | YarnEvaluatorPreserverThe Evaluator Preserver to use on YARN, defaults to DFS. | 
| class  | YarnHeartbeatPeriodHow 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.RuntimeNameThe runtime name. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | FailureREEF.LocalCommand line parameter = true to run locally, or false to run on YARN. | 
| static class  | FailureREEF.TimeOutNumber of minutes before timeout. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NumEvaluatorsToFailThe number of Evaluators to fail and resubmit in  FailureDriver. | 
| class  | NumEvaluatorsToSubmitThe number of Evaluators to submit in  FailureDriver. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | FailDriver.FailMsgClassNameName of the message class to specify the failing message handler. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | Driver.FailTaskNameName of the message class to specify the failing message handler. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RackNameParameterRack name. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | IsTaskSuspendedBoolean value, true = task is suspended. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LogLevelNameName of a log Level as a string such as "INFO", "FINE". | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | VortexWorkerConf.NumOfThreadsWorker Threads. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | StageConfiguration.CapacityThe capacity for the stage. | 
| static class  | StageConfiguration.ErrorHandlerThe error handler for the stage. | 
| static class  | StageConfiguration.NumberOfThreadsThe number of threads for the stage. | 
| static class  | StageConfiguration.StageExecutorServiceThe executor service for the stage. | 
| static class  | StageConfiguration.StageHandlerThe event handler for the stage. | 
| static class  | StageConfiguration.StageNameThe stage name. | 
| static class  | StageConfiguration.StageObserverThe observer for the stage. | 
| static class  | StageConfiguration.TimerInitialDelayThe initial delay for periodic events of the timer stage. | 
| static class  | StageConfiguration.TimerPeriodThe period for periodic events of the timer stage. | 
| static class  | WakeParameters.ExecutorShutdownTimeoutExecutor shutdown timeout. | 
| static class  | WakeParameters.MaxFrameLengthMaximum frame length unit. | 
| static class  | WakeParameters.RemoteSendTimeoutRemote send timeout. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | RemoteConfiguration.ErrorHandlerThe event handler to be used for throwables. | 
| static class  | RemoteConfiguration.HostAddressThe host address to be used for messages. | 
| static class  | RemoteConfiguration.ManagerNameThe name of the remote manager. | 
| static class  | RemoteConfiguration.MessageCodecThe codec to be used for messages. | 
| static class  | RemoteConfiguration.NumberOfTriesThe number of tries. | 
| static class  | RemoteConfiguration.OrderingGuaranteeWhether or not to use the message ordering guarantee. | 
| static class  | RemoteConfiguration.PortThe port to be used for messages. | 
| static class  | RemoteConfiguration.RemoteClientStageClient stage for messaging transport. | 
| static class  | RemoteConfiguration.RemoteServerStageServer stage for messaging transport. | 
| static class  | RemoteConfiguration.RetryTimeoutThe timeout of connection retrying. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TcpPortRangeBeginFirst tcp port number to try. | 
| class  | TcpPortRangeCountNumber of tcp ports in the range. | 
| class  | TcpPortRangeTryCountMax number tries for port numbers. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | Clock.IdleHandlerBind this to an event handler to statically subscribe to the IdleClock Event. | 
| static class  | Clock.RuntimeStartHandlerBind this to an event handler to statically subscribe to the RuntimeStart Event. | 
| static class  | Clock.RuntimeStopHandlerBind this to an event handler to statically subscribe to the RuntimeStart Event. | 
| static class  | Clock.StartHandlerBind this to an event handler to statically subscribe to the StartTime Event. | 
| static class  | Clock.StopHandlerBind this to an event handler to statically subscribe to the StopTime Event. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HttpEventHandlersHttpEventHandlers. | 
Copyright © 2017 The Apache Software Foundation. All rights reserved.