|
Apache REEF
0.15.0
Retainable Evaluator Execution Framework
|
| ▼NOrg | |
| ▼NApache | |
| ▼NREEF | |
| ►NClient | |
| ►NAPI | |
| ►NExceptions | |
| CClasspathException | Thrown when the client fails to assemble the classpath for the Java part of the client |
| CJavaNotFoundException | Thrown when the java installation cannot be found on the client |
| CAppParameters | The parameters for a REEF application, used to specify application parameters for each REEF application |
| CAppParametersBuilder | A builder for AppParameters |
| CClientFactory | Instantiates the client based on IConfiguration for the chosen runtime |
| CIREEFClient | Interface for job submission on a REEF cluster |
| CJobParameters | The parameters for a REEF job, used to specify job parameters on each REEF submission |
| CJobParametersBuilder | A builder for JobParameters |
| CJobRequest | Describes parameters for a single job submission |
| CJobRequestBuilder | |
| CTcpPortConfigurationModule | Configuration Module for the TCP port provider |
| ►NAvro | |
| ►NLocal | |
| CAvroLocalAppSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters |
| CAvroLocalJobSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters |
| ►NYARN | |
| CAvroYarnAppSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters |
| CAvroYarnClusterJobSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters |
| CAvroYarnJobSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters |
| CAvroAppSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters |
| CAvroJobSubmissionParameters | Used to serialize and deserialize Avro record org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters |
| ►NCommon | |
| CIJobSubmissionResult | |
| ►NLocal | |
| ►NParameters | |
| CLocalRuntimeDirectory | |
| CNumberOfEvaluators | |
| CLocalClient | An implementation of the REEF interface using an external Java program |
| CLocalRuntimeClientConfiguration | |
| ►NYarn | |
| ►NRestClient | |
| CIUrlProvider | |
| CIJobResourceUploader | |
| CIJobSubmissionDirectoryProvider | Provides path to job submission directory |
| CJobResource | |
| CJobSubmissionDirectoryProvider | Provides path to job submission directory |
| CYARNClientConfiguration | The Configuration for the YARN Client |
| ►NYARN | |
| ►NHDI | |
| CHDInsightClientConfiguration | |
| CHDInsightCommandLineEnvironment | Provides YARN classpath for HDInsight environment |
| CHDInsightPasswordSecureString | |
| CHDInsightPasswordString | |
| CHDInsightUrl | |
| CHDInsightUserName | |
| ►NParameters | |
| CDriverMaxMemoryAllicationPoolSizeMB | |
| CDriverMaxPermSizeMB | |
| CEnableDebugLogging | |
| CJobSubmissionDirectoryPrefixParameter | |
| CSecurityTokenKindParameter | |
| CSecurityTokenServiceParameter | |
| ►NRestClient | |
| CIYarnRestClientCredential | Provides the credentials to be used by the REST client to connect to YARN RM |
| CMultipleRMUrlProvider | |
| CYarnREEFDotNetClient | Temporary client for developing and testing .NET job submission E2E |
| ►NCommon | |
| ►NApi | |
| CAbstractFailure | |
| CIAbstractFailure | |
| CIFailure | Common interface for all error messages in REEF |
| ►NAvro | |
| CAvroDriverInfo | Used to serialize and deserialize Avro record org.apache.reef.webserver.AvroDriverInfo |
| CAvroFailedTask | Used to serialize and deserialize Avro record org.apache.reef.javabridge.avro.AvroFailedTask |
| CAvroHttpRequest | Used to serialize and deserialize Avro record org.apache.reef.webserver.AvroHttpRequest |
| CAvroJsonSerializer | Wrapper class for serialize/deserialize Avro json |
| CAvroReefServiceInfo | Used to serialize and deserialize Avro record org.apache.reef.webserver.AvroReefServiceInfo |
| CHeaderEntry | Used to serialize and deserialize Avro record org.apache.reef.webserver.HeaderEntry |
| ►NCatalog | |
| ►NCapabilities | |
| CCPU | |
| CICapability | |
| CRAM | |
| CINodeDescriptor | |
| CIRackDescriptor | |
| CIResourceCatalog | |
| ►NClient | |
| ►NParameters | |
| CDriverConfigurationProviders | |
| ►NContext | |
| ►NDefaults | |
| CDefaultContextMessageSource | Default ContextMessageSource: return nothing |
| CDefaultContextStartHandler | Default handler for ContextStart |
| CDefaultContextStopHandler | Default event handler for ContextStop |
| CContextConfiguration | |
| ►CContextConfigurationOptions | Configuration parameters for ContextConfiguration module |
| CContextIdentifier | |
| CContextMessageHandlers | |
| CContextMessageSources | |
| CStartHandlers | |
| CStopHandlers | |
| CContextMessage | |
| CIContextMessage | |
| CIContextMessageHandler | |
| CIContextMessageSource | Implement (and bind) this interface to send messages from a context as part of a heartbeat from Evaluator to Driver |
| ►NEvaluator | |
| ►NDriverConnectionConfigurationProviders | |
| CIDriverReconnConfigProvider | A configuration provider for the Evaluator to create the appropriate reconnection object to reconnect to the Driver based on the environment |
| CLocalHttpDriverReconnConfigProvider | A driver reconnection configuration provider for the Local Driver based on HTTP connection |
| CYarnClusterHttpDriverReconnConfigProvider | A driver reconnection configuration provider for the YARN Driver based on HTTP connection |
| CYarnOneBoxHttpDriverReconnConfigProvider | A driver reconnection configuration provider for the YARN OneBox Driver based on HTTP connection |
| ►NParameters | |
| CEvaluatorConfigurationProviders | |
| CDefaultLocalHttpDriverConnection | |
| CDefaultYarnClusterHttpDriverConnection | |
| CDefaultYarnOneBoxHttpDriverConnection | |
| CDriverInformation | |
| CIDriverConnection | |
| ►NEvents | |
| CIContextStart | |
| CIContextStop | |
| ►NExceptions | |
| CJobException | |
| CNonSerializableEvaluatorException | Encapsulates Exception::ToString for an Exception from a REEF Evaluator that was not Serializable to the Job Driver |
| CNonSerializableTaskException | Encapsulates Exception::ToString for an Exception from a REEF Task that was not Serializable to the Job Driver |
| ►NFiles | |
| CREEFFileNames | Contains all file system constants used by REEF |
| ►NIo | |
| CINameClient | Client for the Reef name service |
| CNameAssignment | Tuple containing the string identifier and IPEndpoint |
| CNamingConfiguration | |
| ►CNamingConfigurationOptions | |
| CNameServerAddress | |
| CNameServerPort | |
| CTcpPortConfigurationProvider | |
| ►NJar | |
| CResourceHelper | Helps with retrieval of embedded resources |
| ►NPoison | |
| CCrashMinDelay | |
| CCrashProbability | |
| CCrashTimeout | |
| CPoisonedEventHandler | Handler to process an event in a way that has certain probability of failure within certain inverval of time |
| CPoisonException | Exception thrown by PoisonedEventHandler |
| ►NProtobuf | |
| ►NReefProtocol | |
| CAddContextProto | |
| CContextControlProto | |
| CContextMessageProto | |
| ►CContextStatusProto | |
| CContextMessageProto | |
| CDoneEvaluatorProto | |
| CDriverProcessRegistrationProto | |
| CEvaluatorControlProto | |
| CEvaluatorHeartbeatProto | Add serializer/deserializer to EvaluatorHeartbeatProto |
| CEvaluatorHeartbeatProtoCodec | |
| CEvaluatorStatusProto | |
| CFileResourceProto | |
| CJobControlProto | |
| CJobStatusProto | |
| CJobSubmissionProto | |
| CKillEvaluatorProto | |
| CNodeDescriptorProto | |
| CREEFMessage | Add serializer/deserializer to REEFMessage |
| CREEFMessageCodec | |
| CRemoveContextProto | |
| CResourceAllocationProto | |
| CResourceLaunchProto | |
| CResourceReleaseProto | |
| CResourceRequestProto | |
| CResourceStatusProto | |
| CRuntimeErrorProto | |
| CRuntimeStatusProto | |
| CStartTaskProto | |
| CStopEvaluatorProto | |
| CStopTaskProto | |
| CSuspendTaskProto | |
| ►CTaskStatusProto | |
| CTaskMessageProto | |
| ►NRuntime | |
| ►NEvaluator | |
| CMachineStatus | |
| ►NServices | |
| CServiceConfiguration | Configuration module for services |
| CServicesSet | |
| ►NTasks | |
| ►NDefaults | |
| CDefaultDriverConnectionMessageHandler | |
| CDefaultDriverMessageHandler | |
| CDefaultTaskCloseHandler | A default handler for an event from the driver signaling the suspension of a task |
| CDefaultTaskMessageSource | |
| ►NEvents | |
| CICloseEvent | |
| CIDriverMessage | |
| CISuspendEvent | An event from the driver signaling that a task should be suspended |
| CITaskStart | |
| CITaskStop | |
| CIDriverConnectionMessage | The message triggered on a change of status in heartbeat to Driver |
| CIDriverConnectionMessageHandler | The handler implementable by users to handle IDriverConnectionMessages, which notifies the Task when there is a change in driver connection state |
| CIDriverMessageHandler | |
| CITask | |
| CITaskMessageSource | |
| CTaskConfiguration | |
| ►CTaskConfigurationOptions | |
| CCloseHandler | |
| CIdentifier | |
| CMemento | |
| CMessageHandler | |
| CStartHandlers | |
| CStopHandlers | |
| CSuspendHandler | |
| CTaskMessageSources | |
| CTaskMessage | |
| CConstants | |
| CIContextAndTaskSubmittable | Base interface for classes that support the simultaneous submission of both Context and Task configurations |
| CIContextSubmittable | Base interface for classes that support Context submission |
| CITaskSubmittable | Base interface for classes that support Task submission |
| ►NDriver | |
| ►NBridge | |
| ►NAvro | |
| CDefinedRuntimes | Used to serialize and deserialize Avro record org.apache.reef.javabridge.avro.DefinedRuntimes |
| ►NClr2java | |
| CIActiveContextClr2Java | |
| CIAllocatedEvaluatorClr2Java | |
| CIClosedContextClr2Java | A closed context event from Java |
| CIClr2Java | |
| CIClr2JavaTaskMessage | An message sent from a Task to a Driver |
| CICompletedEvaluatorClr2Java | |
| CICompletedTaskClr2Java | |
| CIContextMessageClr2Java | |
| CIDriverRestartCompletedClr2Java | |
| CIDriverRestartedClr2Java | |
| CIEvaluatorRequestorClr2Java | |
| CIFailedContextClr2Java | |
| CIFailedEvaluatorClr2Java | |
| CIFailedTaskClr2Java | |
| CIHttpServerBridgeClr2Java | |
| CIRunningTaskClr2Java | |
| CISuspendedTaskClr2Java | |
| CITaskMessageClr2Java | |
| CBridgeHandlerManager | A class that holds all .NET handles for Java InterOp calls |
| CBridgeLogger | A wrapper around the general Logger class used specifically for logging in CPP bridge code |
| CClrClientHelper | |
| CClrHandlerHelper | |
| CClrSystemHandlerWrapper | |
| CCommandLineArguments | |
| CCustomTraceLevel | |
| CCustomTraceListeners | |
| ►CDriverBridgeConfigurationOptions | Hosts all named parameters for Drivers, including bridge handlers |
| CActiveContextHandlers | |
| CAllocatedEvaluatorHandlers | |
| CArgumentSets | |
| CClosedContextHandlers | |
| CCompletedEvaluatorHandlers | |
| CCompletedTaskHandlers | |
| CContextMessageHandlers | |
| CDriverRestartActiveContextHandlers | |
| CDriverRestartCompletedHandlers | |
| CDriverRestartedHandlers | |
| CDriverRestartEvaluatorRecoverySeconds | |
| CDriverRestartFailedEvaluatorHandlers | |
| CDriverRestartRunningTaskHandlers | |
| CDriverStartedHandlers | |
| CEvaluatorRequestHandlers | |
| CFailedContextHandlers | |
| CFailedEvaluatorHandlers | |
| CFailedTaskHandlers | |
| CHttpEventHandlers | |
| CRunningTaskHandlers | |
| CSetOfAssemblies | |
| CSuspendedTaskHandlers | |
| CTaskMessageHandlers | |
| CTraceLevel | |
| CTraceListenersSet | |
| CHttpServerPort | |
| CIHttpHandler | |
| CIHttpMessage | |
| CILogger | |
| CReefHttpRequest | |
| CReefHttpResponse | |
| ►NContext | |
| CIActiveContext | |
| CIClosedContext | A closed context |
| CIContext | A common base interface for Contexts, available or failed |
| CIFailedContext | |
| ►NDefaults | |
| CDefaultClientCloseHandler | Default handler for close messages from the client: logging it |
| CDefaultClientCloseWithMessageHandler | Default handler for close messages from the client: Throw an Exception |
| CDefaultClientMessageHandler | DDefault event handler for Client messages: Logging it |
| CDefaultContextActiveHandler | Default handler for ActiveContext: Close it |
| CDefaultContextClosureHandler | Default event handler for ClosedContext: Logging it |
| CDefaultContextFailureHandler | Default event handler used for FailedContext: It crashes the driver |
| CDefaultContextMessageHandler | Default event handler for ContextMessage: Logging it |
| CDefaultCustomTraceListener | |
| CDefaultDriverRestartCompletedHandler | The default driver restart completed handler |
| CDefaultDriverRestartContextActiveHandler | Default handler for ActiveContext received during driver restart: Close it |
| CDefaultDriverRestartHandler | Default event handler for driver restart: Logging it |
| CDefaultDriverRestartTaskRunningHandler | Default event handler for TaskRuntime received during driver restart: Logging it |
| CDefaultEvaluatorAllocationHandler | Default handler for AllocatedEvaluator: close it |
| CDefaultEvaluatorCompletionHandler | Default event handler for CompletedEvaluator: Logging it |
| CDefaultEvaluatorFailureHandler | Default event handler used for FailedEvaluator: It crashes the driver |
| CDefaultHttpHandler | |
| CDefaultTaskCompletionHandler | Default event handler for CompletedTask: Log it and close the context |
| CDefaultTaskFailureHandler | Default event handler used for FailedTask: It crashes the driver |
| CDefaultTaskMessageHandler | Default event handler for TaskMessage: Logging it |
| CDefaultTaskRunningHandler | Default event handler for TaskRuntime: Logging it |
| CDefaultTaskSuspensionHandler | Default event handler used for SuspendedTask: It crashes the driver |
| ►NEvaluator | |
| CEvaluatorDescriptorImpl | |
| CEvaluatorException | |
| CEvaluatorRequestBuilder | |
| CIAllocatedEvaluator | Represents an Evaluator that is allocated, but is not running yet |
| CICompletedEvaluator | Represents an Evaluator that has completed |
| CIEvaluatorDescriptor | Metadata about an Evaluator |
| CIEvaluatorRequest | A request for an Evaluator allocation |
| CIEvaluatorRequestor | Interface through which Evaluators can be requested |
| CIFailedEvaluator | Represents an Evaluator that became unavailable |
| ►NTask | |
| CICompletedTask | |
| CIFailedTask | |
| CIRunningTask | Represents a running Task |
| CISuspendedTask | Represents a suspended task |
| CITaskMessage | Driver-side representation of a message sent from a Task to the Driver |
| CJavaTaskException | A Task Exception from the Java side |
| CConstants | |
| CDriverConfigGenerator | |
| CDriverConfiguration | Fill this out to configure a Driver |
| CDriverConfigurationSettings | |
| CIDriver | empty driver interface to facilitate referencing driver dll |
| CIDriverRestartCompleted | Event fired on Driver restart completed |
| CIDriverRestarted | Event fired on Driver restarts instead of IDriverStarted |
| CIDriverStarted | Event fired when the Driver started |
| CIProgressProvider | Provides the progress of the job to the Resource Manager |
| ►NEvaluator | |
| CEvaluator | |
| ►NIMRU | |
| ►NAPI | |
| CIIMRUClient | |
| CIIMRUResultHandler | Interface defining how to handle the output of Update function in IMRU |
| CIMapFunction | Interface to be implemented by Map functions in IMRU |
| CIMRUCodecConfiguration | A configuration module for specifying codecs for IMRU |
| CIMRUJobDefinition | Describes an IMRU Job |
| CIMRUJobDefinitionBuilder | Use this class to create an IMRU Job Definition |
| CIMRUMapConfiguration | A configuration module for IMRU IMapFunction |
| CIMRUPerMapperConfigGeneratorConfiguration | A configuration module for per mapper configuration |
| CIMRUPipelineDataConverterConfiguration | A configuration module for The PipelineDataConverter used for chunking and dechunking TMapInput and TMapOutput |
| CIMRUReduceFunctionConfiguration | A configuration module for IMRU Reduce function |
| CIMRUUpdateConfiguration | A configuration module for IMRU Update function |
| CIPerMapperConfigGenerator | Class returning mapper specific configuration |
| CIUpdateFunction | The interface for the Update function of IMRU |
| CPerMapConfigGeneratorSet | |
| CUpdateResult | Represents the output of an IUpdateFunction |
| ►NInProcess | |
| ►NParameters | |
| CNumberOfMappers | The number of mappers to instantiate |
| CInProcessIMRUClient | Implements the IMRU client API for in-process execution |
| CInProcessIMRUConfiguration | Configuration module for the in-process IMRU |
| ►NOnREEF | |
| ►NClient | |
| CREEFIMRUClientConfiguration | A configuration module for specifying REEFIMRUClient |
| ►NDriver | |
| CIMRUSystemException | Type of exception thrown when possible bugs are detected in IMRU code |
| CMaximumNumberOfEvaluatorFailuresExceededException | Type of exception thrown when number of failed evaluators reach the maximum allowed limit |
| ►NResultHandler | |
| CResultOutputLocation | |
| CWriteResultHandler | Writes IMRU result from Update task to a file |
| ►NIO | |
| ►NFiles | |
| CDefaultDirectoryInfo | This is meant only as a proxy class for DirectoryInfo and has no relation to classes in Org.Apache.REEF.IO.FileSystem |
| CDefaultFileInfo | This is meant only as a proxy class for FileInfo and has no relation to classes in Org.Apache.REEF.IO.FileSystem |
| CFileSystemInfoFactory | A static factory class that creates an IFileSystemInfo object from a FileSystemInfo object |
| CIDirectoryInfo | This is meant only as a proxy interface for DirectoryInfo and has no relation to classes in Org.Apache.REEF.IO.FileSystem |
| CIFileInfo | This is meant only as a proxy interface for FileInfo and has no relation to classes in Org.Apache.REEF.IO.FileSystem |
| CIFileSystemInfo | This is meant only as a proxy interface for FileSystemInfo and has no relation to classes in Org.Apache.REEF.IO.FileSystem |
| ►NFileSystem | |
| ►NAzureBlob | |
| ►NParameters | |
| CAzureStorageConnectionString | |
| ►NRetryPolicy | |
| CIAzureBlobRetryPolicy | |
| CAzureBlockBlobFileSystemConfiguration | Configuration Module for the Azure Block Blob (WASB) file system implementation of IFileSystem |
| ►NHadoop | |
| CHadoopFileSystemConfiguration | Configuration Module for the (command based) Hadoop file system implementation of IFileSystem |
| CHDFSConfigurationWithoutDriverBinding | Configuration Module for the (command based) Hadoop file system implementation of IFileSystem |
| ►NLocal | |
| CLocalFileSystemConfiguration | ConfigurationModule for the local file system |
| CFileStatus | Represents metadata about a file |
| CIFileSystem | A file system abstraction |
| ►NPartitionedData | |
| ►NFileSystem | |
| CFileSystemInputPartitionConfiguration | This configuration module set FileSystemDataSet as IPartitionedDataSet |
| CIFileDeSerializer | A interface for user to implement its deserializer |
| ►NRandom | |
| CRandomInputDataConfiguration | Configuration module for the random dataset generator |
| CIInputPartition | Evaluator-Side representation of a data set partition |
| CIPartitionDescriptor | Driver-Side representation of a partition |
| CIPartitionedInputDataSet | Driver-Side representation of a partitioned data set |
| ►NTempFileCreation | |
| CITempFileCreator | Provide interface to wrap temp file folder and temp file folder creation |
| CTempFileConfigurationModule | Configuration Module for TempFileCreator |
| CTempFileFolder | Folder for local temp file |
| ►NTestClient | |
| CAssert | |
| CAssertFailedException | |
| CHadoopFileSystemTest | |
| CRun | This purpose of this test is to run tests in Yarn environment |
| ►NNetwork | |
| ►NGroup | |
| ►NConfig | |
| CCodecConfiguration | |
| CCodecToStreamingCodecConfiguration | |
| ►CGroupCommConfigurationOptions | |
| CCommunicationGroupName | |
| CDriverId | |
| CFanOut | |
| CGroupName | |
| CInitialize | |
| CMasterTaskId | |
| CMessageType | |
| CNumberOfTasks | |
| COperatorName | |
| CSerializedGroupConfigs | |
| CSerializedOperatorConfigs | |
| CTimeout | |
| CTopologyChildTaskIds | |
| CTopologyRootTaskId | |
| CPipelineDataConverterConfiguration | |
| CReduceFunctionConfiguration | |
| CStreamingCodecConfiguration | Defines configuration for streaming codecs and pipeline message streaming codecs by taking streaming codec as input |
| CStreamingCodecConfigurationMinusMessage | Defines configuration for internal streaming codecs and internal pipeline message streaming codecs required for group communication |
| ►NDriver | |
| ►NImpl | |
| CGeneralGroupCommunicationMessage | Messages sent by MPI Operators |
| CGroupCommDriver | Used to create Communication Groups for Group Communication Operators on the Reef driver |
| CTaskStarter | Helper class to start Group Communication tasks |
| CICommunicationGroupDriver | Used to configure Group Communication operators in Reef driver |
| CIGroupCommDriver | Used to create Communication Groups for Group Communication Operators |
| ►NOperators | |
| ►NImpl | |
| CBroadcastOperatorSpec | The specification used to define Broadcast Operators |
| CBroadcastReceiver | Group Communication Operator used to receive broadcast messages in pipelined fashion |
| CBroadcastSender | Group Communication Operator used to send messages to child Tasks in pipelined fashion |
| CPipelinedReduceFunction | The class used to aggregate pipelined messages sent by ReduceSenders |
| CReduceFunction | |
| CReduceOperatorSpec | The specification used to define Reduce Group Communication Operators |
| CReduceReceiver | Group Communication operator used to receive and reduce messages in pipelined fashion |
| CReduceSender | Group Communication Operator used to send messages to be reduced by the ReduceReceiver in pipelined fashion |
| CScatterOperatorSpec | The specification used to define Scatter Group Communication Operators |
| CScatterReceiver | Group Communication operator used to receive a sublist of messages sent from the IScatterSender |
| CScatterSender | Group Communication operator used to scatter a list of elements to all of the IScatterReceivers |
| CIBroadcastReceiver | Group Communication Operator used to receive broadcast messages |
| CIBroadcastSender | Group Communication Operator used to send messages to child Tasks |
| CIGroupCommOperator | An Group Communication Operator to be used in a Reef Task |
| CIOperatorSpec | The specification used to define Broadcast Operators |
| CIReduceFunction | The class used to aggregate messages sent by ReduceSenders |
| CIReduceReceiver | Group Communication operator used to receive and reduce messages |
| CIReduceSender | Group Communication Operator used to send messages to be reduced by the ReduceReceiver |
| CIScatterReceiver | Group Communication operator used to receive a sublist of messages sent from the IScatterSender |
| CIScatterSender | Group Communication operator used to scatter a list of elements to all of the IScatterReceivers |
| ►NPipelining | |
| ►NImpl | |
| CDefaultPipelineDataConverter | Default IPipelineDataConverter implementation This basically is a non-pipelined implementation that just packs the whole message in one single PipelineMessage |
| CIPipelineDataConverter | User specified class to convert the message to be communicated in to pipelining amenable data and vice-versa |
| CPipelineMessage | the message for pipelined communication |
| CPipelineMessageCodec | The codec for PipelineMessage |
| CStreamingPipelineMessageCodec | The streaming codec for PipelineMessage |
| ►NTask | |
| ►NImpl | |
| CGroupCommClient | Used by Tasks to fetch CommunicationGroupClients |
| COperatorTopology | Contains the Operator's topology graph |
| CICommunicationGroupClient | Used by Tasks to fetch Group Communication Operators in the group configured by the driver |
| CIGroupCommClient | Used by Tasks to fetch CommunicationGroupClients |
| CIOperatorTopology | Contains the Operator's topology graph |
| ►NTopology | |
| CITopology | Represents a topology graph for IGroupCommOperators |
| ►NNaming | |
| ►NContracts | |
| CAvroNamingAssignment | Used to serialize and deserialize Avro record Org.Apache.REEF.Network.Naming.Contracts.AvroNamingAssignment |
| CAvroNamingLookupRequest | Used to serialize and deserialize Avro record Org.Apache.REEF.Network.Naming.Contracts.AvroNamingLookupRequest |
| CAvroNamingLookupResponse | Used to serialize and deserialize Avro record Org.Apache.REEF.Network.Naming.Contracts.AvroNamingLookupResponse |
| CAvroNamingRegisterRequest | Used to serialize and deserialize Avro record Org.Apache.REEF.Network.Naming.Contracts.AvroNamingRegisterRequest |
| CAvroNamingUnRegisterRequest | Used to serialize and deserialize Avro record Org.Apache.REEF.Network.Naming.Contracts.AvroNamingUnRegisterRequest |
| ►NParameters | |
| ►CNameCacheConfiguration | |
| CCacheEntryExpiryTime | |
| CCacheMemoryLimit | |
| CPollingInterval | |
| CINameServer | Service that manages names and IPEndpoints for well known hosts |
| CNameClient | Client for the Reef name service |
| ►CNameServer | Service that manages names and IPEndpoints for well known hosts |
| CPort | |
| ►NNetworkService | |
| ►NCodec | |
| CControlMessageCodec | |
| CNsMessageCodec | Codec to serialize NsMessages for NetworkService |
| CNsMessageProto | |
| CIConnection | Represents a connection between two endpoints named by identifiers |
| CINetworkService | Network service used for Reef Task communication |
| CNetworkService | Network service used for Reef Task communication |
| ►CNetworkServiceOptions | |
| CNetworkServicePort | |
| CNsConnection | Represents a connection between two hosts using the NetworkService |
| CNsMessage | Message sent between NetworkServices |
| CStreamingNetworkService | Writable Network service used for Reef Task communication |
| ►NUtilities | |
| CBlockingCollectionExtensions | |
| CTcpClientConfigurationModule | Configuration Module for the TCP Client provider |
| CTcpClientConfigurationProvider | Configuration provider for TcpClient connection |
| ►NTang | |
| ►NAnnotations | |
| CDefaultImplementationAttribute | DefaultImplementationAttribute |
| CInjectAttribute | InjectAttribute |
| CName | Base class for named parameters |
| CNamedParameterAttribute | |
| CParameterAttribute | ParameterAttribute |
| CUnitAttribute | UnitAttribute |
| ►NExceptions | |
| CBindException | |
| CClassHierarchyException | |
| CIllegalStateException | |
| CInjectionException | |
| CNameResolutionException | |
| CParseException | |
| ►NFormats | |
| ►NAvroConfigurationDataContract | |
| CAvroConfiguration | |
| CConfigurationEntry | |
| CAvroConfigurationResolver | |
| CAvroConfigurationSerializer | |
| CConfigurationFile | |
| CConfigurationModule | Allows applications to bundle sets of configuration options together into discrete packages |
| CConfigurationModuleBuilder | |
| CIConfigurationSerializer | |
| CIImpl | |
| CIParam | |
| COptionalImpl | |
| COptionalParameter | |
| CProvides | |
| CRequiredImpl | |
| CRequiredParameter | |
| ►NImplementations | |
| ►NClassHierarchy | |
| ►NAvroDataContract | |
| CAvroClassNode | Used to serialize and deserialize Avro record org.apache.reef.tang.implementation.avro.AvroClassNode |
| CAvroConstructorArg | Used to serialize and deserialize Avro record org.apache.reef.tang.implementation.avro.AvroConstructorArg |
| CAvroConstructorDef | Used to serialize and deserialize Avro record org.apache.reef.tang.implementation.avro.AvroConstructorDef |
| CAvroNamedParameterNode | Used to serialize and deserialize Avro record org.apache.reef.tang.implementation.avro.AvroNamedParameterNode |
| CAvroNode | Used to serialize and deserialize Avro record org.apache.reef.tang.implementation.avro.AvroNode |
| CAvroPackageNode | Used to serialize and deserialize Avro record org.apache.reef.tang.implementation.avro.AvroPackageNode |
| ►NConfiguration | |
| CConfigurations | |
| ►NInjectionPlan | |
| CIInjectionFuture | |
| CInjectionFutureImpl | |
| CInjectionPlan | |
| ►NTang | |
| CTangFactory | |
| ►NInterface | |
| CAspect | |
| CIClassHierarchy | |
| CIClassHierarchySerializer | |
| CIConfiguration | |
| CIConfigurationBuilder | |
| CIConfigurationProvider | Provides configurations |
| CICsClassHierarchy | |
| CICsConfigurationBuilder | |
| CIExternalConstructor | |
| CIInjector | |
| CITang | |
| ►NProtobuf | |
| CClassNode | |
| CConstructor | |
| CConstructorArg | |
| CConstructorDef | |
| CInjectionPlan | |
| CInstance | |
| CNamedParameterNode | |
| CNode | |
| CPackageNode | |
| CProtocolBufferClassHierarchy | |
| CSubplan | |
| ►NTools | |
| CClassHierarchyBuilder | |
| ►NTypes | |
| CIClassNode | |
| CIConstructorArg | |
| CIConstructorDef | |
| CINamedParameterNode | |
| CINode | |
| CIPackageNode | |
| CITraversable | |
| ►NUtil | |
| CAbstractMonotonicMultiMap | |
| CAssemblyLoader | |
| CGenericType | |
| CMonotonicHashMap | |
| CMonotonicHashSet | |
| CMonotonicMultiHashMap | |
| CMonotonicMultiMap | |
| CMonotonicSet | |
| CMonotonicTreeMap | |
| CReflectionUtilities | |
| ►NUtilities | |
| ►NAsyncUtils | |
| CLoggingHelper | Logging helpers for TPL |
| CRemoveSynchronizationContextAwaiter | This is to avoid deadlocks in clients that use synchronization context (WinForms/ASP.NET) Use at asynchronous entry points of all async REEF client APIs |
| CVoidResult | A type used to indicate that no meaningful value is returned |
| ►NAttributes | |
| CClientSideAttribute | Attribute target should be used by REEF Clients |
| CDriverSideAttribute | Attribute target should be used at the Job Driver |
| CEvaluatorSideAttribute | Attribute target should be used by Evaluators |
| CInteropAttribute | Attribute target is used at the Interop layer |
| CNotThreadSafeAttribute | Indicates that the attribute target is not thread safe |
| CPrivateAttribute | Attribute target should not be used by users, and may change at any time without a deprecation phase |
| CTaskSideAttribute | Attribute target should be used by Tasks |
| CTestingAttribute | Attribute target should only be used in tests |
| CThreadSafeAttribute | Indicates that the attribute target is thread safe |
| CUnstableAttribute | Signals that the API is NOT stabilized |
| ►NCollections | |
| CPriorityQueue | A simple priority queue implementation, where the head of the queue is the smallest element in the priority queue |
| CReadOnlySet | An implementation of a set that is read only |
| ►NDiagnostics | |
| CExceptions | |
| ►NLogging | |
| CLogger | |
| CAvroUtils | |
| CByteUtilities | |
| CIIdentifiable | Denotes an object that has a string identifier |
| CIMessage | A message from a REEF component |
| CNetUtilities | |
| COptional | A convenience class that indicates whether a variable is set or not |
| CValidationUtilities | |
| ►NWake | |
| ►NExamples | |
| ►NP2p | |
| CIEventSource | The pull side of the interface: Clients implement this and register it with the PullToPush class |
| CPull2Push | Performs a Pull-to-Push conversion in Wake |
| ►NImpl | |
| CLoggingEventHandler | A logging event handler |
| CMissingStartHandlerHandler | |
| CMultiEventHandler | Event handler that dispatches an event to a specific handler based on an event class type |
| CPeriodicEvent | Periodic event for timers |
| CPubSubEventHandler | Event handler to provide publish/subscribe interfaces |
| CSingleThreadStage | Single thread stage that runs the event handler |
| CSyncStage | Stage that synchronously executes an event handler |
| CThreadPoolStage | Stage that executes an event handler with a thread pool |
| CTimerStage | Stage that triggers an event handler periodically |
| ►NRemote | |
| ►NImpl | |
| CByteCodec | |
| CChannel | Performs low level network IO operations between hosts |
| CDefaultLocalAddressProvider | The local address provider that provides the local IP address using NetworkUtils.LocalIPAddress |
| CDefaultRemoteManager | Manages incoming and outgoing messages between remote hosts |
| CIntCodec | |
| CLink | Represents an open connection between remote hosts |
| CLoopbackLocalAddressProvider | Provides the loopback address as the local address |
| CMultiCodec | Codec that can encode and decode a class depending on the class type |
| CMultiDecoder | Decoder using the WakeTuple protocol buffer (class name and bytes) |
| CMultiEncoder | Encoder using the WakeTuple protocol buffer (class name and bytes) |
| CRemoteEvent | |
| CRemoteEventDecoder | |
| CRemoteEventEncoder | |
| CRemoteEventEndPoint | |
| CSocketRemoteIdentifier | Remote identifier based on a socket address |
| CStreamDataReader | Class with functions to Read from stream |
| CStreamDataWriter | |
| CStreamingRemoteManagerFactory | StreamingRemoteManagerFactory for StreamingRemoteManager |
| CStringCodec | |
| CStringIdentifier | |
| CStringIdentifierFactory | |
| CTcpClientConnectionException | Exception class for the case when Tcp Client connection fails after trying for some finite number of times |
| CTcpClientConnectionFactory | Default implementation of ITcpClientFactory |
| CTransportClient | Establish connections to TransportServer for remote message passing |
| CTransportEvent | |
| CTransportServer | Server to handle incoming remote messages |
| ►NParameters | |
| CConnectionRetryCount | |
| CSleepTimeInMs | |
| CTcpPortRangeCount | |
| CTcpPortRangeSeed | |
| CTcpPortRangeStart | |
| CTcpPortRangeTryCount | |
| ►NProto | |
| CWakeMessagePBuf | Message p buff |
| CWakeTuplePBuf | Wake tuple buf |
| CICodec | Interface for serialization routines that translate back and forth between byte arrays with low latency |
| CIConnectionRetryHandler | Interface for the retry logic to connect to remote endpoint |
| CIDataReader | Interface for reading standard primitives |
| CIDataWriter | Interface for writing standard primitives |
| CIDecoder | Interface for serialization routines that translate back and forth between byte arrays with low latency |
| CIEncoder | Interface for serialization routines that translate back and forth between byte arrays with low latency |
| CILink | Represents a link between two endpoints |
| CILocalAddressProvider | Provides the local address |
| CIRemoteEvent | |
| CIRemoteIdentifier | An identifier that represents a remote source |
| CIRemoteIdentifierFactory | Factory that creates a RemoteIdentifier |
| CIRemoteManager | |
| CIRemoteManagerFactory | Creates new instances of IRemoteManager |
| CIRemoteMessage | Message received from a remote handler |
| CIRemoteObserver | A disposable remote observer observer, that is not managed by the manager that creates it |
| CISubscriptionManager | |
| CITcpClientConnectionFactory | Provides TcpClient for the remote endpoint |
| CITcpPortProvider | Provides port numbers for tcp listeners |
| ►CRemoteConfiguration | |
| CErrorHandler | |
| CHostAddress | |
| CManagerName | |
| CMessageCodec | |
| COrderingGuarantee | |
| CPort | |
| CRemoteRuntimeException | Wake remote runtime exception |
| CTcpPortProvider | |
| ►NRX | |
| ►NImpl | |
| CPubSubSubject | Subject to provide publish/subscribe interface |
| CRxSyncStage | Stage that executes the observer synchronously |
| CRxThreadPoolStage | Stage that executes the observer with a thread pool |
| CRxTimerStage | Timer stage that provides events to the observer periodically |
| CSimpleSubject | A Subject that relays all messages to its subscribers. |
| CAbstractObserver | An observer with logging-only onError and onCompleted() methods |
| CAbstractRxStage | An Rx stage that implements metering |
| CIRxStage | Stage that executes the observer |
| CIStaticObservable | |
| CISubject | A class implementing Observer> and StaticObservable |
| CObserverCompletedException | It is illegal to call onError() or onCompleted() when a call to onNext() is still outstanding, or to call onNext(), onError() or onCompleted() after a call to onError() or onCompleted() has been dispatched |
| ►NStreamingCodec | |
| ►NCommonStreamingCodecs | |
| CDoubleArrayStreamingCodec | Streaming codec for double array |
| CDoubleStreamingCodec | Streaming codec for double |
| CFloatArrayStreamingCodec | Streaming codec for float array |
| CFloatStreamingCodec | Streaming codec for float |
| CIntArrayStreamingCodec | Streaming codec for integer array |
| CIntStreamingCodec | Streaming codec for integer |
| CStringStreamingCodec | Streaming codec for string |
| CCodecToStreamingCodec | Converts codec to streaming codec |
| CIStreamingCodec | Codec Interface that external users should implement to directly write to the stream |
| ►NTime | |
| ►NEvent | |
| CAlarm | Represents a timer event |
| CStartTime | Represents the Time at which a component started |
| CStopTime | Represents the Time at which a component stops |
| ►NParameters | |
| CIdleHandler | Bind this to an event handler to statically subscribe to the IdleClock Event |
| CRuntimeStartHandler | Bind this to an event handler to statically subscribe to the RuntimeStart Event |
| CRuntimeStopHandler | Bind this to an event handler to statically subscribe to the RuntimeStop Event |
| CStartHandler | Bind this to an event handler to statically subscribe to the StartTime Event |
| CStopHandler | Bind this to an event handler to statically subscribe to the StopTime Event |
| ►NRuntime | |
| ►NEvent | |
| CClientAlarm | |
| CIdleClock | |
| CRuntimeAlarm | |
| CRuntimeStart | |
| CRuntimeStop | |
| CITimer | |
| CLogicalTimer | LogicalTimer class used for testing purposes |
| CRealTimer | |
| CRuntimeClock | |
| ►CIClock | |
| CIdleHandler | Bind this to an event handler to statically subscribe to the IdleClock Event |
| CRuntimeStartHandler | Bind this to an event handler to statically subscribe to the RuntimeStart Event |
| CRuntimeStopHandler | Bind this to an event handler to statically subscribe to the RuntimeStop Event |
| CStartHandler | Bind this to an event handler to statically subscribe to the StartTime Event |
| CStopHandler | Bind this to an event handler to statically subscribe to the StopTime Event |
| CTime | Time object |
| ►NUtil | |
| CActionable | |
| CFixedThreadPoolTaskService | |
| CIStartable | |
| CITaskService | |
| CNetworkUtils | |
| CSerializationHelper | |
| CTaskExtensions | |
| CTimeHelper | |
| CAbstractEStage | An estage that implements metering |
| CIEStage | Stage that executes an event handler |
| CIEventHandler | Handler to process an event |
| CIIdentifier | Identifier class for REEF |
| CIIdentifierFactory | |
| CIObserverFactory | |
| CIStage | Stage is an execution unit for events and provides a way to reclaim its resources |
| CWakeRuntimeException | Wake runtime exception |
1.8.11