This project has retired. For details please refer to its Attic page.
Index (REEF 0.16.0 API)
A B C D E F G H I J K L M N O P Q R S T U V W Y 

A

A - Class in org.apache.reef.tang.examples
 
A() - Constructor for class org.apache.reef.tang.examples.A
 
abort(CheckpointService.CheckpointWriteChannel) - Method in interface org.apache.reef.io.checkpoint.CheckpointService
Aborts the current checkpoint.
abort(CheckpointService.CheckpointWriteChannel) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointService
 
AbstractClassHierarchyNodeVisitor - Class in org.apache.reef.tang.util.walk
Generic interface to traverse nodes of the class hierarchy.
AbstractClassHierarchyNodeVisitor() - Constructor for class org.apache.reef.tang.util.walk.AbstractClassHierarchyNodeVisitor
 
AbstractEStage<T> - Class in org.apache.reef.wake
An EStage that implements metering.
AbstractEStage(String) - Constructor for class org.apache.reef.wake.AbstractEStage
Constructs an abstract estage.
AbstractEvaluatorToPartitionStrategy - Class in org.apache.reef.io.data.loading.impl
This is an abstract class useful for EvaluatorToPartitionStrategy implementations.
AbstractFailure - Class in org.apache.reef.common
Common data and functionality for all error messages in REEF.
AbstractGroupCommOperator - Class in org.apache.reef.io.network.group.api.operators
 
AbstractGroupCommOperator() - Constructor for class org.apache.reef.io.network.group.api.operators.AbstractGroupCommOperator
 
AbstractInjectionPlanNodeVisitor - Class in org.apache.reef.tang.util.walk
Generic interface to traverse nodes of the injection plan.
AbstractInjectionPlanNodeVisitor() - Constructor for class org.apache.reef.tang.util.walk.AbstractInjectionPlanNodeVisitor
 
AbstractMonotonicMultiMap<K,V> - Class in org.apache.reef.tang.util
 
AbstractMonotonicMultiMap(Map<K, Set<V>>) - Constructor for class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
AbstractNode - Class in org.apache.reef.tang.implementation.types
 
AbstractNode(Node, String, String) - Constructor for class org.apache.reef.tang.implementation.types.AbstractNode
 
AbstractObserver<T> - Class in org.apache.reef.wake.rx
An Observer with logging-only onError and onCompleted() methods.
AbstractObserver() - Constructor for class org.apache.reef.wake.rx.AbstractObserver
 
AbstractRxStage<T> - Class in org.apache.reef.wake.rx
An RxStage that implements metering.
AbstractRxStage(String) - Constructor for class org.apache.reef.wake.rx.AbstractRxStage
Constructs an abstact rxstage.
AbstractVector - Class in org.apache.reef.examples.group.utils.math
Abstract base class for Vector implementations.
AbstractVector() - Constructor for class org.apache.reef.examples.group.utils.math.AbstractVector
 
Accumulable<T> - Interface in org.apache.reef.io
Similar to Iterable, this is an interface for objects that can return Accumulators.
accumulator() - Method in interface org.apache.reef.io.Accumulable
Returns a new Accumulator.
Accumulator<T> - Interface in org.apache.reef.io
A basic Accumulator interface.
accumulator() - Method in interface org.apache.reef.io.Spool
Returns an Accumulator for the spool file.
accumulator() - Method in class org.apache.reef.io.storage.FramingOutputStream
 
accumulator() - Method in class org.apache.reef.io.storage.local.CodecFileAccumulable
 
accumulator() - Method in class org.apache.reef.io.storage.local.SerializerFileSpool
 
accumulator() - Method in class org.apache.reef.io.storage.ram.RamSpool
 
accumulator() - Method in class org.apache.reef.io.storage.ram.SortingRamSpool
 
Acknowledgement - Class in org.apache.reef.bridge.message
 
Acknowledgement() - Constructor for class org.apache.reef.bridge.message.Acknowledgement
Default constructor.
Acknowledgement(Long) - Constructor for class org.apache.reef.bridge.message.Acknowledgement
All-args constructor.
Acknowledgement.Builder - Class in org.apache.reef.bridge.message
RecordBuilder for Acknowledgement instances.
ACLS_MODIFY_APP - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
ACLS_VIEW_APP - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
ACTIVE_CONTEXT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
ActiveContext - Interface in org.apache.reef.driver.context
Represents an active context on an Evaluator.
activeContext - Variable in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Deprecated.
activeContext - Variable in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Deprecated.
activeContext - Variable in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Deprecated.
activeContext - Variable in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Deprecated.
ActiveContextBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for ActiveContext.
ActiveContextBridgeFactory - Class in org.apache.reef.javabridge
Factory for ActiveContextBridge instances.
activeContextReceived(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling activeContext handler.
add(Vector) - Method in class org.apache.reef.examples.group.utils.math.AbstractVector
 
add(Vector) - Method in interface org.apache.reef.examples.group.utils.math.Vector
Adds the Vector that to this one in place: this += that.
add(double) - Method in class org.apache.reef.examples.group.utils.math.Window
 
add(T) - Method in interface org.apache.reef.io.Accumulator
Add the given datum to this.
add(K, V) - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
add(L) - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
add(K, V) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
add(Map.Entry<K, V>) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
add(T) - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
add(T) - Method in class org.apache.reef.tang.util.MonotonicSet
 
add(File) - Method in class org.apache.reef.util.JARFileMaker
Adds a file to the JAR.
ADD_CONTEXT_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
addAll(Collection<? extends Map.Entry<K, V>>) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
addAll(Collection<? extends T>) - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
addAll(Collection<? extends T>) - Method in class org.apache.reef.tang.util.MonotonicSet
 
addAllArgs(Iterable<? extends ClassHierarchyProto.ConstructorArg>) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addAllArgs(Iterable<? extends InjectionPlanProto.InjectionPlan>) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addAllChildren(Iterable<? extends ClassHierarchyProto.Node>) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addAllContextMessage(Iterable<? extends ReefServiceProtos.ContextStatusProto.ContextMessageProto>) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addAllContextStatus(Iterable<? extends ReefServiceProtos.ContextStatusProto>) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addAllIgnoreDuplicates(Collection<? extends T>) - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
addAllIgnoreDuplicates(Collection<? extends T>) - Method in class org.apache.reef.tang.util.MonotonicSet
 
addAllImplFullNames(Iterable<String>) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
addAllInjectableConstructors(Iterable<? extends ClassHierarchyProto.ConstructorDef>) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addAllInstanceDefault(Iterable<String>) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
addAllMsgs(Iterable<? extends ReefNetworkGroupCommProtos.GroupMessageBody>) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addAllMsgs(Iterable<? extends ReefNetworkServiceProtos.NSRecordPBuf>) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addAllOtherConstructors(Iterable<? extends ClassHierarchyProto.ConstructorDef>) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addAllPlans(Iterable<? extends InjectionPlanProto.InjectionPlan>) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addAllTaskMessage(Iterable<? extends ReefServiceProtos.TaskStatusProto.TaskMessageProto>) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addApplicationAcl(String, String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
addApplicationTag(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
addArgs(ClassHierarchyProto.ConstructorArg) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addArgs(int, ClassHierarchyProto.ConstructorArg) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addArgs(ClassHierarchyProto.ConstructorArg.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addArgs(int, ClassHierarchyProto.ConstructorArg.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addArgs(InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addArgs(int, InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addArgs(InjectionPlanProto.InjectionPlan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addArgs(int, InjectionPlanProto.InjectionPlan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addArgsBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addArgsBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
addArgsBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addArgsBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
addAsData(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
addAsData(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
addBroadcast(Class<? extends Name<String>>, BroadcastOperatorSpec) - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
Add the broadcast operator specified by the.
addBroadcast(Class<? extends Name<String>>, BroadcastOperatorSpec) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
addChild(TaskNode) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
addChild(TaskNode) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
addChild(TopologySimpleNode) - Method in class org.apache.reef.io.network.group.impl.driver.TopologySimpleNode
 
addChildren(ClassHierarchyProto.Node) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addChildren(int, ClassHierarchyProto.Node) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addChildren(ClassHierarchyProto.Node.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addChildren(int, ClassHierarchyProto.Node.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addChildren(File) - Method in class org.apache.reef.util.JARFileMaker
 
addChildrenBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addChildrenBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
addCLRFiles(File) - Method in class org.apache.reef.javabridge.generic.JobClient
 
addCommandLineOption(Option, CommandLine.CommandLineCallback) - Method in class org.apache.reef.tang.formats.CommandLine
 
addComputeRequest(EvaluatorRequest) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
Adds a single request to the compute requests list.
addComputeRequests(List<EvaluatorRequest>) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
Adds the requests to the compute requests list.
addConfiguration(Configuration) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Add all configuration parameters from the given Configuration object.
addConfiguration(Configuration) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
addContainerAllocation(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
Add an entry to containerAllocationList.
addContextMessage(ReefServiceProtos.ContextStatusProto.ContextMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addContextMessage(int, ReefServiceProtos.ContextStatusProto.ContextMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addContextMessage(ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addContextMessage(int, ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addContextMessageBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addContextMessageBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
addContextStatus(ReefServiceProtos.ContextStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addContextStatus(int, ReefServiceProtos.ContextStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addContextStatus(ReefServiceProtos.ContextStatusProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addContextStatus(int, ReefServiceProtos.ContextStatusProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addContextStatusBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addContextStatusBuilder(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
addData(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.task.NodeStruct
 
addData(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
addDataRequest(EvaluatorRequest) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
Adds a single request to the data requests list.
addDataRequests(List<EvaluatorRequest>) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
Adds the requests to the data requests list.
addEnvironment(String, String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
addEventHandler(EventHandler<E>) - Method in class org.apache.reef.runtime.common.utils.BroadCastEventHandler
 
addFile(File) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
Puts the given file into the working directory of the Evaluator.
addFile(FileResource) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
Add an entry to the fileSet.
addFile(File) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
addFiles(Iterable<File>) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
Utility method that adds files to the fileSet.
addGather(Class<? extends Name<String>>, GatherOperatorSpec) - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
Add the gather operator specified by operatorName and spec.
addGather(Class<? extends Name<String>>, GatherOperatorSpec) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
addGlobalFile(FileResource) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
Add an entry to the globalFileSet.
addGlobalFiles(File) - Method in interface org.apache.reef.runtime.local.driver.Container
 
addGlobalFiles(File) - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
addGradient(Vector, double) - Method in interface org.apache.reef.examples.group.bgd.data.Example
Adds the current example's gradient to the gradientVector, assuming that the gradient with respect to the prediction is gradient.
addGradient(Vector, double) - Method in class org.apache.reef.examples.group.bgd.data.SparseExample
 
addHandler(Class<? extends Name<String>>, SingleThreadStage<GroupCommunicationMessage>) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommMessageHandler
 
addHandler(EventHandler<T>) - Method in class org.apache.reef.io.network.group.impl.utils.BroadcastingEventHandler
 
addHttpHandler(HttpHandler) - Method in interface org.apache.reef.webserver.HttpServer
Add a httpHandler to the server.
addHttpHandler(HttpHandler) - Method in class org.apache.reef.webserver.HttpServerImpl
Add a HttpHandler to Jetty Handler.
addHttpHandler(HttpHandler) - Method in class org.apache.reef.webserver.NoOpHttpServerImpl
 
addImplFullNames(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
addImplFullNamesBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
addInjectableConstructors(ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addInjectableConstructors(int, ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addInjectableConstructors(ClassHierarchyProto.ConstructorDef.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addInjectableConstructors(int, ClassHierarchyProto.ConstructorDef.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addInjectableConstructorsBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addInjectableConstructorsBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
addInstanceDefault(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
addInstanceDefaultBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
AdditionAggregateFunction - Class in org.apache.reef.vortex.examples.sumones
Aggregates and sums the outputs.
AdditionAggregateFunction() - Constructor for class org.apache.reef.vortex.examples.sumones.AdditionAggregateFunction
 
addLibraries(Iterable<File>) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
Utility method that adds Libraries to the fileSet.
addLibrary(File) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
Puts the given file into the working directory of the Evaluator and adds it to its classpath.
addLibrary(File) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
addLocalFile(FileResource) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
Add an entry to the localFileSet.
addLocalFiles(Iterable<File>) - Method in interface org.apache.reef.runtime.local.driver.Container
Copies the files to the working directory of the container.
addLocalFiles(Iterable<File>) - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
addLocalResource(String, LocalResource) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
addLocalResource(String, LocalResource) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Add a file to be localized on the driver.
addMsgs(ReefNetworkGroupCommProtos.GroupMessageBody) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addMsgs(int, ReefNetworkGroupCommProtos.GroupMessageBody) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addMsgs(ReefNetworkGroupCommProtos.GroupMessageBody.Builder) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addMsgs(int, ReefNetworkGroupCommProtos.GroupMessageBody.Builder) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addMsgs(ReefNetworkServiceProtos.NSRecordPBuf) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addMsgs(int, ReefNetworkServiceProtos.NSRecordPBuf) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addMsgs(ReefNetworkServiceProtos.NSRecordPBuf.Builder) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addMsgs(int, ReefNetworkServiceProtos.NSRecordPBuf.Builder) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addMsgsBuilder() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addMsgsBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
addMsgsBuilder() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addMsgsBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
addNodeName(String) - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Adds a node name.It is the preferred location where the evaluator should run on.
addNodeName(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
Add an entry to the nodeNameList.
addNodeNames(List<String>) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
Add a list of node names.
addOption(String) - Method in class org.apache.reef.driver.evaluator.JVMProcess
Add a JVM option.
addOption(String) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
Add a JVM option.
addOtherConstructors(ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addOtherConstructors(int, ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addOtherConstructors(ClassHierarchyProto.ConstructorDef.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addOtherConstructors(int, ClassHierarchyProto.ConstructorDef.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addOtherConstructorsBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addOtherConstructorsBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
addParser(Class<? extends ExternalConstructor<?>>) - Method in class org.apache.reef.tang.formats.ParameterParser
 
addParser(Class<U>, Class<? extends ExternalConstructor<T>>) - Method in class org.apache.reef.tang.formats.ParameterParser
 
addPartition(DistributedDataSetPartition) - Method in class org.apache.reef.io.data.loading.api.DistributedDataSet
Adds the given partition to the set.
addPartitions(Collection<DistributedDataSetPartition>) - Method in class org.apache.reef.io.data.loading.api.DistributedDataSet
Adds the given partitions to the set.
addPlans(InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addPlans(int, InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addPlans(InjectionPlanProto.InjectionPlan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addPlans(int, InjectionPlanProto.InjectionPlan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addPlansBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addPlansBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
addRackName(String) - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Adds a rack name.
addRackName(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
Add a list of rack names.
addRackNames(List<String>) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
Add an entry to rackNameList.
addReduce(Class<? extends Name<String>>, ReduceOperatorSpec) - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
Add the reduce operator specified by the.
addReduce(Class<? extends Name<String>>, ReduceOperatorSpec) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
addRestartEvaluator(EvaluatorRestartInfo) - Method in class org.apache.reef.driver.restart.RestartEvaluators.Builder
 
addRuntime(String) - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeConfigurationBuilder
Adds runtime name to the builder.
addRuntime(Configuration, String) - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeDefinitionBuilder
Adds runtime configuration module to the builder.
addScatter(Class<? extends Name<String>>, ScatterOperatorSpec) - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
Add the scatter operator specified by operatorName and spec.
addScatter(Class<? extends Name<String>>, ScatterOperatorSpec) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
addSecret(String, String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
addServiceData(String, String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
addTask(Configuration) - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
Add the task represented by this configuration to this communication group.
addTask(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Add task with id 'taskId' to.
addTask(Configuration) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
addTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
addTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
addTaskMessage(ReefServiceProtos.TaskStatusProto.TaskMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addTaskMessage(int, ReefServiceProtos.TaskStatusProto.TaskMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addTaskMessage(ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addTaskMessage(int, ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addTaskMessageBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addTaskMessageBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
addToken(String, String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
addTokens(byte[]) - Method in interface org.apache.reef.runtime.yarn.client.SecurityTokenProvider
Add serialized tokens to the credentials.
addTokens(byte[]) - Method in class org.apache.reef.runtime.yarn.client.UserCredentialSecurityTokenProvider
Add serialized token to teh credentials.
addTopologyElement(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommGroupNetworkHandler
 
addTopologyElement(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommGroupNetworkHandlerImpl
 
AggregateResult<TInput,TOutput> - Class in org.apache.reef.vortex.api
The result of an aggregate.
AggregateResultSynchronous<TInput,TOutput> - Class in org.apache.reef.vortex.api
The synchronous result of an aggregate, returned by VortexAggregateFuture.get().
aggregationCompleted(List<Integer>, TOutput) - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
Aggregation has completed for a list of Tasklets, with an aggregated result.
aggregationCompleted(List<Integer>, TOutput) - Method in class org.apache.reef.vortex.api.VortexFuture
VortexMaster should never call this.
aggregationCompleted(List<Integer>, TOutput) - Method in interface org.apache.reef.vortex.driver.VortexFutureDelegate
The list of aggregated Tasklets associated with the Future that have completed with a result.
aggregationThrewException(List<Integer>, Exception) - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
A list of Tasklets has failed during aggregation phase.
aggregationThrewException(List<Integer>, Exception) - Method in class org.apache.reef.vortex.api.VortexFuture
VortexMaster should never call this.
aggregationThrewException(List<Integer>, Exception) - Method in interface org.apache.reef.vortex.driver.VortexFutureDelegate
The list of Tasklets associated with the Future that have thrown an Exception.
Alarm - Class in org.apache.reef.wake.time.event
An alarm is a timer event to be invoked at a given time.
Alarm(long, EventHandler<Alarm>) - Constructor for class org.apache.reef.wake.time.event.Alarm
 
ALIAS_LANGUAGE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
ALIAS_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
AllCommunicationGroup - Class in org.apache.reef.examples.group.bgd.parameters
Communication group name.
AllCommunicationGroup() - Constructor for class org.apache.reef.examples.group.bgd.parameters.AllCommunicationGroup
 
AllCommunicationGroup - Class in org.apache.reef.examples.group.broadcast.parameters
Communication group name.
AllCommunicationGroup() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.AllCommunicationGroup
 
allEvaluatorsAreClosed() - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
Return true if all evaluators are in closed state (and their processing queues are empty).
AllGather<T> - Interface in org.apache.reef.io.network.group.api.operators
MPI AllGather Operator.
AllGather_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
AllGather = 5;
ALLOCATED_MB - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
ALLOCATED_VCORES - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
AllocatedEvaluator - Interface in org.apache.reef.driver.evaluator
Represents an Evaluator that is allocated, but is not running yet.
AllocatedEvaluatorBridge - Class in org.apache.reef.javabridge
The AllocatedEvaluatorBridge object to bridge operations between REEF .NET and Java allocated evaluator operations.
AllocatedEvaluatorBridgeFactory - Class in org.apache.reef.javabridge
The Factory object used to create AllocatedEvaluatorBridge objects.
AllocatedEvaluatorImpl - Class in org.apache.reef.runtime.common.driver.evaluator
Driver-Side representation of an allocated evaluator.
AllReduce<T> - Interface in org.apache.reef.io.network.group.api.operators
MPI All Reduce Operator.
AllReduce_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
AllReduce = 6;
AM_CONTAINER_LOGS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
AM_CONTAINER_SPEC - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
AM_HOST_HTTP_ADDRESS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
AmContainerSpec - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents the specifications for an application master container.
AmContainerSpec() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
ANY_RACK - Static variable in class org.apache.reef.runtime.common.utils.Constants
Any modifier.
APP - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
APPLICATION_ACLS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
APPLICATION_ID - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
APPLICATION_IDENTIFIER - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
APPLICATION_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
APPLICATION_TAGS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
APPLICATION_TYPE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
ApplicationID - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents the response to an application ID request to the YARN Resource Manager via the YARN REST API.
ApplicationID() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationID
 
ApplicationIdentifier - Class in org.apache.reef.runtime.common.evaluator.parameters
The RM application/job identifier.
ApplicationResponse - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
A response object used in deserialization when querying the Resource Manager for an application via the YARN REST API.
ApplicationResponse() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationResponse
 
ApplicationState - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
An object representing the state of an application, used to deserialize queries for an application/list of applications to the Resource Manager on HDInsight via the YARN REST API.
ApplicationState() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
ApplicationSubmission - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents an Application Submission object to the YARN REST API.
ApplicationSubmission() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
apply(Iterable<Pair<Vector, Integer>>) - Method in class org.apache.reef.examples.group.bgd.LineSearchReduceFunction
 
apply(Iterable<Pair<Pair<Double, Integer>, Vector>>) - Method in class org.apache.reef.examples.group.bgd.LossAndGradientReduceFunction
 
apply(Iterable<Boolean>) - Method in class org.apache.reef.examples.group.broadcast.ModelReceiveAckReduceFunction
 
apply(T) - Method in interface org.apache.reef.io.network.group.api.operators.AllGather
Apply the operation on element.
apply(T, List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.AllGather
Apply the operation on element.
apply(T) - Method in interface org.apache.reef.io.network.group.api.operators.AllReduce
Apply the operation on element.
apply(T, List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.AllReduce
Apply the operation on element.
apply(Iterable<T>) - Method in interface org.apache.reef.io.network.group.api.operators.Reduce.ReduceFunction
Apply the function on elements.
apply(List<T>, List<Integer>) - Method in interface org.apache.reef.io.network.group.api.operators.ReduceScatter
Apply this operation on elements where counts specify the distribution of elements to each task.
apply(List<T>, List<Integer>, List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.ReduceScatter
Apply this operation on elements where counts specify the distribution of elements to each task.
APPS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
areAssertionsEnabled() - Static method in class org.apache.reef.util.EnvironmentUtils
Check whether assert() statements are evaluated.
ARGS_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
ARGS_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
asError() - Method in class org.apache.reef.common.AbstractFailure
Return the original Java Exception, or generate a new one if it does not exists.
asError() - Method in interface org.apache.reef.common.Failure
Return the original Java Exception, or generate a new one if it does not exists.
asError - Variable in class org.apache.reef.io.watcher.common.AvroFailure
Deprecated.
Aspect - Interface in org.apache.reef.tang
A simple interface that allows external code to interpose on Tang object injections.
assertSingleton(Class) - Static method in class org.apache.reef.util.SingletonAsserter
Check if a given class is instantiated only once.
assertSingleton(String, Class) - Static method in class org.apache.reef.util.SingletonAsserter
Check if given class is singleton within a particular environment or scope.
assertStaticClean() - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
availableSpace() - Method in class org.apache.reef.io.storage.local.LocalScratchSpace
 
availableSpace() - Method in interface org.apache.reef.io.storage.ScratchSpace
 
avg() - Method in class org.apache.reef.examples.group.utils.math.Window
 
avgIfAdded(double) - Method in class org.apache.reef.examples.group.utils.math.Window
 
AvroActiveContext - Class in org.apache.reef.io.watcher.driver.context
 
AvroActiveContext() - Constructor for class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Default constructor.
AvroActiveContext(AvroContextBase) - Constructor for class org.apache.reef.io.watcher.driver.context.AvroActiveContext
All-args constructor.
AvroActiveContext.Builder - Class in org.apache.reef.io.watcher.driver.context
RecordBuilder for AvroActiveContext instances.
AvroAllocatedEvaluator - Class in org.apache.reef.io.watcher.driver.evaluator
 
AvroAllocatedEvaluator() - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Default constructor.
AvroAllocatedEvaluator(CharSequence, AvroEvaluatorDescriptor) - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
All-args constructor.
AvroAllocatedEvaluator.Builder - Class in org.apache.reef.io.watcher.driver.evaluator
RecordBuilder for AvroAllocatedEvaluator instances.
AvroAppSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroAppSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Default constructor.
AvroAppSubmissionParameters(Integer, Integer, Integer) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
All-args constructor.
AvroAppSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroAppSubmissionParameters instances.
AvroClassHierarchySerializer - Class in org.apache.reef.tang.implementation.avro
Serialize and Deserialize ClassHierarchy to and from AvroClassHierarchy.
AvroClassHierarchySerializer() - Constructor for class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
AvroClassNode - Class in org.apache.reef.tang.implementation.avro
 
AvroClassNode() - Constructor for class org.apache.reef.tang.implementation.avro.AvroClassNode
Default constructor.
AvroClassNode(Boolean, Boolean, Boolean, List<AvroConstructorDef>, List<AvroConstructorDef>, List<CharSequence>, CharSequence) - Constructor for class org.apache.reef.tang.implementation.avro.AvroClassNode
All-args constructor.
AvroClassNode.Builder - Class in org.apache.reef.tang.implementation.avro
RecordBuilder for AvroClassNode instances.
AvroClosedContext - Class in org.apache.reef.io.watcher.driver.context
 
AvroClosedContext() - Constructor for class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Default constructor.
AvroClosedContext(AvroContextBase, AvroActiveContext) - Constructor for class org.apache.reef.io.watcher.driver.context.AvroClosedContext
All-args constructor.
AvroClosedContext.Builder - Class in org.apache.reef.io.watcher.driver.context
RecordBuilder for AvroClosedContext instances.
AvroCompletedEvaluator - Class in org.apache.reef.io.watcher.driver.evaluator
 
AvroCompletedEvaluator() - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Default constructor.
AvroCompletedEvaluator(CharSequence) - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
All-args constructor.
AvroCompletedEvaluator.Builder - Class in org.apache.reef.io.watcher.driver.evaluator
RecordBuilder for AvroCompletedEvaluator instances.
AvroCompletedTask - Class in org.apache.reef.io.watcher.driver.task
 
AvroCompletedTask() - Constructor for class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Default constructor.
AvroCompletedTask(CharSequence, AvroActiveContext, ByteBuffer) - Constructor for class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
All-args constructor.
AvroCompletedTask.Builder - Class in org.apache.reef.io.watcher.driver.task
RecordBuilder for AvroCompletedTask instances.
AvroConfiguration - Class in org.apache.reef.tang.formats.avro
 
AvroConfiguration() - Constructor for class org.apache.reef.tang.formats.avro.AvroConfiguration
Default constructor.
AvroConfiguration(CharSequence, List<ConfigurationEntry>) - Constructor for class org.apache.reef.tang.formats.avro.AvroConfiguration
All-args constructor.
AvroConfiguration.Builder - Class in org.apache.reef.tang.formats.avro
RecordBuilder for AvroConfiguration instances.
AvroConfigurationSerializer - Class in org.apache.reef.tang.formats
(De-)Serializing Configuration to and from AvroConfiguration.
AvroConfigurationSerializer() - Constructor for class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
AvroConstructorArg - Class in org.apache.reef.tang.implementation.avro
 
AvroConstructorArg() - Constructor for class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Default constructor.
AvroConstructorArg(CharSequence, CharSequence, Boolean) - Constructor for class org.apache.reef.tang.implementation.avro.AvroConstructorArg
All-args constructor.
AvroConstructorArg.Builder - Class in org.apache.reef.tang.implementation.avro
RecordBuilder for AvroConstructorArg instances.
AvroConstructorDef - Class in org.apache.reef.tang.implementation.avro
 
AvroConstructorDef() - Constructor for class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Default constructor.
AvroConstructorDef(CharSequence, List<AvroConstructorArg>) - Constructor for class org.apache.reef.tang.implementation.avro.AvroConstructorDef
All-args constructor.
AvroConstructorDef.Builder - Class in org.apache.reef.tang.implementation.avro
RecordBuilder for AvroConstructorDef instances.
AvroContextBase - Class in org.apache.reef.io.watcher.driver.context
 
AvroContextBase() - Constructor for class org.apache.reef.io.watcher.driver.context.AvroContextBase
Default constructor.
AvroContextBase(CharSequence, CharSequence, CharSequence, AvroEvaluatorDescriptor) - Constructor for class org.apache.reef.io.watcher.driver.context.AvroContextBase
All-args constructor.
AvroContextBase.Builder - Class in org.apache.reef.io.watcher.driver.context
RecordBuilder for AvroContextBase instances.
AvroContextMessage - Class in org.apache.reef.io.watcher.driver.context
 
AvroContextMessage() - Constructor for class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Default constructor.
AvroContextMessage(CharSequence, CharSequence, ByteBuffer) - Constructor for class org.apache.reef.io.watcher.driver.context.AvroContextMessage
All-args constructor.
AvroContextMessage.Builder - Class in org.apache.reef.io.watcher.driver.context
RecordBuilder for AvroContextMessage instances.
AvroDriverInfo - Class in org.apache.reef.webserver
 
AvroDriverInfo() - Constructor for class org.apache.reef.webserver.AvroDriverInfo
Default constructor.
AvroDriverInfo(CharSequence, CharSequence, List<AvroReefServiceInfo>) - Constructor for class org.apache.reef.webserver.AvroDriverInfo
All-args constructor.
AvroDriverInfo.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroDriverInfo instances.
AvroDriverInfoSerializer - Class in org.apache.reef.webserver
Serialize Drive information.
AvroEvaluatorDescriptor - Class in org.apache.reef.io.watcher.driver.evaluator
 
AvroEvaluatorDescriptor() - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Default constructor.
AvroEvaluatorDescriptor(AvroNodeDescriptor, AvroEvaluatorProcess, Integer, Integer) - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
All-args constructor.
AvroEvaluatorDescriptor.Builder - Class in org.apache.reef.io.watcher.driver.evaluator
RecordBuilder for AvroEvaluatorDescriptor instances.
AvroEvaluatorEntry - Class in org.apache.reef.webserver
 
AvroEvaluatorEntry() - Constructor for class org.apache.reef.webserver.AvroEvaluatorEntry
Default constructor.
AvroEvaluatorEntry(CharSequence, CharSequence) - Constructor for class org.apache.reef.webserver.AvroEvaluatorEntry
All-args constructor.
AvroEvaluatorEntry.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroEvaluatorEntry instances.
AvroEvaluatorInfo - Class in org.apache.reef.webserver
 
AvroEvaluatorInfo() - Constructor for class org.apache.reef.webserver.AvroEvaluatorInfo
Default constructor.
AvroEvaluatorInfo(CharSequence, CharSequence, CharSequence, Integer, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.reef.webserver.AvroEvaluatorInfo
All-args constructor.
AvroEvaluatorInfo.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroEvaluatorInfo instances.
AvroEvaluatorInfoSerializer - Class in org.apache.reef.webserver
Serialize Evaluator Info.
AvroEvaluatorList - Class in org.apache.reef.webserver
 
AvroEvaluatorList() - Constructor for class org.apache.reef.webserver.AvroEvaluatorList
Default constructor.
AvroEvaluatorList(List<AvroEvaluatorEntry>, Integer, CharSequence) - Constructor for class org.apache.reef.webserver.AvroEvaluatorList
All-args constructor.
AvroEvaluatorList.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroEvaluatorList instances.
AvroEvaluatorListSerializer - Class in org.apache.reef.webserver
Serializer for Evaluator list.
AvroEvaluatorProcess - Class in org.apache.reef.io.watcher.driver.evaluator
 
AvroEvaluatorProcess() - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Default constructor.
AvroEvaluatorProcess(List<CharSequence>, AvroEvaluatorType, Boolean) - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
All-args constructor.
AvroEvaluatorProcess.Builder - Class in org.apache.reef.io.watcher.driver.evaluator
RecordBuilder for AvroEvaluatorProcess instances.
AvroEvaluatorRequest - Class in org.apache.reef.io.data.loading.avro
 
AvroEvaluatorRequest() - Constructor for class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Default constructor.
AvroEvaluatorRequest(Integer, Integer, Integer, List<CharSequence>, List<CharSequence>) - Constructor for class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
All-args constructor.
AvroEvaluatorRequest.Builder - Class in org.apache.reef.io.data.loading.avro
RecordBuilder for AvroEvaluatorRequest instances.
AvroEvaluatorRequestSerializer - Class in org.apache.reef.io.data.loading.impl
Serialize and deserialize EvaluatorRequest objects using Avro.
AvroEvaluatorsInfo - Class in org.apache.reef.webserver
 
AvroEvaluatorsInfo() - Constructor for class org.apache.reef.webserver.AvroEvaluatorsInfo
Default constructor.
AvroEvaluatorsInfo(List<AvroEvaluatorInfo>) - Constructor for class org.apache.reef.webserver.AvroEvaluatorsInfo
All-args constructor.
AvroEvaluatorsInfo.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroEvaluatorsInfo instances.
AvroEvaluatorType - Enum in org.apache.reef.io.watcher.driver.evaluator
 
AvroFailedContext - Class in org.apache.reef.io.watcher.driver.context
 
AvroFailedContext() - Constructor for class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Default constructor.
AvroFailedContext(AvroContextBase, AvroActiveContext, AvroFailure) - Constructor for class org.apache.reef.io.watcher.driver.context.AvroFailedContext
All-args constructor.
AvroFailedContext.Builder - Class in org.apache.reef.io.watcher.driver.context
RecordBuilder for AvroFailedContext instances.
AvroFailedEvaluator - Class in org.apache.reef.io.watcher.driver.evaluator
 
AvroFailedEvaluator() - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Default constructor.
AvroFailedEvaluator(CharSequence, CharSequence, List<AvroFailedContext>, AvroFailedTask) - Constructor for class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
All-args constructor.
AvroFailedEvaluator.Builder - Class in org.apache.reef.io.watcher.driver.evaluator
RecordBuilder for AvroFailedEvaluator instances.
AvroFailedTask - Class in org.apache.reef.io.watcher.driver.task
 
AvroFailedTask() - Constructor for class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Default constructor.
AvroFailedTask(AvroFailure, AvroActiveContext) - Constructor for class org.apache.reef.io.watcher.driver.task.AvroFailedTask
All-args constructor.
AvroFailedTask - Class in org.apache.reef.javabridge.avro
 
AvroFailedTask() - Constructor for class org.apache.reef.javabridge.avro.AvroFailedTask
Default constructor.
AvroFailedTask(CharSequence, ByteBuffer, ByteBuffer, CharSequence) - Constructor for class org.apache.reef.javabridge.avro.AvroFailedTask
All-args constructor.
AvroFailedTask.Builder - Class in org.apache.reef.io.watcher.driver.task
RecordBuilder for AvroFailedTask instances.
AvroFailedTask.Builder - Class in org.apache.reef.javabridge.avro
RecordBuilder for AvroFailedTask instances.
AvroFailure - Class in org.apache.reef.io.watcher.common
 
AvroFailure() - Constructor for class org.apache.reef.io.watcher.common.AvroFailure
Default constructor.
AvroFailure(CharSequence, CharSequence, CharSequence, CharSequence, ByteBuffer, CharSequence) - Constructor for class org.apache.reef.io.watcher.common.AvroFailure
All-args constructor.
AvroFailure.Builder - Class in org.apache.reef.io.watcher.common
RecordBuilder for AvroFailure instances.
AvroHttpRequest - Class in org.apache.reef.webserver
 
AvroHttpRequest() - Constructor for class org.apache.reef.webserver.AvroHttpRequest
Default constructor.
AvroHttpRequest(List<HeaderEntry>, CharSequence, CharSequence, CharSequence, CharSequence, ByteBuffer) - Constructor for class org.apache.reef.webserver.AvroHttpRequest
All-args constructor.
AvroHttpRequest.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroHttpRequest instances.
AvroHttpSerializer - Class in org.apache.reef.webserver
Serialize Http Request Response data with Avro.
AvroHttpSerializer() - Constructor for class org.apache.reef.webserver.AvroHttpSerializer
 
AvroJobSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroJobSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Default constructor.
AvroJobSubmissionParameters(CharSequence, CharSequence) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
All-args constructor.
AvroJobSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroJobSubmissionParameters instances.
AvroLocalAppSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroLocalAppSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Default constructor.
AvroLocalAppSubmissionParameters(AvroAppSubmissionParameters, Integer) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
All-args constructor.
AvroLocalAppSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroLocalAppSubmissionParameters instances.
AvroLocalJobSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroLocalJobSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Default constructor.
AvroLocalJobSubmissionParameters(AvroJobSubmissionParameters, CharSequence, CharSequence) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
All-args constructor.
AvroLocalJobSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroLocalJobSubmissionParameters instances.
AvroMultiRuntimeAppSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroMultiRuntimeAppSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Default constructor.
AvroMultiRuntimeAppSubmissionParameters(AvroAppSubmissionParameters, AvroLocalAppSubmissionParameters, AvroYarnAppSubmissionParameters, CharSequence, List<CharSequence>) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
All-args constructor.
AvroMultiRuntimeAppSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroMultiRuntimeAppSubmissionParameters instances.
AvroMultiRuntimeDefinition - Class in org.apache.reef.runtime.multi.utils.avro
 
AvroMultiRuntimeDefinition() - Constructor for class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Default constructor.
AvroMultiRuntimeDefinition(CharSequence, List<AvroRuntimeDefinition>) - Constructor for class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
All-args constructor.
AvroMultiRuntimeDefinition.Builder - Class in org.apache.reef.runtime.multi.utils.avro
RecordBuilder for AvroMultiRuntimeDefinition instances.
AvroNamedParameterNode - Class in org.apache.reef.tang.implementation.avro
 
AvroNamedParameterNode() - Constructor for class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Default constructor.
AvroNamedParameterNode(CharSequence, CharSequence, Boolean, Boolean, CharSequence, CharSequence, List<CharSequence>) - Constructor for class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
All-args constructor.
AvroNamedParameterNode.Builder - Class in org.apache.reef.tang.implementation.avro
RecordBuilder for AvroNamedParameterNode instances.
AvroNamingAssignment - Class in org.apache.reef.io.network.naming.avro
 
AvroNamingAssignment() - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Default constructor.
AvroNamingAssignment(CharSequence, CharSequence, Integer) - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
All-args constructor.
AvroNamingAssignment.Builder - Class in org.apache.reef.io.network.naming.avro
RecordBuilder for AvroNamingAssignment instances.
AvroNamingLookupRequest - Class in org.apache.reef.io.network.naming.avro
 
AvroNamingLookupRequest() - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Default constructor.
AvroNamingLookupRequest(List<CharSequence>) - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
All-args constructor.
AvroNamingLookupRequest.Builder - Class in org.apache.reef.io.network.naming.avro
RecordBuilder for AvroNamingLookupRequest instances.
AvroNamingLookupResponse - Class in org.apache.reef.io.network.naming.avro
 
AvroNamingLookupResponse() - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Default constructor.
AvroNamingLookupResponse(List<AvroNamingAssignment>) - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
All-args constructor.
AvroNamingLookupResponse.Builder - Class in org.apache.reef.io.network.naming.avro
RecordBuilder for AvroNamingLookupResponse instances.
AvroNamingRegisterRequest - Class in org.apache.reef.io.network.naming.avro
 
AvroNamingRegisterRequest() - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Default constructor.
AvroNamingRegisterRequest(CharSequence, CharSequence, Integer) - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
All-args constructor.
AvroNamingRegisterRequest.Builder - Class in org.apache.reef.io.network.naming.avro
RecordBuilder for AvroNamingRegisterRequest instances.
AvroNamingUnRegisterRequest - Class in org.apache.reef.io.network.naming.avro
 
AvroNamingUnRegisterRequest() - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Default constructor.
AvroNamingUnRegisterRequest(CharSequence) - Constructor for class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
All-args constructor.
AvroNamingUnRegisterRequest.Builder - Class in org.apache.reef.io.network.naming.avro
RecordBuilder for AvroNamingUnRegisterRequest instances.
AvroNode - Class in org.apache.reef.tang.implementation.avro
 
AvroNode() - Constructor for class org.apache.reef.tang.implementation.avro.AvroNode
Default constructor.
AvroNode(CharSequence, CharSequence, AvroClassNode, AvroNamedParameterNode, AvroPackageNode, List<AvroNode>) - Constructor for class org.apache.reef.tang.implementation.avro.AvroNode
All-args constructor.
AvroNode.Builder - Class in org.apache.reef.tang.implementation.avro
RecordBuilder for AvroNode instances.
AvroNodeDescriptor - Class in org.apache.reef.io.watcher.driver.catalog
 
AvroNodeDescriptor() - Constructor for class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Default constructor.
AvroNodeDescriptor(CharSequence, CharSequence, CharSequence, AvroRackDescriptor) - Constructor for class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
All-args constructor.
AvroNodeDescriptor.Builder - Class in org.apache.reef.io.watcher.driver.catalog
RecordBuilder for AvroNodeDescriptor instances.
AvroNodeDescriptorInRackDescriptor - Class in org.apache.reef.io.watcher.driver.catalog
 
AvroNodeDescriptorInRackDescriptor() - Constructor for class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Default constructor.
AvroNodeDescriptorInRackDescriptor(CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
All-args constructor.
AvroNodeDescriptorInRackDescriptor.Builder - Class in org.apache.reef.io.watcher.driver.catalog
RecordBuilder for AvroNodeDescriptorInRackDescriptor instances.
AvroPackageNode - Class in org.apache.reef.tang.implementation.avro
 
AvroPackageNode() - Constructor for class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
AvroPackageNode.Builder - Class in org.apache.reef.tang.implementation.avro
RecordBuilder for AvroPackageNode instances.
AvroRackDescriptor - Class in org.apache.reef.io.watcher.driver.catalog
 
AvroRackDescriptor() - Constructor for class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Default constructor.
AvroRackDescriptor(CharSequence, List<AvroNodeDescriptorInRackDescriptor>) - Constructor for class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
All-args constructor.
AvroRackDescriptor.Builder - Class in org.apache.reef.io.watcher.driver.catalog
RecordBuilder for AvroRackDescriptor instances.
AvroReefServiceInfo - Class in org.apache.reef.webserver
 
AvroReefServiceInfo() - Constructor for class org.apache.reef.webserver.AvroReefServiceInfo
Default constructor.
AvroReefServiceInfo(CharSequence, CharSequence) - Constructor for class org.apache.reef.webserver.AvroReefServiceInfo
All-args constructor.
AvroReefServiceInfo.Builder - Class in org.apache.reef.webserver
RecordBuilder for AvroReefServiceInfo instances.
AvroRunningTask - Class in org.apache.reef.io.watcher.driver.task
 
AvroRunningTask() - Constructor for class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Default constructor.
AvroRunningTask(CharSequence, AvroActiveContext) - Constructor for class org.apache.reef.io.watcher.driver.task.AvroRunningTask
All-args constructor.
AvroRunningTask.Builder - Class in org.apache.reef.io.watcher.driver.task
RecordBuilder for AvroRunningTask instances.
AvroRuntimeDefinition - Class in org.apache.reef.runtime.multi.utils.avro
 
AvroRuntimeDefinition() - Constructor for class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Default constructor.
AvroRuntimeDefinition(CharSequence, CharSequence) - Constructor for class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
All-args constructor.
AvroRuntimeDefinition.Builder - Class in org.apache.reef.runtime.multi.utils.avro
RecordBuilder for AvroRuntimeDefinition instances.
AvroRuntimeStart - Class in org.apache.reef.io.watcher.wake.time.runtime.event
 
AvroRuntimeStart() - Constructor for class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Default constructor.
AvroRuntimeStart(Long) - Constructor for class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
All-args constructor.
AvroRuntimeStart.Builder - Class in org.apache.reef.io.watcher.wake.time.runtime.event
RecordBuilder for AvroRuntimeStart instances.
AvroRuntimeStop - Class in org.apache.reef.io.watcher.wake.time.runtime.event
 
AvroRuntimeStop() - Constructor for class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Default constructor.
AvroRuntimeStop(Long, CharSequence) - Constructor for class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
All-args constructor.
AvroRuntimeStop.Builder - Class in org.apache.reef.io.watcher.wake.time.runtime.event
RecordBuilder for AvroRuntimeStop instances.
AvroStartTime - Class in org.apache.reef.io.watcher.wake.time.event
 
AvroStartTime() - Constructor for class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Default constructor.
AvroStartTime(Long) - Constructor for class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
All-args constructor.
AvroStartTime.Builder - Class in org.apache.reef.io.watcher.wake.time.event
RecordBuilder for AvroStartTime instances.
AvroStopTime - Class in org.apache.reef.io.watcher.wake.time.event
 
AvroStopTime() - Constructor for class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Default constructor.
AvroStopTime(Long) - Constructor for class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
All-args constructor.
AvroStopTime.Builder - Class in org.apache.reef.io.watcher.wake.time.event
RecordBuilder for AvroStopTime instances.
AvroSuspendedTask - Class in org.apache.reef.io.watcher.driver.task
 
AvroSuspendedTask() - Constructor for class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Default constructor.
AvroSuspendedTask(CharSequence, AvroActiveContext, ByteBuffer) - Constructor for class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
All-args constructor.
AvroSuspendedTask.Builder - Class in org.apache.reef.io.watcher.driver.task
RecordBuilder for AvroSuspendedTask instances.
AvroTaskMessage - Class in org.apache.reef.io.watcher.driver.task
 
AvroTaskMessage() - Constructor for class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Default constructor.
AvroTaskMessage(CharSequence, CharSequence, CharSequence, ByteBuffer) - Constructor for class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
All-args constructor.
AvroTaskMessage.Builder - Class in org.apache.reef.io.watcher.driver.task
RecordBuilder for AvroTaskMessage instances.
AvroYarnAppSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroYarnAppSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Default constructor.
AvroYarnAppSubmissionParameters(AvroAppSubmissionParameters, Integer) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
All-args constructor.
AvroYarnAppSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroYarnAppSubmissionParameters instances.
AvroYarnClusterJobSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroYarnClusterJobSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Default constructor.
AvroYarnClusterJobSubmissionParameters(AvroYarnJobSubmissionParameters, CharSequence, CharSequence, Integer, Integer, CharSequence, CharSequence) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
All-args constructor.
AvroYarnClusterJobSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroYarnClusterJobSubmissionParameters instances.
AvroYarnJobSubmissionParameters - Class in org.apache.reef.reef.bridge.client.avro
 
AvroYarnJobSubmissionParameters() - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Default constructor.
AvroYarnJobSubmissionParameters(AvroJobSubmissionParameters, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
All-args constructor.
AvroYarnJobSubmissionParameters.Builder - Class in org.apache.reef.reef.bridge.client.avro
RecordBuilder for AvroYarnJobSubmissionParameters instances.
await() - Method in class org.apache.reef.io.network.group.impl.utils.CountingSemaphore
 
await() - Method in class org.apache.reef.io.network.group.impl.utils.ResettingCountDownLatch
 
awaitAndReset(int) - Method in class org.apache.reef.io.network.group.impl.utils.ResettingCountDownLatch
 
AzureStorageAccountContainerName - Class in org.apache.reef.runtime.hdinsight.parameters
The Storage account container name to be used by Azure.
AzureStorageAccountContainerName() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.AzureStorageAccountContainerName
 
AzureStorageAccountKey - Class in org.apache.reef.runtime.hdinsight.parameters
The Storage account key to be used by Azure.
AzureStorageAccountKey() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.AzureStorageAccountKey
 
AzureStorageAccountName - Class in org.apache.reef.runtime.hdinsight.parameters
The Storage account to be used by Azure.
AzureStorageAccountName() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.AzureStorageAccountName
 
AzureStorageBaseFolder - Class in org.apache.reef.runtime.hdinsight.parameters
The folder to use as the base folder for storing the JARs.
AzureStorageBaseFolder() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.AzureStorageBaseFolder
 

B

B - Class in org.apache.reef.tang.examples
 
B() - Constructor for class org.apache.reef.tang.examples.B
 
base - Variable in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Deprecated.
base - Variable in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Deprecated.
base - Variable in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Deprecated.
BGDClient - Class in org.apache.reef.examples.group.bgd
A client to submit BGD Jobs.
BGDClient(String, int, int, int, BGDControlParameters) - Constructor for class org.apache.reef.examples.group.bgd.BGDClient
 
BGDControlParameters - Class in org.apache.reef.examples.group.bgd.parameters
Control parameters for BGD example.
BGDControlParameters(int, double, double, double, double, int, boolean, int, BGDLossType) - Constructor for class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
BGDDriver - Class in org.apache.reef.examples.group.bgd
Driver for BGD example.
BGDDriver(DataLoadingService, GroupCommDriver, ConfigurationSerializer, BGDControlParameters) - Constructor for class org.apache.reef.examples.group.bgd.BGDDriver
 
BGDLocal - Class in org.apache.reef.examples.group.bgd
Runs BGD on the local runtime.
BGDLossType - Class in org.apache.reef.examples.group.bgd.parameters
Type of loss function used in example.
BGDLossType(String) - Constructor for class org.apache.reef.examples.group.bgd.parameters.BGDLossType
 
BGDYarn - Class in org.apache.reef.examples.group.bgd
Runs BGD on the YARN runtime.
bind(String, String) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Bind classes to each other, based on their full class names; alternatively, bound a NamedParameter configuration option to a configuration value.
bind(Node, Node) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Bind classes to each other, based on their full class names; alternatively, bound a NamedParameter configuration option to a configuration value.
bind(Class<?>, Impl<?>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bind(String, String) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bind(Node, Node) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bind(Class<T>, Class<?>) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bind(Class<T>, Class<?>) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
Bind named parameters, implementations or external constructors, depending on the types of the classes passed in.
bindAspect(Aspect) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
bindAspect(Aspect) - Method in interface org.apache.reef.tang.Injector
Binds a TANG Aspect to this injector.
bindConstructor(ClassNode<T>, ClassNode<? extends ExternalConstructor<? extends T>>) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Register an ExternalConstructor implementation with Tang.
bindConstructor(Class<T>, Class<? extends ExternalConstructor<? extends T>>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindConstructor(Class<T>, Impl<? extends ExternalConstructor<? extends T>>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindConstructor(ClassNode<T>, ClassNode<? extends ExternalConstructor<? extends T>>) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindConstructor(Class<T>, Class<? extends ExternalConstructor<? extends T>>) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bindConstructor(Class<T>, Class<? extends ExternalConstructor<? extends T>>) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
 
BindException - Exception in org.apache.reef.tang.exceptions
Thrown when an illegal or contradictory configuration option is encountered.
BindException(String, Throwable) - Constructor for exception org.apache.reef.tang.exceptions.BindException
 
BindException(String) - Constructor for exception org.apache.reef.tang.exceptions.BindException
 
bindImplementation(Class<T>, Class<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindImplementation(Class<T>, String) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindImplementation(Class<T>, Impl<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindImplementation(ClassNode<T>, ClassNode<? extends T>) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindImplementation(Class<T>, Class<? extends T>) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bindImplementation(Class<T>, Class<? extends T>) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
Binds the Class impl as the implementation of the interface iface.
Bindings - Variable in class org.apache.reef.tang.formats.avro.AvroConfiguration
Deprecated.
bindList(NamedParameterNode<List<T>>, List) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Bind an list of implementations(Class or String) to an given NamedParameter.
bindList(String, List) - Method in interface org.apache.reef.tang.ConfigurationBuilder
 
bindList(Class<? extends Name<List<T>>>, Impl<List>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindList(Class<? extends Name<List<T>>>, Param<List>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindList(Class<? extends Name<List<T>>>, List) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindList(NamedParameterNode<List<T>>, List) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindList(String, List) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindList(Class<? extends Name<List<T>>>, List) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
Binding list method for JavaConfigurationBuilder.
bindList(Class<? extends Name<List<T>>>, List) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
Binds a specific list to a named parameter.
BindLocation - Interface in org.apache.reef.tang
This interface is used to track the source of configuration bindings.
bindNamedParameter(Class<? extends Name<T>>, String) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindNamedParameter(Class<? extends Name<T>>, Param<T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindNamedParameter(Class<? extends Name<T>>, Class<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindNamedParameter(Class<? extends Name<T>>, Impl<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindNamedParameter(Class<? extends Name<?>>, String) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bindNamedParameter(Class<? extends Name<T>>, Class<? extends T>) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bindNamedParameter(Class<? extends Name<?>>, String) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
Set the value of a named parameter.
bindNamedParameter(Class<? extends Name<T>>, Class<? extends T>) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
 
BindNSToTask - Class in org.apache.reef.io.network.impl
 
BindNSToTask(NetworkService<?>, IdentifierFactory) - Constructor for class org.apache.reef.io.network.impl.BindNSToTask
 
bindParameter(NamedParameterNode<T>, String) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindSetEntry(NamedParameterNode<Set<T>>, Node) - Method in interface org.apache.reef.tang.ConfigurationBuilder
 
bindSetEntry(NamedParameterNode<Set<T>>, String) - Method in interface org.apache.reef.tang.ConfigurationBuilder
 
bindSetEntry(String, String) - Method in interface org.apache.reef.tang.ConfigurationBuilder
 
bindSetEntry(String, Node) - Method in interface org.apache.reef.tang.ConfigurationBuilder
 
bindSetEntry(Class<? extends Name<Set<T>>>, String) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindSetEntry(Class<? extends Name<Set<T>>>, Class<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindSetEntry(Class<? extends Name<Set<T>>>, Impl<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindSetEntry(Class<? extends Name<Set<T>>>, Param<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
bindSetEntry(String, String) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindSetEntry(String, Node) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindSetEntry(NamedParameterNode<Set<T>>, String) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindSetEntry(NamedParameterNode<Set<T>>, Node) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
bindSetEntry(Class<? extends Name<Set<T>>>, String) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bindSetEntry(Class<? extends Name<Set<T>>>, Class<? extends T>) - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
bindSetEntry(Class<? extends Name<Set<T>>>, String) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
 
bindSetEntry(Class<? extends Name<Set<T>>>, Class<? extends T>) - Method in interface org.apache.reef.tang.JavaConfigurationBuilder
 
bindVolatileInstance(Class<T>, T) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
bindVolatileInstance(Class<T>, T) - Method in interface org.apache.reef.tang.Injector
Binds the given object to the class.
bindVolatileParameter(Class<? extends Name<T>>, T) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
bindVolatileParameter(Class<? extends Name<T>>, T) - Method in interface org.apache.reef.tang.Injector
 
bldGCM(ReefNetworkGroupCommProtos.GroupCommMessage.Type, Identifier, Identifier, byte[]...) - Static method in class org.apache.reef.io.network.util.Utils
 
bldVersionedGCM(Class<? extends Name<String>>, Class<? extends Name<String>>, ReefNetworkGroupCommProtos.GroupCommMessage.Type, String, int, String, int, byte[]...) - Static method in class org.apache.reef.io.network.group.impl.utils.Utils
 
BlockingEventHandler<T> - Class in org.apache.reef.examples.utils.wake
An EventHandler that blocks until a set number of Events has been received.
BlockingEventHandler(int, EventHandler<Iterable<T>>) - Constructor for class org.apache.reef.examples.utils.wake.BlockingEventHandler
 
BlockingEventHandler<T> - Class in org.apache.reef.wake.impl
An EventHandler that blocks until a set number of Events has been received.
BlockingEventHandler(int, EventHandler<Iterable<T>>) - Constructor for class org.apache.reef.wake.impl.BlockingEventHandler
 
BlockingJoin - Class in org.apache.reef.wake.examples.join
Blocking join.
BlockingJoin(Observer<TupleEvent>) - Constructor for class org.apache.reef.wake.examples.join.BlockingJoin
 
BlockingSignalEventHandler<T> - Class in org.apache.reef.wake.impl
An EventHandler that blocks until a set number of Events has been received.
BlockingSignalEventHandler(int, EventHandler<T>) - Constructor for class org.apache.reef.wake.impl.BlockingSignalEventHandler
 
boxClass(Class<?>) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Given a primitive type, return its boxed representation.
BRIDGE_SETUP - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
BridgeHandlerManager - Class in org.apache.reef.javabridge
A class that holds all handles to the .NET side.
BridgeHandlerManager() - Constructor for class org.apache.reef.javabridge.BridgeHandlerManager
 
BridgeInterop - Class in org.apache.reef.bridge.message
 
BridgeInterop() - Constructor for class org.apache.reef.bridge.message.BridgeInterop
Default constructor.
BridgeInterop(Long, MessageType, Object) - Constructor for class org.apache.reef.bridge.message.BridgeInterop
All-args constructor.
BridgeInterop.Builder - Class in org.apache.reef.bridge.message
RecordBuilder for BridgeInterop instances.
Broadcast - Interface in org.apache.reef.io.network.group.api.operators
MPI Broadcast operator.
Broadcast.Receiver<T> - Interface in org.apache.reef.io.network.group.api.operators
Receivers or Non-roots.
Broadcast.Sender<T> - Interface in org.apache.reef.io.network.group.api.operators
Sender or Root.
Broadcast_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
Broadcast = 3;
BroadcastDriver - Class in org.apache.reef.examples.group.broadcast
Driver for broadcast example.
BroadcastDriver(EvaluatorRequestor, GroupCommDriver, ConfigurationSerializer, int, int) - Constructor for class org.apache.reef.examples.group.broadcast.BroadcastDriver
 
BroadcastDriver.ContextActiveHandler - Class in org.apache.reef.examples.group.broadcast
ActiveContext handler.
BroadcastDriver.ContextActiveHandler() - Constructor for class org.apache.reef.examples.group.broadcast.BroadcastDriver.ContextActiveHandler
 
BroadcastDriver.ContextCloseHandler - Class in org.apache.reef.examples.group.broadcast
ClosedContext handler.
BroadcastDriver.ContextCloseHandler() - Constructor for class org.apache.reef.examples.group.broadcast.BroadcastDriver.ContextCloseHandler
 
BroadcastDriver.FailedTaskHandler - Class in org.apache.reef.examples.group.broadcast
FailedTask handler.
BroadcastDriver.FailedTaskHandler() - Constructor for class org.apache.reef.examples.group.broadcast.BroadcastDriver.FailedTaskHandler
 
BroadCastEventHandler<E> - Class in org.apache.reef.runtime.common.utils
Handler for BroadCastEvent which sends event to all handlers in the list.
BroadCastEventHandler(Collection<EventHandler<E>>) - Constructor for class org.apache.reef.runtime.common.utils.BroadCastEventHandler
 
BroadcastingEventHandler<T> - Class in org.apache.reef.io.network.group.impl.utils
 
BroadcastingEventHandler() - Constructor for class org.apache.reef.io.network.group.impl.utils.BroadcastingEventHandler
 
BroadcastOperatorSpec - Class in org.apache.reef.io.network.group.impl.config
The specification for the broadcast operator.
BroadcastOperatorSpec(String, Class<? extends Codec>) - Constructor for class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec
 
BroadcastOperatorSpec.Builder - Class in org.apache.reef.io.network.group.impl.config
 
BroadcastOperatorSpec.Builder() - Constructor for class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec.Builder
 
BroadcastReceiver<T> - Class in org.apache.reef.io.network.group.impl.operators
 
BroadcastReceiver(String, String, String, Codec<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient) - Constructor for class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
BroadcastREEF - Class in org.apache.reef.examples.group.broadcast
Client for broadcast example.
BroadcastREEF.InputDir - Class in org.apache.reef.examples.group.broadcast
Input path.
BroadcastREEF.InputDir() - Constructor for class org.apache.reef.examples.group.broadcast.BroadcastREEF.InputDir
 
BroadcastREEF.Local - Class in org.apache.reef.examples.group.broadcast
Command line parameter = true to run locally, or false to run on YARN.
BroadcastREEF.Local() - Constructor for class org.apache.reef.examples.group.broadcast.BroadcastREEF.Local
 
BroadcastSender<T> - Class in org.apache.reef.io.network.group.impl.operators
 
BroadcastSender(String, String, String, Codec<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient) - Constructor for class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
build() - Method in class org.apache.reef.bridge.message.Acknowledgement.Builder
 
build() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
 
build() - Method in class org.apache.reef.bridge.message.Header.Builder
 
build() - Method in class org.apache.reef.bridge.message.Protocol.Builder
 
build() - Method in class org.apache.reef.bridge.message.SetupBridge.Builder
 
build() - Method in class org.apache.reef.bridge.message.SystemOnStart.Builder
 
build() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Builds the EvaluatorRequest.
build() - Method in class org.apache.reef.driver.restart.RestartEvaluators.Builder
 
build() - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
build() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
 
build() - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition.Builder
build() - Method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec.Builder
 
build() - Method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec.Builder
 
build() - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec.Builder
 
build() - Method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec.Builder
 
build() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
 
build() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest.Builder
 
build() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse.Builder
 
build() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
 
build() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest.Builder
 
build() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
build() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
build() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
build() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
build() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
 
build() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
 
build() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime.Builder
 
build() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime.Builder
 
build() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart.Builder
 
build() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
 
build() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
 
build() - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes.Builder
 
build() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
build() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
build() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
build() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
 
build() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.files.FileResourceImpl.Builder
 
build() - Method in class org.apache.reef.runtime.common.launch.CLRLaunchCommandBuilder
 
build() - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
build() - Method in interface org.apache.reef.runtime.common.launch.LaunchCommandBuilder
 
build() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
 
build() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
 
build() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease.Builder
 
build() - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeConfigurationBuilder
Builds the configuration.
build() - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeDefinitionBuilder
Builds multi runtime definition.
build() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
 
build() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
 
build() - Method in interface org.apache.reef.tang.ConfigurationBuilder
Produce an immutable Configuration object that contains the current bindings and ClassHierarchy of this ConfigurationBuilder.
build() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
 
build() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
 
build() - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
build() - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
 
build() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
 
build() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
 
build() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
 
build() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
 
build() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
 
build() - Method in class org.apache.reef.tang.implementation.avro.AvroPackageNode.Builder
 
build() - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
build() - Method in class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
build() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
build() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
build() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
build() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
build() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
build() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
build() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
build() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
build() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
build() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
build() - Method in interface org.apache.reef.util.Builder
Builds a fresh instance of the object.
build() - Method in class org.apache.reef.vortex.api.VortexAggregatePolicy.AggregatePolicyBuilder
Builds and returns a new VortexAggregatePolicy based on user's specification.
build() - Method in class org.apache.reef.vortex.driver.VortexJobConf.Builder
Instantiate a VortexJobConf object, where a Configuration is built by Tang internally.
build() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
build() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
build() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
build() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
 
build() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
 
build() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
 
build() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
 
build() - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo.Builder
 
build() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
 
build() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
 
build() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
 
Builder<T> - Interface in org.apache.reef.util
A basic Builder pattern interface.
BuilderUtils - Class in org.apache.reef.util
Utilities for creating Builders.
buildPartial() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
buildPartial() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
buildPartial() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
buildPartial() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
buildPartial() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
buildPartial() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
buildPartial() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
buildPartial() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
buildPartial() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
ByteCodec - Class in org.apache.reef.wake.remote.impl
Codec that performs identity transformation on bytes.
ByteCodec() - Constructor for class org.apache.reef.wake.remote.impl.ByteCodec
 
ByteEncoder - Class in org.apache.reef.wake.remote.transport.netty
Wrapping encoder for byte[].
ByteEncoder() - Constructor for class org.apache.reef.wake.remote.transport.netty.ByteEncoder
 

C

Cache<K,V> - Interface in org.apache.reef.util.cache
Cache with get-if-absent-compute semantics.
CACHE_TIMEOUT - Static variable in class org.apache.reef.io.network.naming.LocalNameResolverConfiguration
The timeout of caching lookup.
CACHE_TIMEOUT - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
The timeout of caching lookup.
CacheImpl<K,V> - Class in org.apache.reef.util.cache
Implementation that supports expire-after-write.
CacheImpl(CurrentTime, long) - Constructor for class org.apache.reef.util.cache.CacheImpl
Construct an expire-after-write cache.
call(byte[]) - Method in class org.apache.reef.examples.data.loading.LineCountingTask
 
call(byte[]) - Method in class org.apache.reef.examples.data.output.OutputServiceTask
Receives an output stream from the output service and writes "Hello REEF!" on it.
call(byte[]) - Method in class org.apache.reef.examples.group.bgd.MasterTask
 
call(byte[]) - Method in class org.apache.reef.examples.group.bgd.SlaveTask
 
call(byte[]) - Method in class org.apache.reef.examples.group.broadcast.MasterTask
 
call(byte[]) - Method in class org.apache.reef.examples.group.broadcast.SlaveTask
 
call(byte[]) - Method in class org.apache.reef.examples.hello.HelloTask
 
call(byte[]) - Method in class org.apache.reef.examples.library.ShellTask
Execute the shell command and return the result, which is sent back to the JobDriver and surfaced in the CompletedTask object.
call(byte[]) - Method in class org.apache.reef.examples.pool.SleepTask
Sleep for delay milliseconds and return.
call(byte[]) - Method in class org.apache.reef.examples.suspend.SuspendTestTask
Main method of the task: run cycle from 0 to numCycles, and sleep for delay seconds on each cycle.
call(byte[]) - Method in interface org.apache.reef.task.Task
Called by the resourcemanager harness to execute the task.
call(byte[]) - Method in class org.apache.reef.tests.fail.driver.NoopTask
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTask
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTaskCall
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTaskClose
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTaskMsg
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTaskStart
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTaskStop
 
call(byte[]) - Method in class org.apache.reef.tests.fail.task.FailTaskSuspend
 
call(byte[]) - Method in class org.apache.reef.tests.group.MasterTask
 
call(byte[]) - Method in class org.apache.reef.tests.group.SlaveTask
 
call(byte[]) - Method in class org.apache.reef.tests.library.tasks.EchoTask
 
call(byte[]) - Method in class org.apache.reef.tests.library.tasks.NoopTask
 
call(byte[]) - Method in class org.apache.reef.tests.messaging.task.TaskMessagingTask
 
call(byte[]) - Method in class org.apache.reef.tests.statepassing.StatePassingTask
 
call(byte[]) - Method in class org.apache.reef.tests.watcher.WatcherTestTask
 
call(List<TOutput>) - Method in interface org.apache.reef.vortex.api.VortexAggregateFunction
Runs a custom local aggregation function on Tasklets assigned to a VortexWorker.
call(TInput) - Method in interface org.apache.reef.vortex.api.VortexFunction
 
call(byte[]) - Method in class org.apache.reef.vortex.evaluator.VortexWorker
Starts the scheduler and executor and waits until termination.
call(List<Integer>) - Method in class org.apache.reef.vortex.examples.sumones.AdditionAggregateFunction
 
call(Integer) - Method in class org.apache.reef.vortex.examples.sumones.IdentityFunction
Outputs input.
callClrSystemOnRestartHandler(DriverRestartedBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
callClrSystemOnStartHandler() - Static method in class org.apache.reef.javabridge.NativeInterop
 
cancel() - Method in class org.apache.reef.runtime.local.process.RunnableProcess
Cancels the running process if it is running.
cancel(boolean) - Method in class org.apache.reef.tang.InjectionFuture
 
cancel(boolean) - Method in class org.apache.reef.vortex.api.VortexFuture
Sends a cancel signal and blocks and waits until the task is cancelled, completed, or failed.
cancel(boolean, long, TimeUnit) - Method in class org.apache.reef.vortex.api.VortexFuture
Sends a cancel signal and blocks and waits until the task is cancelled, completed, or failed, or if the timeout has expired.
cancelled(int) - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
Not implemented for local aggregation.
cancelled(int) - Method in class org.apache.reef.vortex.api.VortexFuture
Called by VortexMaster to let the user know that the Tasklet was cancelled.
cancelled(int) - Method in interface org.apache.reef.vortex.driver.VortexFutureDelegate
A Tasklet associated with the Future has been cancelled.
cancelTask(int) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
Cancel a Task waiting on the queue.
cancelTasklet(boolean, int) - Method in interface org.apache.reef.vortex.driver.VortexMaster
Call this when a Tasklet is to be cancelled.
canParse(String) - Method in class org.apache.reef.tang.formats.ParameterParser
 
cause - Variable in class org.apache.reef.javabridge.avro.AvroFailedTask
Deprecated.
cell(String, String) - Method in class org.apache.reef.tang.util.Tint
 
cell(StringBuffer, String) - Method in class org.apache.reef.tang.util.Tint
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.reef.wake.remote.transport.netty.ChunkedReadWriteHandler
 
check() - Method in class org.apache.reef.runtime.common.driver.idle.EventHandlerIdlenessSource
 
checkAndSendTopologySetupMessage() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
Check if this node is ready for sending.
checkAndSendTopologySetupMessage() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
checkAndSendTopologySetupMessageFor(String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
Check if the neighbor node with id source.
checkAndSendTopologySetupMessageFor(String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
checkDead(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.ChildNodeStruct
 
checkDead(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
checkDead(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.ParentNodeStruct
 
CheckpointID - Interface in org.apache.reef.io.checkpoint
This class represent an identifier of a checkpoint.
CheckpointNamingService - Interface in org.apache.reef.io.checkpoint
This class represent a naming service for checkpoints.
CheckpointService - Interface in org.apache.reef.io.checkpoint
The CheckpointService provides a simple API to store and retrieve the state of a task.
CheckpointService.CheckpointReadChannel - Interface in org.apache.reef.io.checkpoint
A channel to read from a checkpoint.
CheckpointService.CheckpointWriteChannel - Interface in org.apache.reef.io.checkpoint
A channel to write to a checkpoint.
ChildAdd_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ChildAdd = 11;
ChildAdded_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ChildAdded = 15;
ChildDead_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ChildDead = 13;
ChildNodeStruct - Class in org.apache.reef.io.network.group.impl.task
 
ChildNodeStruct(String, int) - Constructor for class org.apache.reef.io.network.group.impl.task.ChildNodeStruct
 
ChildRemoved_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ChildRemoved = 17;
children - Variable in class org.apache.reef.tang.implementation.avro.AvroNode
Deprecated.
CHILDREN_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
ChunkedReadWriteHandler - Class in org.apache.reef.wake.remote.transport.netty
Thin wrapper around ChunkedWriteHandler.
ChunkedReadWriteHandler() - Constructor for class org.apache.reef.wake.remote.transport.netty.ChunkedReadWriteHandler
 
CLASS_HIERARCHY_FILENAME - Static variable in class org.apache.reef.examples.helloCLR.HelloCLR
The name of the class hierarchy file.
CLASS_NODE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
classAndAncestors(Type) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Given a Type, return all of the classes it extends and interfaces it implements (including the class itself).
classForName(String) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
Helper method that converts a String to a Class using this ClassHierarchy's classloader.
classForName(String) - Method in interface org.apache.reef.tang.JavaClassHierarchy
 
classForName(String, ClassLoader) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Lookup the provided name using the provided classloader.
ClassHierarchy - Interface in org.apache.reef.tang
ClassHierarchy objects store information about the interfaces and implementations that are available in a particular runtime environment.
ClassHierarchyException - Exception in org.apache.reef.tang.exceptions
This exception is thrown when Tang detects improper or inconsistent class annotations.
ClassHierarchyException(Throwable) - Constructor for exception org.apache.reef.tang.exceptions.ClassHierarchyException
 
ClassHierarchyException(String) - Constructor for exception org.apache.reef.tang.exceptions.ClassHierarchyException
 
ClassHierarchyException(String, Throwable) - Constructor for exception org.apache.reef.tang.exceptions.ClassHierarchyException
 
ClassHierarchyImpl - Class in org.apache.reef.tang.implementation.java
 
ClassHierarchyImpl() - Constructor for class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
ClassHierarchyImpl(URL...) - Constructor for class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
ClassHierarchyImpl(URL[], Class<? extends ExternalConstructor<?>>[]) - Constructor for class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
ClassHierarchyProto - Class in org.apache.reef.tang.proto
 
ClassHierarchyProto.ClassNode - Class in org.apache.reef.tang.proto
Protobuf type ClassNode
ClassHierarchyProto.ClassNode.Builder - Class in org.apache.reef.tang.proto
Protobuf type ClassNode
ClassHierarchyProto.ClassNodeOrBuilder - Interface in org.apache.reef.tang.proto
 
ClassHierarchyProto.ConstructorArg - Class in org.apache.reef.tang.proto
Protobuf type ConstructorArg
ClassHierarchyProto.ConstructorArg.Builder - Class in org.apache.reef.tang.proto
Protobuf type ConstructorArg
ClassHierarchyProto.ConstructorArgOrBuilder - Interface in org.apache.reef.tang.proto
 
ClassHierarchyProto.ConstructorDef - Class in org.apache.reef.tang.proto
Protobuf type ConstructorDef
ClassHierarchyProto.ConstructorDef.Builder - Class in org.apache.reef.tang.proto
Protobuf type ConstructorDef
ClassHierarchyProto.ConstructorDefOrBuilder - Interface in org.apache.reef.tang.proto
 
ClassHierarchyProto.NamedParameterNode - Class in org.apache.reef.tang.proto
Protobuf type NamedParameterNode
ClassHierarchyProto.NamedParameterNode.Builder - Class in org.apache.reef.tang.proto
Protobuf type NamedParameterNode
ClassHierarchyProto.NamedParameterNodeOrBuilder - Interface in org.apache.reef.tang.proto
 
ClassHierarchyProto.Node - Class in org.apache.reef.tang.proto
Protobuf type Node
ClassHierarchyProto.Node.Builder - Class in org.apache.reef.tang.proto
Protobuf type Node
ClassHierarchyProto.NodeOrBuilder - Interface in org.apache.reef.tang.proto
 
ClassHierarchyProto.PackageNode - Class in org.apache.reef.tang.proto
Protobuf type PackageNode
ClassHierarchyProto.PackageNode.Builder - Class in org.apache.reef.tang.proto
Protobuf type PackageNode
ClassHierarchyProto.PackageNodeOrBuilder - Interface in org.apache.reef.tang.proto
 
ClassHierarchySerializer - Interface in org.apache.reef.tang
A base interface for ClassHierarchy serializers.
className - Variable in class org.apache.reef.bridge.message.Header
Deprecated.
CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
classNode - Variable in class org.apache.reef.tang.implementation.avro.AvroNode
Deprecated.
ClassNode<T> - Interface in org.apache.reef.tang.types
 
ClassNodeImpl<T> - Class in org.apache.reef.tang.implementation.types
 
ClassNodeImpl(Node, String, String, boolean, boolean, boolean, ConstructorDef<T>[], ConstructorDef<T>[], String) - Constructor for class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
ClasspathProvider - Class in org.apache.reef.runtime.common.files
Supplies the classpath to REEF for process (Driver, Evaluator) launches.
classPrettyDefaultString(String) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Pretty print the default implementation / value of the provided class / NamedParameter.
classPrettyDefaultString(String) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
classPrettyDescriptionString(String) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Pretty print the human readable documentation of the provided class / NamedParameter.
classPrettyDescriptionString(String) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
clear() - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
clear() - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
clear() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
clear() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
clear() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
clear() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
clear() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
clear() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
clear() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
clear() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
clear() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
clear() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
clear() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
clear() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
clear() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
clear() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
clear() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
clear() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
clear() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
clear() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
clear() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
clear() - Method in class org.apache.reef.tang.util.MonotonicHashMap
 
clear() - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
clear() - Method in class org.apache.reef.tang.util.MonotonicSet
 
clear() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
clear() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
clear() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
clear() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
clear() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
clearActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Clears the value of the 'activeContext' field.
clearActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Clears the value of the 'activeContext' field.
clearActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Clears the value of the 'activeContext' field.
clearActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Clears the value of the 'activeContext' field.
clearAddContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
clearAliasLanguage() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_language = 9;
clearAliasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_name = 8;
clearArgs() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
clearArgs() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
clearAsError() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Clears the value of the 'asError' field.
clearBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Clears the value of the 'base' field.
clearBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Clears the value of the 'base' field.
clearBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Clears the value of the 'base' field.
clearBindings() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Clears the value of the 'Bindings' field.
clearCause() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Clears the value of the 'cause' field.
clearChildren() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Clears the value of the 'children' field.
clearChildren() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
clearClassName() - Method in class org.apache.reef.bridge.message.Header.Builder
Clears the value of the 'className' field.
clearClassName() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required string className = 1;
clearClassNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Clears the value of the 'classNode' field.
clearClassNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
clearCommand() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Clears the value of the 'command' field.
clearCommandLines() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Clears the value of the 'commandLines' field.
clearConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string configuration = 2;
clearConstructor() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
clearConstructorArgs() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Clears the value of the 'constructorArgs' field.
clearContextConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string context_configuration = 2;
clearContextControl() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
clearContextId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Clears the value of the 'contextId' field.
clearContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required string context_id = 1;
clearContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
required string context_id = 1;
clearContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string context_id = 1;
clearContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required string context_id = 2;
clearContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string context_id = 2;
clearContextMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
clearContextMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
clearContextState() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required .ContextStatusProto.State context_state = 1;
clearContextStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
clearCores() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Clears the value of the 'cores' field.
clearData() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
required bytes data = 1;
clearData() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
required bytes data = 1;
clearData() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Clears the value of the 'data' field.
clearData() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Clears the value of the 'data' field.
clearData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required bytes data = 1;
clearData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required bytes data = 2;
clearDateTime() - Method in class org.apache.reef.bridge.message.SystemOnStart.Builder
Clears the value of the 'dateTime' field.
clearDefaultImplementation() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'defaultImplementation' field.
clearDefaultImplementation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
optional string default_implementation = 7;
clearDefaultRuntimeName() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Clears the value of the 'defaultRuntimeName' field.
clearDefaultRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Clears the value of the 'defaultRuntimeName' field.
clearDescription() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Clears the value of the 'description' field.
clearDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string destid = 3;
clearDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string destid = 3;
clearDfsJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Clears the value of the 'dfsJobSubmissionFolder' field.
clearDocumentation() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'documentation' field.
clearDocumentation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string documentation = 5;
clearDoneEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
clearDriverMemory() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'driverMemory' field.
clearDriverRecoveryTimeout() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Clears the value of the 'driverRecoveryTimeout' field.
clearDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Clears the value of the 'driverStderrFilePath' field.
clearDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'driverStderrFilePath' field.
clearDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Clears the value of the 'driverStdoutFilePath' field.
clearDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'driverStdoutFilePath' field.
clearError() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bytes error = 5;
clearError() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
optional bytes error = 3;
clearEvaluatorControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
clearEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Clears the value of the 'evaluatorDescriptor' field.
clearEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Clears the value of the 'evaluatorDescriptor' field.
clearEvaluatorException() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Clears the value of the 'evaluatorException' field.
clearEvaluatorHeartBeat() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
clearEvaluatorId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Clears the value of the 'evaluatorId' field.
clearEvaluatorId() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required string evaluator_id = 1;
clearEvaluatorId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'evaluatorId' field.
clearEvaluatorLaunch() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Clears the value of the 'evaluator_launch' field.
clearEvaluatorRelease() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Clears the value of the 'evaluator_release' field.
clearEvaluators() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Clears the value of the 'evaluators' field.
clearEvaluatorsInfo() - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo.Builder
Clears the value of the 'evaluatorsInfo' field.
clearEvaluatorStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
clearEvaluatorType() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Clears the value of the 'evaluatorType' field.
clearException() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Clears the value of the 'exception' field.
clearException() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes exception = 4;
clearException() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional bytes exception = 3;
clearFailedContextList() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Clears the value of the 'failedContextList' field.
clearFailedTask() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Clears the value of the 'failedTask' field.
clearFailure() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Clears the value of the 'failure' field.
clearFailure() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Clears the value of the 'failure' field.
clearFileSystemUrl() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Clears the value of the 'fileSystemUrl' field.
clearFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Clears the value of the 'fullArgClassName' field.
clearFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'fullArgClassName' field.
clearFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required string full_arg_class_name = 1;
clearFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string full_arg_class_name = 2;
clearFullClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Clears the value of the 'fullClassName' field.
clearFullClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
required string full_class_name = 1;
clearFullName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Clears the value of the 'fullName' field.
clearFullName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string full_name = 2;
clearGet() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Clears the value of the 'get' field.
clearGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Clears the value of the 'get' field.
clearGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Clears the value of the 'get' field.
clearGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Clears the value of the 'get' field.
clearGroupname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string groupname = 4;
clearHeader() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Clears the value of the 'header' field.
clearHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Clears the value of the 'host' field.
clearHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Clears the value of the 'host' field.
clearHttpMethod() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Clears the value of the 'httpMethod' field.
clearHttpServerPortNumber() - Method in class org.apache.reef.bridge.message.SetupBridge.Builder
Clears the value of the 'httpServerPortNumber' field.
clearId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Clears the value of the 'id' field.
clearId() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Clears the value of the 'id' field.
clearIdentifier() - Method in class org.apache.reef.bridge.message.Header.Builder
Clears the value of the 'identifier' field.
clearIdentifier() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Clears the value of the 'identifier' field.
clearIdentifier() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
required string identifier = 1;
clearIdentifier() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required string identifier = 2;
clearIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required string identifier = 1;
clearIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional string identifier = 5;
clearIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Clears the value of the 'identifier' field.
clearIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease.Builder
Clears the value of the 'identifier' field.
clearIds() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest.Builder
Clears the value of the 'ids' field.
clearImplFullNames() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'implFullNames' field.
clearImplFullNames() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
clearInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Clears the value of the 'inetSocketAddress' field.
clearInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Clears the value of the 'inetSocketAddress' field.
clearInjectableConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'injectableConstructors' field.
clearInjectableConstructors() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
clearInputStream() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Clears the value of the 'inputStream' field.
clearInstance() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
clearInstanceDefault() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'instanceDefault' field.
clearInstanceDefault() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
clearInternetAddress() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'internetAddress' field.
clearIsExternalConstructor() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'isExternalConstructor' field.
clearIsExternalConstructor() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_external_constructor = 2;
clearIsInjectionCandidate() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'isInjectionCandidate' field.
clearIsInjectionCandidate() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_injection_candidate = 1;
clearIsInjectionFuture() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Clears the value of the 'isInjectionFuture' field.
clearIsInjectionFuture() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required bool is_injection_future = 3;
clearIsList() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'isList' field.
clearIsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_list = 4;
clearIsOptionSet() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Clears the value of the 'isOptionSet' field.
clearIsSet() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'isSet' field.
clearIsSet() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_set = 3;
clearIsUnit() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'isUnit' field.
clearIsUnit() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_unit = 3;
clearJobControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
clearJobId() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Clears the value of the 'jobId' field.
clearJobStatus() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
clearJobSubmissionDirectoryPrefix() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Clears the value of the 'jobSubmissionDirectoryPrefix' field.
clearJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Clears the value of the 'jobSubmissionFolder' field.
clearKey() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Clears the value of the 'key' field.
clearKey() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Clears the value of the 'key' field.
clearKillEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
clearLanguage() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Clears the value of the 'language' field.
clearList() - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
Clear all the Tasks from the waiting queue.
clearLoad() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required double load = 2;
clearLocalRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Clears the value of the 'localRuntimeAppParameters' field.
clearMaxApplicationSubmissions() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'maxApplicationSubmissions' field.
clearMaxNumberOfConcurrentEvaluators() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Clears the value of the 'maxNumberOfConcurrentEvaluators' field.
clearMegaBytes() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Clears the value of the 'megaBytes' field.
clearMemory() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Clears the value of the 'memory' field.
clearMemory() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'memory' field.
clearMessage() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Clears the value of the 'message' field.
clearMessage() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Clears the value of the 'message' field.
clearMessage() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Clears the value of the 'message' field.
clearMessage() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional bytes message = 3;
clearMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required bytes message = 2;
clearMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required bytes message = 2;
clearMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes message = 3;
clearMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string message = 2;
clearMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required bytes message = 2;
clearMessage() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required string message = 1;
clearMessageIdentifier() - Method in class org.apache.reef.bridge.message.Acknowledgement.Builder
Clears the value of the 'messageIdentifier' field.
clearMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Clears the value of the 'messageSourceId' field.
clearMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Clears the value of the 'messageSourceId' field.
clearMessageType() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Clears the value of the 'messageType' field.
clearMsgs() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
clearMsgs() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
clearName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Clears the value of the 'name' field.
clearName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Clears the value of the 'name' field.
clearName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Clears the value of the 'name' field.
clearName() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string name = 1;
clearName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Clears the value of the 'name' field.
clearName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string name = 1;
clearName() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
required string name = 1;
clearName() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Clears the value of the 'name' field.
clearNamedParameterName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Clears the value of the 'namedParameterName' field.
clearNamedParameterName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
optional string named_parameter_name = 2;
clearNamedParameterNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Clears the value of the 'namedParameterNode' field.
clearNamedParameterNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
clearNodeDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Clears the value of the 'nodeDescriptor' field.
clearNodeId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'nodeId' field.
clearNodeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'nodeName' field.
clearNodeNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Clears the value of the 'nodeNames' field.
clearNodes() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Clears the value of the 'nodes' field.
clearNumber() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Clears the value of the 'number' field.
clearNumberOfCores() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Clears the value of the 'numberOfCores' field.
clearOffset() - Method in class org.apache.reef.bridge.message.Protocol.Builder
Clears the value of the 'offset' field.
clearOperatorname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string operatorname = 5;
clearOtherConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Clears the value of the 'otherConstructors' field.
clearOtherConstructors() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
clearPackageNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Clears the value of the 'packageNode' field.
clearPackageNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
clearParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Clears the value of the 'parentContext' field.
clearParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Clears the value of the 'parentContext' field.
clearParentContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string parent_context_id = 1;
clearParentId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Clears the value of the 'parentId' field.
clearParentId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional string parent_id = 3;
clearPathInfo() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Clears the value of the 'pathInfo' field.
clearPlans() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
clearPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Clears the value of the 'port' field.
clearPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Clears the value of the 'port' field.
clearProcess() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Clears the value of the 'process' field.
clearQueryString() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Clears the value of the 'queryString' field.
clearRackDescriptor() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Clears the value of the 'rackDescriptor' field.
clearRackNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Clears the value of the 'rackNames' field.
clearReason() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Clears the value of the 'reason' field.
clearRecovery() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional bool recovery = 5;
clearRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bool recovery = 6;
clearRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bool recovery = 5;
clearRemoteId() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Clears the value of the 'remoteId' field.
clearRemoveContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
clearRequestUrl() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Clears the value of the 'requestUrl' field.
clearResult() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bytes result = 4;
clearRuntimeError() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
clearRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Clears the value of the 'runtimeName' field.
clearRuntimeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'runtimeName' field.
clearRuntimeNames() - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes.Builder
Clears the value of the 'runtimeNames' field.
clearRuntimes() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Clears the value of the 'runtimes' field.
clearRuntimes() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Clears the value of the 'runtimes' field.
clearSecurityTokenKind() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'securityTokenKind' field.
clearSecurityTokenService() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'securityTokenService' field.
clearSelectedPlan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
optional sint32 selected_plan = 1;
clearSeq() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required int64 seq = 2;
clearSequence() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Clears the value of the 'sequence' field.
clearSerializedConfiguration() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Clears the value of the 'serializedConfiguration' field.
clearServiceConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
optional string service_configuration = 3;
clearServiceInfo() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Clears the value of the 'serviceInfo' field.
clearServiceName() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Clears the value of the 'serviceName' field.
clearServices() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Clears the value of the 'services' field.
clearSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Clears the value of the 'sharedAppSubmissionParameters' field.
clearSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Clears the value of the 'sharedAppSubmissionParameters' field.
clearSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Clears the value of the 'sharedAppSubmissionParameters' field.
clearSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Clears the value of the 'sharedJobSubmissionParameters' field.
clearSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Clears the value of the 'sharedJobSubmissionParameters' field.
clearShortName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'shortName' field.
clearShortName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string short_name = 6;
clearSignal() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional .Signal signal = 2;
clearSimpleArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Clears the value of the 'simpleArgClassName' field.
clearSimpleArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string simple_arg_class_name = 1;
clearSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required string source_id = 1;
clearSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required string source_id = 1;
clearSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string srcid = 2;
clearSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string srcid = 2;
clearSrcVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 srcVersion = 7;
clearStartTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
clearStartTime() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Clears the value of the 'startTime' field.
clearStartTime() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Clears the value of the 'startTime' field.
clearState() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required .State state = 2;
clearState() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required .State state = 2;
clearState() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required .State state = 3;
clearStateAndReleaseLocks() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
Used when the task has failed to clear all.
clearStateAndReleaseLocks() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
clearStopEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
clearStopTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
clearSubplan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
clearSuspendTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
clearTaskId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string task_id = 1;
clearTaskMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional bytes task_message = 1;
clearTaskMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
clearTaskStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
clearTcpBeginPort() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Clears the value of the 'tcpBeginPort' field.
clearTcpRangeCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Clears the value of the 'tcpRangeCount' field.
clearTcpTryCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Clears the value of the 'tcpTryCount' field.
clearTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime.Builder
Clears the value of the 'timestamp' field.
clearTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime.Builder
Clears the value of the 'timestamp' field.
clearTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart.Builder
Clears the value of the 'timestamp' field.
clearTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Clears the value of the 'timestamp' field.
clearTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required int64 timestamp = 1;
clearTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required int64 timestamp = 1;
clearTotal() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Clears the value of the 'total' field.
clearTuples() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse.Builder
Clears the value of the 'tuples' field.
clearType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required .GroupCommMessage.Type type = 1;
clearType() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Clears the value of the 'type' field.
clearValue() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Clears the value of the 'value' field.
clearValue() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
required string value = 1;
clearValue() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Clears the value of the 'value' field.
clearVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 version = 6;
clearYarnJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Clears the value of the 'yarnJobSubmissionParameters' field.
clearYarnRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Clears the value of the 'yarnRuntimeAppParameters' field.
Client - Class in org.apache.reef.tests.fail.task
Client for the test REEF job that fails on different stages of execution.
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
The client remote identifier.
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The remote identifier to use for communications back to the client.
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
The client remote identifier.
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.multi.driver.MultiRuntimeDriverConfiguration
The identifier of the Job submitted.
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
The remote identifier to use for communications back to the client.
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
CLIENT_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
The client remote identifier.
ClientAlarm - Class in org.apache.reef.wake.time.runtime.event
An event for client-created alarm.
ClientAlarm(long, EventHandler<Alarm>) - Constructor for class org.apache.reef.wake.time.runtime.event.ClientAlarm
 
ClientCloseHandlers - Class in org.apache.reef.driver.parameters
Handles close requests from the client.
ClientCloseWithMessageHandlers - Class in org.apache.reef.driver.parameters
Handles client close requests.
ClientConfiguration - Class in org.apache.reef.client
A ConfigurationModule to fill out for the client configuration.
ClientConfiguration() - Constructor for class org.apache.reef.client.ClientConfiguration
 
ClientConnection - Class in org.apache.reef.runtime.common.driver.client
Represents the communication channel to the client.
ClientConnection(String, JobStatusHandler) - Constructor for class org.apache.reef.runtime.common.driver.client.ClientConnection
 
ClientManager - Class in org.apache.reef.runtime.common.driver.client
Represents the Client in the Driver.
ClientMessageHandlers - Class in org.apache.reef.driver.parameters
Handles message from the Client.
ClientPresent - Class in org.apache.reef.runtime.common.client.parameters
A Tang named parameter that indicates whether or not a client (handler for the various Job events) is present.
ClientRemoteIdentifier - Class in org.apache.reef.runtime.common.driver.parameters
The client remote identifier.
ClientRuntimeParameters - Class in org.apache.reef.runtime.common.client.api
Parameters used by client runtime.
ClientRuntimeParameters() - Constructor for class org.apache.reef.runtime.common.client.api.ClientRuntimeParameters
 
ClientRuntimeParameters.RuntimeErrorHandlerRID - Class in org.apache.reef.runtime.common.client.api
The runtime error handler RID.
ClientRuntimeParameters.RuntimeErrorHandlerRID() - Constructor for class org.apache.reef.runtime.common.client.api.ClientRuntimeParameters.RuntimeErrorHandlerRID
 
ClientRuntimeProtocol - Class in org.apache.reef.proto
 
ClientRuntimeProtocol.JobControlProto - Class in org.apache.reef.proto
Protobuf type JobControlProto
ClientRuntimeProtocol.JobControlProto.Builder - Class in org.apache.reef.proto
Protobuf type JobControlProto
ClientRuntimeProtocol.JobControlProtoOrBuilder - Interface in org.apache.reef.proto
 
ClientRuntimeProtocol.Signal - Enum in org.apache.reef.proto
Protobuf enum Signal
ClientSide - Annotation Type in org.apache.reef.annotations.audience
Annotates interface meant to be used by REEF clients.
ClientSideFailure - Exception in org.apache.reef.tests.library.exceptions
Thrown when a test fails on the client side.
ClientSideFailure() - Constructor for exception org.apache.reef.tests.library.exceptions.ClientSideFailure
 
ClientSideFailure(String) - Constructor for exception org.apache.reef.tests.library.exceptions.ClientSideFailure
 
ClientSideFailure(String, Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.ClientSideFailure
 
ClientSideFailure(Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.ClientSideFailure
 
Clock - Interface in org.apache.reef.wake.time
Represents a clock.
Clock.IdleHandler - Class in org.apache.reef.wake.time
Bind this to an event handler to statically subscribe to the IdleClock Event.
Clock.IdleHandler() - Constructor for class org.apache.reef.wake.time.Clock.IdleHandler
 
Clock.RuntimeStartHandler - Class in org.apache.reef.wake.time
Bind this to an event handler to statically subscribe to the RuntimeStart Event.
Clock.RuntimeStartHandler() - Constructor for class org.apache.reef.wake.time.Clock.RuntimeStartHandler
 
Clock.RuntimeStopHandler - Class in org.apache.reef.wake.time
Bind this to an event handler to statically subscribe to the RuntimeStart Event.
Clock.RuntimeStopHandler() - Constructor for class org.apache.reef.wake.time.Clock.RuntimeStopHandler
 
Clock.StartHandler - Class in org.apache.reef.wake.time
Bind this to an event handler to statically subscribe to the StartTime Event.
Clock.StartHandler() - Constructor for class org.apache.reef.wake.time.Clock.StartHandler
 
Clock.StopHandler - Class in org.apache.reef.wake.time
Bind this to an event handler to statically subscribe to the StopTime Event.
Clock.StopHandler() - Constructor for class org.apache.reef.wake.time.Clock.StopHandler
 
ClockConfigurationPath - Class in org.apache.reef.runtime.common.launch.parameters
The path to the clock configuration.
ClockIdlenessSource - Class in org.apache.reef.runtime.common.driver.idle
Informs the DriverIdleManager of clock idleness.
clone() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
clone() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
clone() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
clone() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
clone() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
clone() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
clone() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
clone() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
clone() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
clone() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
clone() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
clone() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
clone() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
clone() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
clone() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
clone() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
clone() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
clone() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
clone() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
clone() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
clone() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
close() - Method in class org.apache.reef.client.DriverLauncher
Kills the running job.
close() - Method in interface org.apache.reef.client.REEF
Close the resourcemanager connection.
close() - Method in interface org.apache.reef.client.RunningJob
Cancels the running Job.
close(byte[]) - Method in interface org.apache.reef.client.RunningJob
Cancels the running Job.
close() - Method in interface org.apache.reef.driver.context.ActiveContext
 
close() - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
Releases the allocated evaluator back to the resource manager.
close() - Method in class org.apache.reef.driver.restart.DriverRestartManager
Close the restart timer.
close(byte[]) - Method in interface org.apache.reef.driver.task.RunningTask
Signal the task to shut down.
close() - Method in interface org.apache.reef.driver.task.RunningTask
Signal the task to shut down.
close() - Method in class org.apache.reef.examples.group.utils.timer.Timer
 
close() - Method in class org.apache.reef.examples.suspend.SuspendClientControl
 
close() - Method in interface org.apache.reef.io.Accumulator
 
close() - Method in interface org.apache.reef.io.data.output.OutputStreamProvider
release resources.
close() - Method in class org.apache.reef.io.data.output.TaskOutputStreamProviderHDFS
 
close() - Method in class org.apache.reef.io.data.output.TaskOutputStreamProviderLocal
 
close() - Method in interface org.apache.reef.io.network.Connection
Closes the connection.
close() - Method in class org.apache.reef.io.network.impl.NetworkConnectionServiceImpl
 
close() - Method in class org.apache.reef.io.network.impl.NetworkService
 
close() - Method in class org.apache.reef.io.network.naming.LocalNameResolverImpl
 
close() - Method in class org.apache.reef.io.network.naming.NameClient
Closes resources.
close() - Method in class org.apache.reef.io.network.naming.NameLookupClient
Closes resources.
close() - Method in class org.apache.reef.io.network.naming.NameRegistryClient
Closes resources.
close() - Method in class org.apache.reef.io.network.naming.NameServerImpl
Closes resources.
close() - Method in interface org.apache.reef.io.network.NetworkConnectionService
Closes all resources and unregisters all registered connection factories.
close() - Method in class org.apache.reef.io.storage.FramingOutputStream
 
close() - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
close() - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
Closes the Java AllocatedEvaluator.
close() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
close() - Method in class org.apache.reef.javabridge.CompletedEvaluatorBridge
 
close() - Method in class org.apache.reef.javabridge.CompletedTaskBridge
 
close() - Method in class org.apache.reef.javabridge.ContextMessageBridge
 
close() - Method in class org.apache.reef.javabridge.DriverRestartedBridge
 
close() - Method in class org.apache.reef.javabridge.EvaluatorRequestorBridge
 
close() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
close() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
close() - Method in class org.apache.reef.javabridge.FailedTaskBridge
 
close() - Method in class org.apache.reef.javabridge.generic.DriverRestartCompletedBridge
 
close(long) - Method in class org.apache.reef.javabridge.generic.JobClient
 
close() - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
close(byte[]) - Method in class org.apache.reef.javabridge.RunningTaskBridge
 
close() - Method in class org.apache.reef.javabridge.RunningTaskBridge
 
close() - Method in class org.apache.reef.javabridge.SuspendedTaskBridge
 
close() - Method in class org.apache.reef.javabridge.TaskMessageBridge
 
close() - Method in class org.apache.reef.runtime.common.client.REEFImplementation
 
close() - Method in class org.apache.reef.runtime.common.client.RunningJobImpl
 
close(byte[]) - Method in class org.apache.reef.runtime.common.client.RunningJobImpl
 
close() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
close() - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
close() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorIdlenessThreadPool
Shutdown the thread pool of idleness checkers.
close() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
 
close() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
close() - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
Closes all EvaluatorManager instances managed.
close() - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
close(byte[]) - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
close() - Method in class org.apache.reef.runtime.common.evaluator.context.ContextManager
Shuts down.
close() - Method in class org.apache.reef.runtime.common.evaluator.DefaultDriverConnection
 
close(byte[]) - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
Close the Task.
close() - Method in class org.apache.reef.runtime.common.launch.REEFErrorHandler
 
close() - Method in class org.apache.reef.runtime.common.REEFEnvironment
Close and cleanup the environment.
close() - Method in class org.apache.reef.runtime.common.utils.DispatchingEStage
Close the stage adn stop accepting new messages.
close() - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
close() - Method in class org.apache.reef.runtime.hdinsight.client.HDInsightJobSubmissionHandler
 
close() - Method in class org.apache.reef.runtime.local.client.LocalJobSubmissionHandler
 
close() - Method in interface org.apache.reef.runtime.local.driver.Container
Kills the Container.
close() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
close() - Method in class org.apache.reef.runtime.standalone.driver.RemoteNodeManager
 
close() - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
 
close() - Method in class org.apache.reef.runtime.yarn.driver.REEFEventHandlers
 
close() - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogAppendReaderWriter
Closes the FileSystem.
close() - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogOverwriteReaderWriter
Closes the FileSystem.
close() - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorPreserver
Closes the readerWriter, which in turn closes the FileSystem.
close() - Method in class org.apache.reef.tests.messaging.driver.DriverMessaging
 
close() - Method in class org.apache.reef.tests.TestDriverLauncher
 
close() - Method in class org.apache.reef.util.JARFileMaker
 
close() - Method in class org.apache.reef.util.logging.CLRBufferedLogHandler
Flushes the remaining buffered logs and shuts down the log scheduler thread.
close() - Method in class org.apache.reef.util.logging.DFSHandler
 
close() - Method in interface org.apache.reef.util.logging.LoggingScope
 
close() - Method in class org.apache.reef.util.logging.LoggingScopeImpl
The close() will be called when the object is to deleted.
close() - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage
 
close() - Method in class org.apache.reef.wake.examples.join.TupleSource
 
close() - Method in class org.apache.reef.wake.examples.p2p.Pull2Push
 
close() - Method in class org.apache.reef.wake.impl.ForkPoolStage
 
close() - Method in class org.apache.reef.wake.impl.IndependentIterationsThreadPoolStage
 
close() - Method in class org.apache.reef.wake.impl.SingleThreadStage
Closes the stage.
close() - Method in class org.apache.reef.wake.impl.StageManager
 
close() - Method in class org.apache.reef.wake.impl.SyncStage
Closes resources.
close() - Method in class org.apache.reef.wake.impl.ThreadPoolStage
Closes resources.
close() - Method in class org.apache.reef.wake.impl.TimerStage
Closes resources.
close() - Method in class org.apache.reef.wake.impl.WakeSharedPool
 
close() - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
 
close() - Method in class org.apache.reef.wake.remote.impl.DefaultTransportEStage
 
close() - Method in class org.apache.reef.wake.remote.impl.OrderedRemoteReceiverStage
 
close() - Method in class org.apache.reef.wake.remote.impl.RemoteReceiverStage
Closes the stage.
close() - Method in class org.apache.reef.wake.remote.impl.RemoteSenderStage
Closes the stage.
close() - Method in class org.apache.reef.wake.remote.impl.Subscription
Deprecated.
Unsubscribes this subscription.
close() - Method in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Closes all channels and releases all resources.
close() - Method in class org.apache.reef.wake.rx.impl.RxSyncStage
Closes the stage.
close() - Method in class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Closes the stage.
close() - Method in interface org.apache.reef.wake.time.Clock
This will stop the clock after all client alarms finish executing.
close() - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
Wait for all client alarms to finish executing and gracefully shutdown the clock.
CloseableIterable<T> - Interface in org.apache.reef.util
An iterable that is closeable.
ClosedContext - Interface in org.apache.reef.driver.context
Represents a Context that has been closed successfully.
closedContext(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling closedContext handler.
ClosedContextBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for ClosedContext.
ClosedContextBridge(ClosedContext, ActiveContextBridgeFactory) - Constructor for class org.apache.reef.javabridge.ClosedContextBridge
 
ClosedContextImpl - Class in org.apache.reef.runtime.common.driver.context
Driver side representation of a closed context.
ClosedContextImpl(ActiveContext, String, String, EvaluatorDescriptor) - Constructor for class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
CloseEvent - Interface in org.apache.reef.task.events
Indicates that the driver called .close() on this Task.
clrBufferedLog(int, String) - Static method in class org.apache.reef.javabridge.NativeInterop
 
CLRBufferedLogHandler - Class in org.apache.reef.util.logging
Logging Handler to intercept java logs and transfer them to the CLR side via the reef-bridge.
CLRBufferedLogHandler() - Constructor for class org.apache.reef.util.logging.CLRBufferedLogHandler
 
CLRLaunchCommandBuilder - Class in org.apache.reef.runtime.common.launch
A builder for the command line to launch a CLR Evaluator.
CLRLaunchCommandBuilder() - Constructor for class org.apache.reef.runtime.common.launch.CLRLaunchCommandBuilder
 
CLRLoggingConfig - Class in org.apache.reef.util.logging
Loader for CLR logging configuration.
CLRLoggingConfig() - Constructor for class org.apache.reef.util.logging.CLRLoggingConfig
 
CLRProcess - Class in org.apache.reef.driver.evaluator
Defines the setup of a CLR process.
CLRProcessFactory - Class in org.apache.reef.driver.evaluator
Factory to setup new CLR processes.
clrSystemActiveContextHandlerOnNext(long, ActiveContextBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemAllocatedEvaluatorHandlerOnNext(long, AllocatedEvaluatorBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemClosedContextHandlerOnNext(long, ClosedContextBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemCompletedEvaluatorHandlerOnNext(long, CompletedEvaluatorBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemCompletedTaskHandlerOnNext(long, CompletedTaskBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemContextMessageHandlerOnNext(long, ContextMessageBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemDriverRestartActiveContextHandlerOnNext(long, ActiveContextBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemDriverRestartCompletedHandlerOnNext(long, DriverRestartCompletedBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemDriverRestartFailedEvaluatorHandlerOnNext(long, FailedEvaluatorBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemDriverRestartRunningTaskHandlerOnNext(long, RunningTaskBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemFailedContextHandlerOnNext(long, FailedContextBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemFailedEvaluatorHandlerOnNext(long, FailedEvaluatorBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemFailedTaskHandlerOnNext(long, FailedTaskBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemHttpServerHandlerOnNext(long, HttpServerEventBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemProgressProviderGetProgress(long) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemRunningTaskHandlerOnNext(long, RunningTaskBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemSetupBridgeHandlerManager(String, BridgeHandlerManager, EvaluatorRequestorBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemSuspendedTaskHandlerOnNext(long, SuspendedTaskBridge) - Static method in class org.apache.reef.javabridge.NativeInterop
 
clrSystemTaskMessageHandlerOnNext(long, byte[], TaskMessageBridge, InteropLogger) - Static method in class org.apache.reef.javabridge.NativeInterop
 
CLUSTER_ID - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
CODEC - Static variable in class org.apache.reef.examples.hellohttp.HttpShellJobDriver
String codec is used to encode the results before passing them back to the client.
CODEC - Static variable in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
 
Codec<T> - Interface in org.apache.reef.io.serialization
Interface for serialization routines that translate back and forth between byte arrays with low latency.
Codec<T> - Interface in org.apache.reef.wake.remote
Interface for serialization routines that translate back and forth between byte arrays with low latency.
CodecFileAccumulable<T,C extends Codec<T>> - Class in org.apache.reef.io.storage.local
 
CodecFileAccumulable(LocalStorageService, C) - Constructor for class org.apache.reef.io.storage.local.CodecFileAccumulable
 
CodecFileIterable<T,C extends Codec<T>> - Class in org.apache.reef.io.storage.local
A read-only spool implementation, based on files.
CodecFileIterable(File, C) - Constructor for class org.apache.reef.io.storage.local.CodecFileIterable
 
CodecRamMap<T> - Class in org.apache.reef.io.storage.ram
 
CodecRamMap(RamStorageService, Codec<T>) - Constructor for class org.apache.reef.io.storage.ram.CodecRamMap
 
CodecRamMap.RamMapCodec - Class in org.apache.reef.io.storage.ram
 
CodecRamMap.RamMapCodec() - Constructor for class org.apache.reef.io.storage.ram.CodecRamMap.RamMapCodec
 
CollectionUtils - Class in org.apache.reef.util
Utility functions for arrays and collection classes.
combine(K, V, V) - Method in interface org.apache.reef.wake.examples.accumulate.CombinerStage.Combiner
 
CombinerStage<K extends Comparable<K>,V> - Class in org.apache.reef.wake.examples.accumulate
key-value pair Combiner stage.
CombinerStage(CombinerStage.Combiner<K, V>, Observer<Map.Entry<K, V>>) - Constructor for class org.apache.reef.wake.examples.accumulate.CombinerStage
 
CombinerStage.Combiner<K extends Comparable<K>,V> - Interface in org.apache.reef.wake.examples.accumulate
key-value pair Combiner Interface.
CombinerStage.Pair<K extends Comparable<K>,V> - Class in org.apache.reef.wake.examples.accumulate
A comparable key-value pair.
CombinerStage.Pair(K, V) - Constructor for class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
Command - Class in org.apache.reef.examples.library
Command line parameter: a command to run, e.g.
Command() - Constructor for class org.apache.reef.examples.library.Command
 
COMMAND - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
command - Variable in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Deprecated.
CommandLine - Class in org.apache.reef.tang.formats
 
CommandLine() - Constructor for class org.apache.reef.tang.formats.CommandLine
 
CommandLine(ConfigurationBuilder) - Constructor for class org.apache.reef.tang.formats.CommandLine
 
CommandLine.CommandLineCallback - Interface in org.apache.reef.tang.formats
 
commandLines - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Deprecated.
Commands - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Commands used to start an Application Master via the YARN Resource Manger REST API.
Commands() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.Commands
 
COMMANDS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
CommandUtils - Class in org.apache.reef.util
run given command and return the result as string.
CommGroupMessageHandler - Class in org.apache.reef.io.network.group.impl.config.parameters
Name class of the comm group message handler.
CommGroupNameClass - Class in org.apache.reef.io.network.group.impl.config.parameters
NamedParameter wrapper for the name class of the comm group.
CommGroupNetworkHandler - Interface in org.apache.reef.io.network.group.api.task
The EventHandler that receives the GroupCommunicationMsg.
CommGroupNetworkHandlerImpl - Class in org.apache.reef.io.network.group.impl.task
 
CommGroupNetworkHandlerImpl() - Constructor for class org.apache.reef.io.network.group.impl.task.CommGroupNetworkHandlerImpl
 
CommGroupNumTask - Class in org.apache.reef.io.network.group.impl.config.parameters
Name class of the number of tasks in the comm group.
commit(CheckpointService.CheckpointWriteChannel) - Method in interface org.apache.reef.io.checkpoint.CheckpointService
Closes an existing checkpoint for writes and returns the CheckpointID that can be later used to get the read-only access to this checkpoint.
commit(CheckpointService.CheckpointWriteChannel) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointService
 
CommonRuntimeConfiguration - Class in org.apache.reef.runtime.common.client
A ConfigurationModule to be merged in by all runtimes into their client configuration.
CommonRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.common.client.CommonRuntimeConfiguration
 
CommunicationGroupClient - Interface in org.apache.reef.io.network.group.api.task
The Task side interface of a communication group.
CommunicationGroupClientImpl - Class in org.apache.reef.io.network.group.impl.task
 
CommunicationGroupDriver - Interface in org.apache.reef.io.network.group.api.driver
The driver side interface of a Communication Group Lets one add operators and tasks.
CommunicationGroupDriverFactory - Class in org.apache.reef.io.network.group.impl.driver
A factory used to create CommunicationGroupDriver instance.
CommunicationGroupDriverImpl - Class in org.apache.reef.io.network.group.impl.driver
 
CommunicationGroupDriverImpl(Class<? extends Name<String>>, ConfigurationSerializer, EStage<GroupCommunicationMessage>, BroadcastingEventHandler<RunningTask>, BroadcastingEventHandler<FailedTask>, BroadcastingEventHandler<FailedEvaluator>, BroadcastingEventHandler<GroupCommunicationMessage>, String, int, int) - Constructor for class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
Deprecated.
in 0.14. Use Tang to obtain an instance of this instead.
CommunicationGroupName - Class in org.apache.reef.io.network.group.impl.config.parameters
 
CommunicationGroupServiceClient - Interface in org.apache.reef.io.network.group.api.task
 
ComparableIdentifier - Interface in org.apache.reef.wake
Identifier that can be totally ordered.
compare(Tuple<K, V>, Tuple<K, V>) - Method in class org.apache.reef.io.storage.util.TupleKeyComparator
 
compare(RemoteEvent<T>, RemoteEvent<T>) - Method in class org.apache.reef.wake.remote.impl.RemoteEventComparator
 
compareTo(NumberedSplit<E>) - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
compareTo(Identifier) - Method in class org.apache.reef.io.network.util.StringIdentifier
 
compareTo(Node) - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
compareTo(ConstructorDef<?>) - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
compareTo(Map.Entry<K, V>) - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
compareTo(TupleEvent) - Method in class org.apache.reef.wake.examples.join.TupleEvent
 
compareTo(Time) - Method in class org.apache.reef.wake.time.Time
 
COMPLETED - Static variable in class org.apache.reef.client.LauncherStatus
 
completed(int, TOutput) - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
A Tasklet associated with the aggregation has completed.
completed(int, TOutput) - Method in class org.apache.reef.vortex.api.VortexFuture
Called by VortexMaster to let the user know that the Tasklet completed.
completed(int, TOutput) - Method in interface org.apache.reef.vortex.driver.VortexFutureDelegate
A Tasklet associated with the future has completed with a result.
CompletedEvaluator - Interface in org.apache.reef.driver.evaluator
Represents a successfully closed Evaluator.
CompletedEvaluatorBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for CompletedEvaluator.
CompletedEvaluatorBridge(CompletedEvaluator) - Constructor for class org.apache.reef.javabridge.CompletedEvaluatorBridge
 
CompletedJob - Interface in org.apache.reef.client
Represents a completed REEF job.
CompletedTask - Interface in org.apache.reef.driver.task
Represents a completed Task.
CompletedTaskBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for CompletedTask.
CompletedTaskBridge(CompletedTask, ActiveContextBridgeFactory) - Constructor for class org.apache.reef.javabridge.CompletedTaskBridge
 
CompletedTaskImpl - Class in org.apache.reef.runtime.common.driver.task
Implementation of CompletedTask.
CompletedTaskImpl(ActiveContext, byte[], String) - Constructor for class org.apache.reef.runtime.common.driver.task.CompletedTaskImpl
 
computeGradient(double, double) - Method in class org.apache.reef.examples.group.bgd.loss.LogisticLossFunction
 
computeGradient(double, double) - Method in interface org.apache.reef.examples.group.bgd.loss.LossFunction
Computes the gradient with respect to f, if y is the true label.
computeGradient(double, double) - Method in class org.apache.reef.examples.group.bgd.loss.SquaredErrorLossFunction
 
computeGradient(double, double) - Method in class org.apache.reef.examples.group.bgd.loss.WeightedLogisticLossFunction
 
computeLoss(double, double) - Method in class org.apache.reef.examples.group.bgd.loss.LogisticLossFunction
 
computeLoss(double, double) - Method in interface org.apache.reef.examples.group.bgd.loss.LossFunction
Computes the loss incurred by predicting f, if y is the true label.
computeLoss(double, double) - Method in class org.apache.reef.examples.group.bgd.loss.SquaredErrorLossFunction
 
computeLoss(double, double) - Method in class org.apache.reef.examples.group.bgd.loss.WeightedLogisticLossFunction
 
ConcurrentCountingMap<K,V> - Class in org.apache.reef.io.network.group.impl.utils
Utility map class that wraps a CountingMap.
ConcurrentCountingMap() - Constructor for class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
CONF - Static variable in class org.apache.reef.client.ClientConfiguration
 
CONF - Static variable in class org.apache.reef.client.DriverConfiguration
ConfigurationModule to fill out to get a legal Driver Configuration.
CONF - Static variable in class org.apache.reef.client.DriverRestartConfiguration
 
CONF - Static variable in class org.apache.reef.client.DriverServiceConfiguration
ConfigurationModule to fill out to get a legal Driver Configuration.
CONF - Static variable in class org.apache.reef.driver.context.ContextConfiguration
A ConfigurationModule for context.
CONF - Static variable in class org.apache.reef.driver.context.ServiceConfiguration
ConfigurationModule for services.
CONF - Static variable in class org.apache.reef.driver.task.TaskConfiguration
ConfigurationModule to fill out for a Task configuration.
CONF - Static variable in class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration
 
CONF - Static variable in class org.apache.reef.io.data.loading.api.DataLoadingDriverConfiguration
 
CONF - Static variable in class org.apache.reef.io.data.output.TaskOutputServiceBuilder
 
CONF - Static variable in class org.apache.reef.io.network.naming.LocalNameResolverConfiguration
 
CONF - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
 
CONF - Static variable in class org.apache.reef.io.network.naming.NameServerConfiguration
 
CONF - Static variable in class org.apache.reef.io.watcher.WatcherConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.common.client.CommonRuntimeConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.common.driver.DriverRuntimeConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.common.driver.DriverRuntimeRestartConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
This is ConfigurationModule for Java Evaluator.
CONF - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfigurationStatic
 
CONF - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfigurationStatic
 
CONF - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
The ConfigurationModule for the local resourcemanager.
CONF - Static variable in class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
The ConfigurationModule for the local resourcemanager.
CONF - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.mesos.client.MesosClientConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.multi.driver.MultiRuntimeDriverConfiguration
Hybrid driver configuration.
CONF - Static variable in class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
The ConfigurationModule for the standalone resourcemanager.
CONF - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnClientConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.yarn.client.YarnDriverConfiguration
ConfigurationModule to set YARN-Specific configuration options to be merged with DriverConfiguration.
CONF - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
CONF - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverRestartConfiguration
This event is fired in place of the ON_DRIVER_STARTED when the Driver is in fact restarted after failure.
CONF - Static variable in class org.apache.reef.tang.examples.timer.TimerMock
 
CONF - Static variable in class org.apache.reef.tests.driver.RuntimeNameTestConfiguration
 
CONF - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Vortex Master configuration.
CONF - Static variable in class org.apache.reef.vortex.driver.VortexWorkerConf
Vortex Worker configuration.
CONF - Static variable in class org.apache.reef.webserver.HttpHandlerConfiguration
HttpHandlerConfiguration merged with HttpRuntimeConfiguration.
CONF - Static variable in class org.apache.reef.webserver.HttpRuntimeConfiguration
HttpRuntimeConfiguration.
CONFCLR - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
This is ConfigurationModule for CLR Evaluator.
Config - Class in org.apache.reef.util.logging
Wrapper for logging config.
Config() - Constructor for class org.apache.reef.util.logging.Config
 
ConfigurableDirectoryTempFileCreator - Class in org.apache.reef.io
Creates temp files in a directory named "temp" within the configured directory.
Configuration - Interface in org.apache.reef.tang
Immutable, type-checked configuration data.
CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
ConfigurationBuilder - Interface in org.apache.reef.tang
This class allows applications to register bindings with Tang.
configurationBuilderFromString(String, ConfigurationBuilder) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
Converts a given serialized string to ConfigurationBuilder from which Configuration can be produced.
ConfigurationBuilderImpl - Class in org.apache.reef.tang.implementation
 
ConfigurationEntry - Class in org.apache.reef.tang.formats.avro
 
ConfigurationEntry() - Constructor for class org.apache.reef.tang.formats.avro.ConfigurationEntry
Default constructor.
ConfigurationEntry(CharSequence, CharSequence) - Constructor for class org.apache.reef.tang.formats.avro.ConfigurationEntry
All-args constructor.
ConfigurationEntry.Builder - Class in org.apache.reef.tang.formats.avro
RecordBuilder for ConfigurationEntry instances.
ConfigurationImpl - Class in org.apache.reef.tang.implementation
 
ConfigurationModule - Class in org.apache.reef.tang.formats
Allows applications to bundle sets of configuration options together into discrete packages.
ConfigurationModuleBuilder - Class in org.apache.reef.tang.formats
 
ConfigurationProvider - Interface in org.apache.reef.tang
Objects that can provide a Configuration implement this interface.
Configurations - Class in org.apache.reef.tang
Helper class for Configurations.
ConfigurationSerializer - Interface in org.apache.reef.tang.formats
A base interface for Configuration serializers.
ConnectFutureTask<T> - Class in org.apache.reef.wake.remote.impl
FutureTask for network connection.
ConnectFutureTask(Callable<T>, EventHandler<ConnectFutureTask<T>>) - Constructor for class org.apache.reef.wake.remote.impl.ConnectFutureTask
 
Connection<T> - Interface in org.apache.reef.io.network
Connection between two end-points named by identifiers.
ConnectionFactory<T> - Interface in org.apache.reef.io.network
Factory that creates a new connection.
Constants - Class in org.apache.reef.bridge.client
Constant Configuration instances used by the bridge.
Constants - Class in org.apache.reef.runtime.common.utils
Constants used by different REEF modules.
Constants - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Constants used in serializing/deserializing REST calls to HDInsight's Resource Manager.
Constructor<T> - Class in org.apache.reef.tang.implementation
 
Constructor(ClassNode<T>, ConstructorDef<T>, InjectionPlan<?>[]) - Constructor for class org.apache.reef.tang.implementation.Constructor
 
CONSTRUCTOR_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
ConstructorArg - Interface in org.apache.reef.tang.types
 
ConstructorArgImpl - Class in org.apache.reef.tang.implementation.types
 
ConstructorArgImpl(String, String, boolean) - Constructor for class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
constructorArgs - Variable in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Deprecated.
ConstructorDef<T> - Interface in org.apache.reef.tang.types
 
ConstructorDefImpl<T> - Class in org.apache.reef.tang.implementation.types
 
ConstructorDefImpl(String, ConstructorArg[], boolean) - Constructor for class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
Container - Interface in org.apache.reef.runtime.local.driver
Represents a Container: A slice of a machine.
CONTAINER_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The Container name to be used by Azure.
CONTAINER_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
The Container name to be used by Azure.
contains(K, V) - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
contains(K, V) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
contains(String) - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
contains(String) - Method in interface org.apache.reef.tang.types.Node
 
contains(K, V) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
contains(Object) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
containsAll(Collection<?>) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
containsKey(CharSequence) - Method in interface org.apache.reef.io.ExternalMap
 
containsKey(K) - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
containsKey(L) - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
containsKey(K) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
containsKey(CharSequence) - Method in class org.apache.reef.io.storage.ram.CodecRamMap
 
containsKey(CharSequence) - Method in class org.apache.reef.io.storage.ram.RamMap
 
containsKey(K) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
containsKey(Object) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
containsKey(Object) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
containsValue(Object) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
containsValue(Object) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
CONTEXT_CLOSE - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
CONTEXT_CONF - Static variable in class org.apache.reef.poison.PoisonedConfiguration
 
CONTEXT_CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
CONTEXT_CONTROL_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
CONTEXT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
CONTEXT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
CONTEXT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
CONTEXT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
CONTEXT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
CONTEXT_MESSAGE - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
CONTEXT_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
CONTEXT_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
CONTEXT_STATE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
CONTEXT_STATUS_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
ContextActiveHandlers - Class in org.apache.reef.driver.parameters
Handler for ActiveContext.
ContextAndTaskSubmittable - Interface in org.apache.reef.driver
Base interface for classes that support the simultaneous submission of both Context and Task configurations.
ContextBase - Interface in org.apache.reef.driver.context
A common base interface for all Driver-side representations of Contexts.
ContextClientCodeException - Exception in org.apache.reef.runtime.common.evaluator.context
Thrown when we encounter a problem with client code in a context.
ContextClientCodeException(String, Optional<String>, String, Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.context.ContextClientCodeException
 
ContextClosedHandlers - Class in org.apache.reef.driver.parameters
Handler for ClosedContext.
ContextConfiguration - Class in org.apache.reef.driver.context
A ConfigurationModule for Context Configuration.
ContextConfiguration() - Constructor for class org.apache.reef.driver.context.ContextConfiguration
 
ContextConfiguration.DriverReconnect - Class in org.apache.reef.driver.context
Implementation for re-connecting to driver after driver restart.
ContextConfiguration.DriverReconnect() - Constructor for class org.apache.reef.driver.context.ContextConfiguration.DriverReconnect
 
ContextControlHandler - Class in org.apache.reef.runtime.common.driver.context
Handles context control messages.
ContextFailedHandlers - Class in org.apache.reef.driver.parameters
Handler for FailedContext.
contextId - Variable in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Deprecated.
ContextIdentifier - Class in org.apache.reef.evaluator.context.parameters
Context identifier.
ContextIdentifier() - Constructor for class org.apache.reef.evaluator.context.parameters.ContextIdentifier
 
ContextManager - Class in org.apache.reef.runtime.common.evaluator.context
Manages the stack of context in the Evaluator.
ContextMessage - Interface in org.apache.reef.driver.context
Driver-side representation of a message sent by a Context to the Driver.
ContextMessage - Class in org.apache.reef.evaluator.context
Evaluator-side representation of a message sent from an Evaluator to a Driver.
ContextMessageBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for ContextMessage.
ContextMessageBridge(ContextMessage) - Constructor for class org.apache.reef.javabridge.ContextMessageBridge
 
ContextMessageHandler - Interface in org.apache.reef.evaluator.context
Implement this interface to receive messages from the driver in a context.
ContextMessageHandlers - Class in org.apache.reef.driver.parameters
Context message handler.
ContextMessageHandlers - Class in org.apache.reef.evaluator.context.parameters
The set of Context message handlers.
ContextMessageHandlers() - Constructor for class org.apache.reef.evaluator.context.parameters.ContextMessageHandlers
 
ContextMessageImpl - Class in org.apache.reef.runtime.common.driver.context
Driver-side representation of a context message.
ContextMessageImpl(byte[], String, String, long) - Constructor for class org.apache.reef.runtime.common.driver.context.ContextMessageImpl
 
ContextMessagePOJO - Class in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of ContextMessageProto.
contextMessageReceived(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling contextMessageReceivedHandler.
ContextMessageSource - Interface in org.apache.reef.evaluator.context
Message source for control flow messages from a context to the Driver.
ContextMessageSources - Class in org.apache.reef.evaluator.context.parameters
The set of ContextMessageSource implementations called during heartbeats.
ContextMessageSources() - Constructor for class org.apache.reef.evaluator.context.parameters.ContextMessageSources
 
ContextRepresenters - Class in org.apache.reef.runtime.common.driver.context
Driver-Side representation of all contexts on an Evaluator.
ContextRuntime - Class in org.apache.reef.runtime.common.evaluator.context
The evaluator side resourcemanager for Contexts.
contextStackIsEmpty() - Method in class org.apache.reef.runtime.common.evaluator.context.ContextManager
 
ContextStart - Interface in org.apache.reef.evaluator.context.events
This Event is fired when a Context is started.
ContextStartHandlers - Class in org.apache.reef.evaluator.context.parameters
The set of event handlers for the ContextStart event.
ContextStartHandlers() - Constructor for class org.apache.reef.evaluator.context.parameters.ContextStartHandlers
 
ContextState - Enum in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of ContextStatusProto.State.
ContextStatusPOJO - Class in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of ContextStatusProto.
ContextStatusPOJO(ReefServiceProtos.ContextStatusProto, long) - Constructor for class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
ContextStop - Interface in org.apache.reef.evaluator.context.events
This event is fired when a Context is about to be closed.
ContextStopHandlers - Class in org.apache.reef.evaluator.context.parameters
The set of event handlers for the ContextStop event.
ContextStopHandlers() - Constructor for class org.apache.reef.evaluator.context.parameters.ContextStopHandlers
 
ContextSubmittable - Interface in org.apache.reef.driver
Base interface for classes that support Context submission.
Control - Class in org.apache.reef.examples.suspend
Control process which sends suspend/resume commands.
Control(int, String, String, TransportFactory) - Constructor for class org.apache.reef.examples.suspend.Control
 
Control.Command - Class in org.apache.reef.examples.suspend
Command: 'suspend' or 'resume'.
Control.Command() - Constructor for class org.apache.reef.examples.suspend.Control.Command
 
Control.TaskId - Class in org.apache.reef.examples.suspend
Task id.
Control.TaskId() - Constructor for class org.apache.reef.examples.suspend.Control.TaskId
 
ControlMessageBroadcaster - Class in org.apache.reef.examples.group.bgd.operatornames
Used to identify the broadcast operator for control flow messages.
ControlMessageBroadcaster() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.ControlMessageBroadcaster
 
ControlMessageBroadcaster - Class in org.apache.reef.examples.group.broadcast.parameters
Control messages broadcaster.
ControlMessageBroadcaster() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.ControlMessageBroadcaster
 
ControlMessages - Enum in org.apache.reef.examples.group.bgd
Control messages used in BGD example.
ControlMessages - Enum in org.apache.reef.examples.group.broadcast
Control messages used in broadcast example.
copy(Iterable<FileResource>, File) - Static method in class org.apache.reef.runtime.common.files.JobJarMaker
 
cores - Variable in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Deprecated.
count(K) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
countDown() - Method in class org.apache.reef.io.network.group.impl.utils.ResettingCountDownLatch
 
Counter - Class in org.apache.reef.tests.statepassing
Simple counter.
Counter() - Constructor for class org.apache.reef.tests.statepassing.Counter
 
CountingMap<L> - Class in org.apache.reef.io.network.group.impl.utils
Utility class to provide a map that allows to add multiple keys and automatically incrementing the count on each add decrementing the count on each remove and removing key on count==0.
CountingMap() - Constructor for class org.apache.reef.io.network.group.impl.utils.CountingMap
 
CountingSemaphore - Class in org.apache.reef.io.network.group.impl.utils
 
CountingSemaphore(int, String, Object) - Constructor for class org.apache.reef.io.network.group.impl.utils.CountingSemaphore
 
CRASH_PROBABILITY - Static variable in class org.apache.reef.poison.PoisonedConfiguration
The probability with which a crash is to occur.
CRASH_TIMEOUT - Static variable in class org.apache.reef.poison.PoisonedConfiguration
The time window in seconds beginning at ContextStart during which the crash is to occur.
CrashProbability - Class in org.apache.reef.poison.params
The probability with which a crash will occur.
CrashTimeout - Class in org.apache.reef.poison.params
The time window after ContextStart in which the crash will occur.
create() - Method in interface org.apache.reef.io.checkpoint.CheckpointService
Creates a checkpoint and provides a channel to write to it.
create() - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointService
 
create(String) - Method in interface org.apache.reef.io.data.output.OutputStreamProvider
create an output stream using the given name.
create(String) - Method in class org.apache.reef.io.data.output.TaskOutputStreamProviderHDFS
create a file output stream using the given name.
create(String) - Method in class org.apache.reef.io.data.output.TaskOutputStreamProviderLocal
create a file output stream using the given name.
create(InType) - Method in interface org.apache.reef.io.serialization.Deserializer
Deserialize a stream of input.
create(OutType) - Method in interface org.apache.reef.io.serialization.Serializer
Serialize a stream of objects.
create(InputStream) - Method in class org.apache.reef.io.storage.FramingTupleDeserializer
 
create(OutputStream) - Method in class org.apache.reef.io.storage.FramingTupleSerializer
 
create(InputStream) - Method in class org.apache.reef.io.storage.util.IntegerDeserializer
 
create(OutputStream) - Method in class org.apache.reef.io.storage.util.IntegerSerializer
 
create(InputStream) - Method in class org.apache.reef.io.storage.util.StringDeserializer
 
create(OutputStream) - Method in class org.apache.reef.io.storage.util.StringSerializer
 
createAvroSchema() - Method in class org.apache.reef.experimental.parquet.ParquetReader
Retrieve avro schema from parquet file.
createChildAspect() - Method in interface org.apache.reef.tang.Aspect
This method creates a child aspect, and returns it.
createChildAspect() - Method in class org.apache.reef.wake.profiler.WakeProfiler
 
createExpectedEvaluatorInfo(ResourceRecoverEvent) - Static method in class org.apache.reef.driver.restart.EvaluatorRestartInfo
Creates an EvaluatorRestartInfo object that represents the information of an evaluator that is expected to recover.
createFailedEvaluatorInfo(String) - Static method in class org.apache.reef.driver.restart.EvaluatorRestartInfo
Creates an EvaluatorRestartInfo object that represents the information of an evaluator that has failed on driver restart.
createJobFolder(String) - Method in class org.apache.reef.runtime.yarn.client.uploader.JobUploader
Convenience override for int ids.
createJobFolder(int) - Method in class org.apache.reef.runtime.yarn.client.uploader.JobUploader
Convenience override for int ids.
createJobFolderWithApplicationId(String) - Method in class org.apache.reef.runtime.yarn.client.uploader.JobUploader
Creates the Job folder on the DFS.
createJobSubmissionJAR(JobSubmissionEvent, Configuration) - Method in class org.apache.reef.runtime.common.files.JobJarMaker
 
createNamedParameterNode(Node, Class<? extends Name<T>>, Type) - Static method in class org.apache.reef.tang.implementation.java.JavaNodeFactory
XXX: This method assumes that all generic types have exactly one type parameter.
createRootPackageNode() - Static method in class org.apache.reef.tang.implementation.java.JavaNodeFactory
 
createTempDirectory(String, FileAttribute<?>) - Method in class org.apache.reef.io.ConfigurableDirectoryTempFileCreator
 
createTempDirectory(String) - Method in class org.apache.reef.io.ConfigurableDirectoryTempFileCreator
 
createTempDirectory(String, FileAttribute<?>) - Method in class org.apache.reef.io.SystemTempFileCreator
 
createTempDirectory(String) - Method in class org.apache.reef.io.SystemTempFileCreator
 
createTempDirectory(String, FileAttribute<?>) - Method in interface org.apache.reef.io.TempFileCreator
Creates a temporary folder.
createTempDirectory(String) - Method in interface org.apache.reef.io.TempFileCreator
Create a temporary folder.
createTempDirectory(String, FileAttribute<?>) - Method in class org.apache.reef.io.WorkingDirectoryTempFileCreator
 
createTempDirectory(String) - Method in class org.apache.reef.io.WorkingDirectoryTempFileCreator
 
createTempFile(String, String) - Method in class org.apache.reef.io.ConfigurableDirectoryTempFileCreator
 
createTempFile(String, String) - Method in class org.apache.reef.io.SystemTempFileCreator
 
createTempFile(String, String) - Method in interface org.apache.reef.io.TempFileCreator
Creates a temporary file.
createTempFile(String, String) - Method in class org.apache.reef.io.WorkingDirectoryTempFileCreator
 
createUniformCounts(int, int) - Static method in class org.apache.reef.io.network.util.Utils
 
CREDENTIALS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Credentials - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents credentials for an application in the YARN REST API.
Credentials() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
CS - Static variable in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
CtrlMsgSender - Class in org.apache.reef.io.network.group.impl.driver
Event handler that receives ctrl msgs and.
CtrlMsgSender(IdentifierFactory, NetworkService<GroupCommunicationMessage>) - Constructor for class org.apache.reef.io.network.group.impl.driver.CtrlMsgSender
 
currentEdenMemoryUsageMB() - Static method in class org.apache.reef.util.MemoryUtils
 
currentOldMemoryUsageMB() - Static method in class org.apache.reef.util.MemoryUtils
 
currentPermMemoryUsageMB() - Static method in class org.apache.reef.util.MemoryUtils
 
CurrentTime - Interface in org.apache.reef.util.cache
Return the current time.

D

data - Variable in class org.apache.reef.io.watcher.common.AvroFailure
Deprecated.
data - Variable in class org.apache.reef.javabridge.avro.AvroFailedTask
Deprecated.
DATA_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
DATA_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
DATA_FIELD_NUMBER - Static variable in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
DATA_FIELD_NUMBER - Static variable in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
DataCodec - Class in org.apache.reef.io.network.group.impl.config.parameters
 
DataLoader - Class in org.apache.reef.io.data.loading.api
The driver component for the DataLoadingService Also acts as the central point for resource requests All the allocated evaluators pass through this and the ones that need data loading have a context stacked that enables a task to get access to Data via the DataSet.
DataLoader(Clock, EvaluatorRequestor, DataLoadingService, Set<String>, Set<String>) - Constructor for class org.apache.reef.io.data.loading.api.DataLoader
Allows to specify compute and data evaluator requests in particular locations.
DataLoader.EvaluatorAllocatedHandler - Class in org.apache.reef.io.data.loading.api
 
DataLoader.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.io.data.loading.api.DataLoader.EvaluatorAllocatedHandler
 
DataLoader.EvaluatorFailedHandler - Class in org.apache.reef.io.data.loading.api
 
DataLoader.EvaluatorFailedHandler() - Constructor for class org.apache.reef.io.data.loading.api.DataLoader.EvaluatorFailedHandler
 
DataLoader.StartHandler - Class in org.apache.reef.io.data.loading.api
 
DataLoader.StartHandler() - Constructor for class org.apache.reef.io.data.loading.api.DataLoader.StartHandler
 
DataLoadingDriverConfiguration - Class in org.apache.reef.io.data.loading.api
 
DataLoadingDriverConfiguration() - Constructor for class org.apache.reef.io.data.loading.api.DataLoadingDriverConfiguration
 
DataLoadingREEF - Class in org.apache.reef.examples.data.loading
Client for the data loading demo app.
DataLoadingREEF.InputDir - Class in org.apache.reef.examples.data.loading
Input path.
DataLoadingREEF.InputDir() - Constructor for class org.apache.reef.examples.data.loading.DataLoadingREEF.InputDir
 
DataLoadingREEF.Local - Class in org.apache.reef.examples.data.loading
Command line parameter = true to run locally, or false to run on YARN.
DataLoadingREEF.Local() - Constructor for class org.apache.reef.examples.data.loading.DataLoadingREEF.Local
 
DataLoadingREEF.TimeOut - Class in org.apache.reef.examples.data.loading
Number of minutes before timeout.
DataLoadingREEF.TimeOut() - Constructor for class org.apache.reef.examples.data.loading.DataLoadingREEF.TimeOut
 
DataLoadingRequestBuilder - Class in org.apache.reef.io.data.loading.api
Builder to create a request to the DataLoadingService.
DataLoadingRequestBuilder() - Constructor for class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
DataLoadingRequestBuilder.LoadDataIntoMemory - Class in org.apache.reef.io.data.loading.api
 
DataLoadingRequestBuilder.LoadDataIntoMemory() - Constructor for class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder.LoadDataIntoMemory
 
DataLoadingRequestBuilder.NumberOfDesiredSplits - Class in org.apache.reef.io.data.loading.api
 
DataLoadingRequestBuilder.NumberOfDesiredSplits() - Constructor for class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder.NumberOfDesiredSplits
 
DataLoadingService - Interface in org.apache.reef.io.data.loading.api
All data loading services should implement this interface.
DataSet<K,V> - Interface in org.apache.reef.io.data.loading.api
A view of the data set to be loaded at an evaluator as an iterable of key value pairs.
dateTime - Variable in class org.apache.reef.bridge.message.SystemOnStart
Deprecated.
decode(byte[]) - Method in class org.apache.reef.examples.group.utils.math.VectorCodec
 
decode(byte[]) - Method in class org.apache.reef.examples.suspend.ObjectWritableCodec
Decode Hadoop Writable object from a byte array.
decode(byte[], IdentifierFactory) - Static method in class org.apache.reef.io.network.group.impl.driver.TopologySerializer
Recursively translate a byte array into a TopologySimpleNode and a list of task Identifiers.
decode(byte[]) - Method in class org.apache.reef.io.network.group.impl.GroupChangesCodec
 
decode(byte[]) - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessageCodec
 
decode(byte[]) - Method in class org.apache.reef.io.network.group.impl.utils.ScatterDecoder
 
decode(byte[]) - Method in class org.apache.reef.io.network.impl.NSMessageCodec
Decodes a network service message from bytes.
decode(byte[]) - Method in class org.apache.reef.io.network.naming.serialization.NamingLookupRequestCodec
Decodes the bytes to a naming lookup request.
decode(byte[]) - Method in class org.apache.reef.io.network.naming.serialization.NamingLookupResponseCodec
Decodes bytes to an iterable of name assignments.
decode(byte[]) - Method in class org.apache.reef.io.network.naming.serialization.NamingRegisterRequestCodec
Decodes the bytes to a name assignment.
decode(byte[]) - Method in class org.apache.reef.io.network.naming.serialization.NamingRegisterResponseCodec
Decodes a naming register response from the bytes.
decode(byte[]) - Method in class org.apache.reef.io.network.naming.serialization.NamingUnregisterRequestCodec
Decodes the bytes to a naming un-registration request.
decode(byte[]) - Method in class org.apache.reef.io.network.util.ListCodec
 
decode(byte[]) - Method in class org.apache.reef.io.network.util.StringCodec
 
decode(byte[]) - Method in interface org.apache.reef.io.serialization.Codec
Decodes the given byte array into an object.
decode(byte[]) - Method in class org.apache.reef.io.serialization.SerializableCodec
 
decode(byte[]) - Method in class org.apache.reef.io.storage.util.IntegerCodec
 
decode(byte[]) - Method in class org.apache.reef.runtime.common.launch.REEFMessageCodec
 
decode(byte[]) - Method in class org.apache.reef.runtime.mesos.util.MesosRemoteManagerCodec
 
decode(byte[]) - Method in interface org.apache.reef.wake.remote.Decoder
Decodes the given byte array into an object.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.ByteCodec
Returns the byte array argument.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.MultiCodec
Decodes byte array.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.MultiDecoder
Decodes byte array.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.ObjectSerializableCodec
Decodes an object from the bytes.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.RemoteEventCodec
Decodes a remote event object from the bytes.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.RemoteEventDecoder
Decodes a remote event from the byte array data.
decode(byte[]) - Method in class org.apache.reef.wake.remote.impl.StringCodec
Returns a string decoded from the byte array.
decodeFromStream(DataInputStream) - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessageCodec
 
decodeFromStream(DataInputStream) - Method in interface org.apache.reef.io.network.impl.StreamingCodec
 
Decoder<T> - Interface in org.apache.reef.wake.remote
Interface for serialization routines that translate back and forth between byte arrays with low latency.
decrement() - Method in class org.apache.reef.io.network.group.impl.utils.CountingSemaphore
 
DEFAULT - Static variable in class org.apache.reef.driver.parameters.DriverRestartEvaluatorRecoverySeconds
Default restart wait for the driver is 3 minutes.
DEFAULT_APPLICATION_TYPE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
DEFAULT_COMMAND - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Commands
 
DEFAULT_IMPLEMENTATION_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
DEFAULT_KEEP_CONTAINERS_ACROSS_APPLICATION_ATTEMPTS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
DEFAULT_MAX_APP_ATTEMPTS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
DEFAULT_PRIORITY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
DEFAULT_QUEUE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
DEFAULT_RACK - Static variable in class org.apache.reef.runtime.common.driver.catalog.ResourceCatalogImpl
 
DEFAULT_RACK_NAME - Static variable in class org.apache.reef.runtime.local.client.parameters.RackNames
 
DEFAULT_UNMANAGED_AM - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
DEFAULT_VALUE - Static variable in class org.apache.reef.driver.parameters.DriverIdentifier
 
DEFAULT_VALUE - Static variable in class org.apache.reef.poison.params.CrashProbability
 
DEFAULT_VALUE - Static variable in class org.apache.reef.poison.params.CrashTimeout
 
DEFAULT_VALUE - Static variable in class org.apache.reef.runtime.local.client.parameters.RootFolder
 
DEFAULT_VALUE - Static variable in class org.apache.reef.runtime.standalone.client.parameters.NodeFolder
 
DEFAULT_VALUE - Static variable in class org.apache.reef.runtime.standalone.client.parameters.RootFolder
 
DEFAULT_VALUE - Static variable in class org.apache.reef.runtime.yarn.client.parameters.RootFolder
 
DEFAULT_VALUE - Static variable in class org.apache.reef.runtime.yarn.driver.parameters.FileSystemUrl
 
DEFAULT_VALUE - Static variable in class org.apache.reef.wake.remote.ports.parameters.TcpPortRangeBegin
 
DEFAULT_VALUE - Static variable in class org.apache.reef.wake.remote.ports.parameters.TcpPortRangeCount
 
DEFAULT_VALUE - Static variable in class org.apache.reef.wake.remote.ports.parameters.TcpPortRangeTryCount
 
DefaultClientCloseHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default handler for close messages from the client: Throw an Exception.
DefaultClientCloseWithMessageHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default handler for close messages from the client: Throw an Exception.
DefaultClientCloseWithMessageHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultClientCloseWithMessageHandler
 
DefaultClientConstructor - Class in org.apache.reef.runtime.hdinsight.client.sslhacks
Default Client constructor with default SSL checks.
DefaultClientMessageHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for Client messages: Logging it.
DefaultClientMessageHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultClientMessageHandler
 
DefaultCloseHandler - Class in org.apache.reef.runtime.common.evaluator.task.defaults
Default implementation for EventHandler<CloseEvent>.
DefaultCloseHandler() - Constructor for class org.apache.reef.runtime.common.evaluator.task.defaults.DefaultCloseHandler
 
DefaultCompletedJobHandler - Class in org.apache.reef.runtime.common.client.defaults
Default event handler for CompletedJob: Logging it.
DefaultContextActiveHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default handler for ActiveContext: Close it.
DefaultContextClosureHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for ClosedContext: Logging it.
DefaultContextClosureHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultContextClosureHandler
 
DefaultContextFailureHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler used for FailedContext: It crashes the driver.
DefaultContextFailureHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultContextFailureHandler
 
DefaultContextMessageHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for ContextMessage: Logging it.
DefaultContextMessageHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultContextMessageHandler
 
DefaultContextMessageHandler - Class in org.apache.reef.runtime.common.evaluator.context.defaults
Default handler for messages sent by the driver: Crash the context.
DefaultContextMessageSource - Class in org.apache.reef.runtime.common.evaluator.context.defaults
Default ContextMessageSource: return nothing.
DefaultContextMessageSource() - Constructor for class org.apache.reef.runtime.common.evaluator.context.defaults.DefaultContextMessageSource
 
DefaultContextStartHandler - Class in org.apache.reef.runtime.common.evaluator.context.defaults
Default handler for ContextStart.
DefaultContextStopHandler - Class in org.apache.reef.runtime.common.evaluator.context.defaults
Default event handler for ContextStop.
DefaultDriverConnection - Class in org.apache.reef.runtime.common.evaluator
Default implementation for re-establishing connection to driver after driver restart.
DefaultDriverConnection() - Constructor for class org.apache.reef.runtime.common.evaluator.DefaultDriverConnection
 
DefaultDriverMessageHandler - Class in org.apache.reef.runtime.common.evaluator.task.defaults
A default implementation of EventHandler<DriverMessage>.
DefaultDriverMessageHandler() - Constructor for class org.apache.reef.runtime.common.evaluator.task.defaults.DefaultDriverMessageHandler
 
DefaultDriverRestartCompletedHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default handler for driver restart completed event: log it.
DefaultDriverRestartContextActiveHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default handler for ActiveContext from previous evaluator during driver restart: Close it.
DefaultDriverRestartTaskRunningHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for Task Restart TaskRuntime: Logging it.
DefaultDriverRestartTaskRunningHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultDriverRestartTaskRunningHandler
 
DefaultEvaluatorAllocationHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default handler for AllocatedEvaluator: close it.
DefaultEvaluatorAllocationHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultEvaluatorAllocationHandler
 
DefaultEvaluatorCompletionHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for CompletedEvaluator: Logging it.
DefaultEvaluatorCompletionHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultEvaluatorCompletionHandler
 
DefaultEvaluatorFailureHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler used for FailedEvaluator: It crashes the driver.
DefaultEvaluatorFailureHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultEvaluatorFailureHandler
 
DefaultFailedJobHandler - Class in org.apache.reef.runtime.common.client.defaults
Default event handler for FailedJob: rethrow the exception.
DefaultIdentifierFactory - Class in org.apache.reef.wake.impl
Default remote identifier factory that creates a specific remote identifier from a string representation.
DefaultIdentifierFactory() - Constructor for class org.apache.reef.wake.impl.DefaultIdentifierFactory
Constructs a default remote identifier factory.
DefaultIdentifierFactory(Map<String, Class<? extends Identifier>>) - Constructor for class org.apache.reef.wake.impl.DefaultIdentifierFactory
Constructs a default remote identifier factory.
DefaultImplementation - Annotation Type in org.apache.reef.tang.annotations
Allows interfaces to specify a default implementation.
defaultImplementation - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
DefaultJobMessageHandler - Class in org.apache.reef.runtime.common.client.defaults
Default event handler for job message: Logging it.
DefaultMemorySize - Class in org.apache.reef.runtime.local.client.parameters
The size of the default container returned in MB.
DefaultMemorySize() - Constructor for class org.apache.reef.runtime.local.client.parameters.DefaultMemorySize
 
DefaultNumberOfCores - Class in org.apache.reef.runtime.local.client.parameters
The number of the default core.
DefaultNumberOfCores() - Constructor for class org.apache.reef.runtime.local.client.parameters.DefaultNumberOfCores
 
DefaultProgressProvider - Class in org.apache.reef.driver
The default implementation of ProgressProvider.
DefaultRackNameFormatter - Class in org.apache.reef.runtime.yarn.driver
Default implementation of rack names formatter.
DefaultRemoteIdentifierFactoryImplementation - Class in org.apache.reef.wake.remote.impl
A default implementation for RemoteIdentifierFactory interface.
DefaultRemoteIdentifierFactoryImplementation() - Constructor for class org.apache.reef.wake.remote.impl.DefaultRemoteIdentifierFactoryImplementation
 
DefaultRemoteIdentifierFactoryImplementation(Map<String, Class<? extends RemoteIdentifier>>) - Constructor for class org.apache.reef.wake.remote.impl.DefaultRemoteIdentifierFactoryImplementation
 
DefaultRemoteManagerImplementation - Class in org.apache.reef.wake.remote.impl
Default remote manager implementation.
DefaultRunningJobHandler - Class in org.apache.reef.runtime.common.client.defaults
Default event handler for RunningJob: Logging it.
DefaultRuntimeErrorHandler - Class in org.apache.reef.runtime.common.client.defaults
Default event handler for REEF FailedRuntime: rethrow the exception.
defaultRuntimeName - Variable in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Deprecated.
DefaultRuntimeName - Class in org.apache.reef.runtime.multi.client.parameters
Serialized tang configuration for a runtime.
DefaultRuntimeName() - Constructor for class org.apache.reef.runtime.multi.client.parameters.DefaultRuntimeName
 
defaultRuntimeName - Variable in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Deprecated.
DefaultSubmittedJobHandler - Class in org.apache.reef.runtime.common.client.defaults
Default event handler for SubmittedJob: Log the new job ID.
DefaultSuspendHandler - Class in org.apache.reef.runtime.common.evaluator.task.defaults
Default handler for SuspendEvent.
DefaultSuspendHandler() - Constructor for class org.apache.reef.runtime.common.evaluator.task.defaults.DefaultSuspendHandler
 
DefaultTaskCompletionHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for CompletedTask: Log it and close the context.
DefaultTaskCompletionHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultTaskCompletionHandler
 
DefaultTaskFailureHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler used for FailedTask: It crashes the driver.
DefaultTaskFailureHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultTaskFailureHandler
 
DefaultTaskMessageHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for TaskMessage: Logging it.
DefaultTaskMessageHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultTaskMessageHandler
 
DefaultTaskRunningHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler for TaskRuntime: Logging it.
DefaultTaskRunningHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultTaskRunningHandler
 
DefaultTaskSuspensionHandler - Class in org.apache.reef.runtime.common.driver.defaults
Default event handler used for SuspendedTask: It crashes the driver.
DefaultTaskSuspensionHandler() - Constructor for class org.apache.reef.runtime.common.driver.defaults.DefaultTaskSuspensionHandler
 
DefaultThreadFactory - Class in org.apache.reef.wake.impl
A default thread factory implementation that names created threads.
DefaultThreadFactory(String) - Constructor for class org.apache.reef.wake.impl.DefaultThreadFactory
Constructs a default thread factory.
DefaultThreadFactory(String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.reef.wake.impl.DefaultThreadFactory
Constructs a default thread factory.
DefaultTransportEStage - Class in org.apache.reef.wake.remote.impl
A default event-based message transporting stage for both client and server.
DefaultTransportEStage() - Constructor for class org.apache.reef.wake.remote.impl.DefaultTransportEStage
 
DefaultUserCredentials - Class in org.apache.reef.runtime.common.client.defaults
A holder object for REEF user credentials.
DefinedRuntimes - Class in org.apache.reef.javabridge.avro
 
DefinedRuntimes() - Constructor for class org.apache.reef.javabridge.avro.DefinedRuntimes
Default constructor.
DefinedRuntimes(List<CharSequence>) - Constructor for class org.apache.reef.javabridge.avro.DefinedRuntimes
All-args constructor.
DefinedRuntimes - Class in org.apache.reef.runtime.common.driver.parameters
The defined runtimes for the job driver.
DefinedRuntimes() - Constructor for class org.apache.reef.runtime.common.driver.parameters.DefinedRuntimes
 
DefinedRuntimes.Builder - Class in org.apache.reef.javabridge.avro
RecordBuilder for DefinedRuntimes instances.
DefinedRuntimesSerializer - Class in org.apache.reef.javabridge.utils
Serializer for MultiRuntimeDefinition.
DefinedRuntimesSerializer() - Constructor for class org.apache.reef.javabridge.utils.DefinedRuntimesSerializer
 
delete(CheckpointID) - Method in interface org.apache.reef.io.checkpoint.CheckpointService
Discards an existing checkpoint identified by its CheckpointID.
delete(CheckpointID) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointService
 
delete() - Method in class org.apache.reef.io.storage.local.LocalScratchSpace
 
delete() - Method in interface org.apache.reef.io.storage.ScratchSpace
 
DeleteTempFiles - Class in org.apache.reef.runtime.common.parameters
Whether or not to delete the temporary files created during Driver and Evaluator submission.
deliver(byte[]) - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
Deliver a message to the Task.
DenseVector - Class in org.apache.reef.examples.group.utils.math
A dense Vector implementation backed by a double[].
DenseVector(int) - Constructor for class org.apache.reef.examples.group.utils.math.DenseVector
Creates a dense vector of the given size.
DenseVector(double[]) - Constructor for class org.apache.reef.examples.group.utils.math.DenseVector
 
DenseVector(ImmutableVector) - Constructor for class org.apache.reef.examples.group.utils.math.DenseVector
Instantiates a new DenseVector by copying the given other vector.
DenseVector(DenseVector) - Constructor for class org.apache.reef.examples.group.utils.math.DenseVector
 
DescentDirectionBroadcaster - Class in org.apache.reef.examples.group.bgd.operatornames
Name of the broadcast operator used to send descent directions during linesearch.
DescentDirectionBroadcaster() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.DescentDirectionBroadcaster
 
description - Variable in class org.apache.reef.io.watcher.common.AvroFailure
Deprecated.
deserialize(String) - Static method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartitionSerializer
 
deserialize(String) - Static method in class org.apache.reef.io.data.loading.impl.WritableSerializer
 
deserialize(String, JobConf) - Static method in class org.apache.reef.io.data.loading.impl.WritableSerializer
 
deserialize(File) - Static method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
in 0.12. Use AvroClassHierarchySerializer instead
deserialize(ClassHierarchy, InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferInjectionPlan
 
deserialize(byte[]) - Method in class org.apache.reef.vortex.common.KryoUtils
 
Deserializer<ObjectType,InType> - Interface in org.apache.reef.io.serialization
Stream-based multi-object deserialization interface.
DESTID_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
DESTID_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
detectRestart() - Method in class org.apache.reef.driver.restart.DriverRestartManager
Triggers the state machine if the application is a restart instance.
DFS_PATH_OPTION - Static variable in class org.apache.reef.util.logging.DFSHandler
 
DFSEvaluatorLogAppendReaderWriter - Class in org.apache.reef.runtime.yarn.driver.restart
The DFS evaluator logger that performs regular append.
DFSEvaluatorLogOverwriteReaderWriter - Class in org.apache.reef.runtime.yarn.driver.restart
The DFS evaluator logger that does not support append and does append by overwrite.
DFSEvaluatorLogReaderWriter - Interface in org.apache.reef.runtime.yarn.driver.restart
The Evaluator log reader/writer that reads from and writes to the Hadoop DFS.
DFSEvaluatorPreserver - Class in org.apache.reef.runtime.yarn.driver.restart
An Evaluator Preserver that uses the DFS on YARN.
DFSHandler - Class in org.apache.reef.util.logging
A java.util.logging.Handler that logs to (H)DFS.
DFSHandler() - Constructor for class org.apache.reef.util.logging.DFSHandler
 
dfsJobSubmissionFolder - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Deprecated.
DIAGNOSTICS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Dimensions - Class in org.apache.reef.examples.group.broadcast.parameters
 
Dimensions() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.Dimensions
 
disconnected(ExecutorDriver) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
DispatchingEStage - Class in org.apache.reef.runtime.common.utils
Delayed event router that dispatches messages to the proper event handler by type.
DispatchingEStage(EventHandler<Throwable>, int, String) - Constructor for class org.apache.reef.runtime.common.utils.DispatchingEStage
 
DispatchingEStage(DispatchingEStage) - Constructor for class org.apache.reef.runtime.common.utils.DispatchingEStage
Constructs a DispatchingEStage that uses the Thread pool and ErrorHandler of another one.
DistributedDataSet - Class in org.apache.reef.io.data.loading.api
Represents a distributed data set that is split across data centers.
DistributedDataSet() - Constructor for class org.apache.reef.io.data.loading.api.DistributedDataSet
 
DistributedDataSetPartition - Class in org.apache.reef.io.data.loading.impl
POJO that represents a distributed data set partition.
DistributedDataSetPartition.Builder - Class in org.apache.reef.io.data.loading.impl
DistributedDataSetPartitions are build using this Builder.
DistributedDataSetPartitionSerializer - Class in org.apache.reef.io.data.loading.impl
Serialize and deserialize DistributedDataSetPartition objects.
DistributedDataSetPartitionSerializer.DistributedDataSetPartitions - Class in org.apache.reef.io.data.loading.impl
Allows to specify a set of distributed data set partitions.
DistributedDataSetPartitionSerializer.DistributedDataSetPartitions() - Constructor for class org.apache.reef.io.data.loading.impl.DistributedDataSetPartitionSerializer.DistributedDataSetPartitions
 
doAs(PrivilegedExceptionAction<T>) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultUserCredentials
Execute the privileged action as a given user.
doAs(PrivilegedExceptionAction<T>) - Method in interface org.apache.reef.runtime.common.UserCredentials
Execute the privileged action as a given user.
doAs(PrivilegedExceptionAction<T>) - Method in class org.apache.reef.runtime.yarn.client.unmanaged.YarnProxyUser
Execute the privileged action as a given user.
documentation - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
DOCUMENTATION_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
DONE_EVALUATOR_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
DONE_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
DONE = 1;
DONE_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.State
DONE = 2;
dot(Vector) - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
Computes the inner product with another Vector.
Driver - Class in org.apache.reef.tests.fail.task
Universal driver for the test REEF job that fails on different stages of execution.
Driver(String, EvaluatorRequestor) - Constructor for class org.apache.reef.tests.fail.task.Driver
 
Driver.FailTaskName - Class in org.apache.reef.tests.fail.task
Name of the message class to specify the failing message handler.
Driver.FailTaskName() - Constructor for class org.apache.reef.tests.fail.task.Driver.FailTaskName
 
DRIVER_CONFIGURATION - Static variable in class org.apache.reef.bridge.client.Constants
Contains all bindings of event handlers to the bridge.
DRIVER_CONFIGURATION_PROVIDER - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
Driver configuration provider for the client.
DRIVER_CONFIGURATION_PROVIDER - Static variable in class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
Driver configuration provider for the client.
DRIVER_CONFIGURATION_PROVIDERS - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
Configuration provides whose Configuration will be merged into all Driver Configuration.
DRIVER_CONFIGURATION_PROVIDERS - Static variable in class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
Configuration provides whose Configuration will be merged into all Driver Configuration.
DRIVER_CONFIGURATION_PROVIDERS - Static variable in class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
Configuration provides whose Configuration will be merged into all Driver Configuration.
DRIVER_CONFIGURATION_PROVIDERS - Static variable in class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
Configuration provides whose Configuration will be merged into all Driver Configuration.
DRIVER_CONFIGURATION_PROVIDERS - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnClientConfiguration
Configuration provides whose Configuration will be merged into all Driver Configuration.
DRIVER_CONFIGURATION_PROVIDERS - Static variable in class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
Configuration provides whose Configuration will be merged into all Driver Configuration.
DRIVER_CONFIGURATION_WITH_HTTP_AND_NAMESERVER - Static variable in class org.apache.reef.bridge.client.Constants
The driver configuration assumed by the the bridge.
DRIVER_FOLDER_NAME - Static variable in class org.apache.reef.runtime.local.client.PreparedDriverFolderLauncher
The name of the folder for the driver within the Job folder.
DRIVER_IDENTIFIER - Static variable in class org.apache.reef.client.DriverConfiguration
Identifies the driver and therefore the JOB.
DRIVER_JOB_SUBMISSION_DIRECTORY - Static variable in class org.apache.reef.client.DriverConfiguration
Job submission directory to be used by driver.
DRIVER_MEMORY - Static variable in class org.apache.reef.client.DriverConfiguration
The amount of memory to be allocated for the Driver.
DRIVER_MEMORY - Static variable in class org.apache.reef.runtime.local.client.PreparedDriverFolderLauncher
The (hard-coded) amount of memory to be used for the driver.
DRIVER_REMOTE_IDENTIFIER - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
DRIVER_RESTART - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DRIVER_RESTART_ACTIVE_CONTEXT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DRIVER_RESTART_COMPLETE - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DRIVER_RESTART_EVALUATOR_RECOVERY_SECONDS - Static variable in class org.apache.reef.client.DriverRestartConfiguration
The amount of time in seconds the driver waits for evaluators to report back on restart.
DRIVER_RESTART_RUNNING_TASK - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DRIVER_START - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DRIVER_STOP - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DRIVER_SUBMIT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
DriverConfiguration - Class in org.apache.reef.client
A ConfigurationModule for Drivers.
DriverConfiguration() - Constructor for class org.apache.reef.client.DriverConfiguration
 
DriverConfigurationProvider - Interface in org.apache.reef.runtime.common.client
A contract for driver configuration provider.
DriverConfigurationProviders - Class in org.apache.reef.client.parameters
Configuration provides whose Configurations will be mixed into the Driver Configuration.
DriverConfigurationProviders() - Constructor for class org.apache.reef.client.parameters.DriverConfigurationProviders
 
DriverConnection - Interface in org.apache.reef.runtime.common.evaluator
Interface used for reconnecting to driver after driver restart.
DriverException - Exception in org.apache.reef.exception
Thrown by the Driver and to the clients of REEF.
DriverException() - Constructor for exception org.apache.reef.exception.DriverException
Standard Exception constructor.
DriverException(String, Throwable) - Constructor for exception org.apache.reef.exception.DriverException
Standard Exception constructor.
DriverException(String) - Constructor for exception org.apache.reef.exception.DriverException
Standard Exception constructor.
DriverException(Throwable) - Constructor for exception org.apache.reef.exception.DriverException
Standard Exception constructor.
DriverExceptionHandler - Class in org.apache.reef.runtime.common.driver
Exception handler for exceptions thrown by client code in the Driver.
DriverExceptionHandler(DriverStatusManager) - Constructor for class org.apache.reef.runtime.common.driver.DriverExceptionHandler
 
DriverFailOnFail - Class in org.apache.reef.tests.fail.driver
Driver which fails on FailedTask event.
DriverFailOnFail(JobMessageObserver, EvaluatorRequestor) - Constructor for class org.apache.reef.tests.fail.driver.DriverFailOnFail
 
DriverFailOnFail.AllocatedEvaluatorHandler - Class in org.apache.reef.tests.fail.driver
Handler for AllocatedEvaluator.
DriverFailOnFail.AllocatedEvaluatorHandler() - Constructor for class org.apache.reef.tests.fail.driver.DriverFailOnFail.AllocatedEvaluatorHandler
 
DriverFailOnFail.FailedTaskHandler - Class in org.apache.reef.tests.fail.driver
Handler for FailedTask.
DriverFailOnFail.FailedTaskHandler() - Constructor for class org.apache.reef.tests.fail.driver.DriverFailOnFail.FailedTaskHandler
 
DriverFailOnFail.StartHandler - Class in org.apache.reef.tests.fail.driver
Handler for StartTime.
DriverFailOnFail.StartHandler() - Constructor for class org.apache.reef.tests.fail.driver.DriverFailOnFail.StartHandler
 
DriverFatalRuntimeException - Exception in org.apache.reef.exception
A special RuntimeException we throw to indicate to the resource manager to never attempt to restart us if this exception is thrown.
DriverFatalRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.exception.DriverFatalRuntimeException
 
DriverFatalRuntimeException(String) - Constructor for exception org.apache.reef.exception.DriverFatalRuntimeException
 
DriverIdentifier - Class in org.apache.reef.driver.parameters
Driver Identifier.
DriverIdentifierGroupComm - Class in org.apache.reef.io.network.group.impl.config.parameters
 
DriverIdentifierGroupComm() - Constructor for class org.apache.reef.io.network.group.impl.config.parameters.DriverIdentifierGroupComm
 
DriverIdleManager - Class in org.apache.reef.runtime.common.driver.idle
Handles the various sources for driver idleness and forwards decisions to DriverStatusManager.
DriverIdlenessSource - Interface in org.apache.reef.runtime.common.driver.idle
Implementations of this interface are used to determine driver idleness.
DriverIdleSources - Class in org.apache.reef.driver.parameters
Sources considered when making an idleness decision.
DriverInfoSerializer - Interface in org.apache.reef.webserver
Interface for DriverInfoSerializer.
DriverIsUnmanaged - Class in org.apache.reef.driver.parameters
If true, run Driver in unmanaged mode.
DriverJobSubmissionDirectory - Class in org.apache.reef.driver.parameters
Job submission directory.
DriverLaunchCommandPrefix - Class in org.apache.reef.runtime.common.launch.parameters
List of strings to be prepended to driver launch command (I.E.
DriverLaunchCommandPrefix() - Constructor for class org.apache.reef.runtime.common.launch.parameters.DriverLaunchCommandPrefix
 
DriverLauncher - Class in org.apache.reef.client
A launcher for REEF Drivers.
DriverLauncher.CompletedJobHandler - Class in org.apache.reef.client
Job driver notifies us that the job had completed successfully.
DriverLauncher.CompletedJobHandler() - Constructor for class org.apache.reef.client.DriverLauncher.CompletedJobHandler
 
DriverLauncher.FailedJobHandler - Class in org.apache.reef.client
Job driver notifies us that the job had failed.
DriverLauncher.FailedJobHandler() - Constructor for class org.apache.reef.client.DriverLauncher.FailedJobHandler
 
DriverLauncher.RunningJobHandler - Class in org.apache.reef.client
Job driver notifies us that the job is running.
DriverLauncher.RunningJobHandler() - Constructor for class org.apache.reef.client.DriverLauncher.RunningJobHandler
 
DriverLauncher.RuntimeErrorHandler - Class in org.apache.reef.client
Handler an error in the job driver.
DriverLauncher.RuntimeErrorHandler() - Constructor for class org.apache.reef.client.DriverLauncher.RuntimeErrorHandler
 
DriverLauncher.SubmittedJobHandler - Class in org.apache.reef.client
Job driver notifies us that the job has been submitted to the Resource Manager.
DriverLauncher.SubmittedJobHandler() - Constructor for class org.apache.reef.client.DriverLauncher.SubmittedJobHandler
 
DriverLocalFiles - Class in org.apache.reef.driver.parameters
Files to be made accessible on the Driver only.
DriverLocalLibraries - Class in org.apache.reef.driver.parameters
Libraries to be made accessible on the Driver only.
DriverMemory - Class in org.apache.reef.driver.parameters
Driver RAM allocation in MB.
driverMemory - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
DriverMessage - Interface in org.apache.reef.task.events
Represents a message sent by the driver.
DriverMessaging - Class in org.apache.reef.tests.messaging.driver
Runner for DriverMessagingTest.
DriverProcessMemory - Class in org.apache.reef.runtime.common.driver.parameters
The driver process memory.
DriverProcessMemory() - Constructor for class org.apache.reef.runtime.common.driver.parameters.DriverProcessMemory
 
driverRecoveryTimeout - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Deprecated.
DriverRemoteIdentifier - Class in org.apache.reef.runtime.common.evaluator.parameters
The identifier used by the Evaluator to connect back to the Driver.
driverRestart(StartTime) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling driverRestartHandler.
driverRestartActiveContextReceived(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling driverRestartActiveContextReceivedHandler.
DriverRestartCompleted - Interface in org.apache.reef.driver.restart
The object used to notify the user that the Driver Restart process has been completed.
driverRestartCompleted(long) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling driverRestartCompletedHandler.
DriverRestartCompletedBridge - Class in org.apache.reef.javabridge.generic
The Java-CLR bridge object for DriverRestartCompleted events.
DriverRestartCompletedHandlers - Class in org.apache.reef.driver.parameters
Handler for event that all evaluators have checked back in after driver restart and that the restart is completed.
DriverRestartConfiguration - Class in org.apache.reef.client
EventHandlers specific to Driver Restart.
DriverRestartContextActiveHandlers - Class in org.apache.reef.driver.parameters
Handler for ActiveContext during a driver restart.
DriverRestarted - Interface in org.apache.reef.driver.restart
Am event encapsulating the time of Driver restart as well as the set of Evaluator IDs of Evaluators that are expected to report back to the Driver after restart.
DriverRestartedBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for DriverRestarted events.
DriverRestartedBridge(DriverRestarted) - Constructor for class org.apache.reef.javabridge.DriverRestartedBridge
 
DriverRestartedImpl - Class in org.apache.reef.driver.restart
 
DriverRestartEvaluatorRecoverySeconds - Class in org.apache.reef.driver.parameters
Represents the amount of time in seconds that the driver restart waits for evaluators to report back.
DriverRestartFailedEvaluatorHandlers - Class in org.apache.reef.driver.parameters
The NamedParameter for Evaluators that have failed on Driver Restart.
DriverRestartHandler - Class in org.apache.reef.driver.parameters
The EventHandler invoked on Driver restart.
DriverRestartHandler() - Constructor for class org.apache.reef.driver.parameters.DriverRestartHandler
 
DriverRestartManager - Class in org.apache.reef.driver.restart
The manager that handles aspects of driver restart such as determining whether the driver is in restart mode, what to do on restart, whether restart is completed, and others.
driverRestartRunningTask(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling driverRestartRunningTaskHandler.
DriverRestartState - Enum in org.apache.reef.driver.restart
Represents the current driver restart progress.
DriverRestartTaskRunningHandlers - Class in org.apache.reef.driver.parameters
Handler for RunningTask events during a Driver restart.
DriverRuntimeConfiguration - Class in org.apache.reef.runtime.common.driver
ConfigurationModule for driver runtime.
DriverRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.common.driver.DriverRuntimeConfiguration
 
DriverRuntimeConfigurationOptions - Class in org.apache.reef.runtime.common.driver
Houses the Driver resourcemanager configuration's NamedParameters.
DriverRuntimeConfigurationOptions() - Constructor for class org.apache.reef.runtime.common.driver.DriverRuntimeConfigurationOptions
 
DriverRuntimeConfigurationOptions.JobControlHandler - Class in org.apache.reef.runtime.common.driver
Handler called when a job control message is received by the client.
DriverRuntimeConfigurationOptions.JobControlHandler() - Constructor for class org.apache.reef.runtime.common.driver.DriverRuntimeConfigurationOptions.JobControlHandler
 
DriverRuntimeRestartConfiguration - Class in org.apache.reef.runtime.common.driver
The base configuration module for driver restart configurations of all runtimes.
DriverRuntimeRestartManager - Interface in org.apache.reef.driver.restart
Classes implementing this interface are in charge of recording evaluator changes as they are allocated as well as recovering Evaluators and discovering which evaluators are lost on the event of a driver restart.
DriverServiceConfiguration - Class in org.apache.reef.client
Use this ConfigurationModule to configure Services to be run in the Driver.
DriverServiceConfiguration() - Constructor for class org.apache.reef.client.DriverServiceConfiguration
 
DriverSide - Annotation Type in org.apache.reef.annotations.audience
Annotates interfaces that are meant to be used in the Job Driver.
DriverSideFailure - Exception in org.apache.reef.tests.library.exceptions
Thrown when a test fails on the driver side.
DriverSideFailure() - Constructor for exception org.apache.reef.tests.library.exceptions.DriverSideFailure
 
DriverSideFailure(String) - Constructor for exception org.apache.reef.tests.library.exceptions.DriverSideFailure
 
DriverSideFailure(String, Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.DriverSideFailure
 
DriverSideFailure(Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.DriverSideFailure
 
driverStart(StartTime) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to start the driver.
DriverStartHandler - Class in org.apache.reef.driver.parameters
Called once the Driver is completely setup.
DriverStartHandler() - Constructor for class org.apache.reef.driver.parameters.DriverStartHandler
 
DriverStartHandler - Class in org.apache.reef.runtime.common.driver
This is bound to the start event of the clock and dispatches it to the appropriate application code.
DriverStatus - Enum in org.apache.reef.runtime.common.driver
The status of the Driver.
DriverStatusManager - Class in org.apache.reef.runtime.common.driver
Manages the Driver's status.
driverStderrFilePath - Variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Deprecated.
driverStderrFilePath - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
driverStdoutFilePath - Variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Deprecated.
driverStdoutFilePath - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
driverStop(long) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to stop the driver.
driverSubmit(Boolean) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time to submit a driver.
DURATION - Static variable in class org.apache.reef.util.logging.LoggingScopeImpl
 
DynamicObservable<T> - Interface in org.apache.reef.wake.rx
Defines a "dynamically configured" provider for push-based notification.

E

EchoTask - Class in org.apache.reef.tests.library.tasks
A Task that just sends the memento back.
EdgeVisitor<T> - Interface in org.apache.reef.tang.util.walk
Generic interface to traverse edges of the configuration graph.
ELAPSED_TIME - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
empty() - Static method in class org.apache.reef.util.Optional
 
EMPTY_BYTE_ARR - Static variable in class org.apache.reef.io.network.group.impl.utils.Utils
 
enableAssertions(boolean) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
Enable or disable assertions on the child process.
EnableRampup - Class in org.apache.reef.examples.group.bgd.parameters
Maximum Number of Iterations.
EnableRampup() - Constructor for class org.apache.reef.examples.group.bgd.parameters.EnableRampup
 
encode(Vector) - Method in class org.apache.reef.examples.group.utils.math.VectorCodec
 
encode(T) - Method in class org.apache.reef.examples.suspend.ObjectWritableCodec
Encodes Hadoop Writable object into a byte array.
encode(TaskNode) - Static method in class org.apache.reef.io.network.group.impl.driver.TopologySerializer
Recursively encode TaskNodes of a Topology into a byte array.
encode(GroupChanges) - Method in class org.apache.reef.io.network.group.impl.GroupChangesCodec
 
encode(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessageCodec
 
encode(List<T>, List<Integer>, List<? extends Identifier>, Codec<T>) - Method in class org.apache.reef.io.network.group.impl.utils.ScatterEncoder
 
encode(NSMessage<T>) - Method in class org.apache.reef.io.network.impl.NSMessageCodec
Encodes a network service message to bytes.
encode(NamingLookupRequest) - Method in class org.apache.reef.io.network.naming.serialization.NamingLookupRequestCodec
Encodes the identifiers to bytes.
encode(NamingLookupResponse) - Method in class org.apache.reef.io.network.naming.serialization.NamingLookupResponseCodec
Encodes name assignments to bytes.
encode(NamingRegisterRequest) - Method in class org.apache.reef.io.network.naming.serialization.NamingRegisterRequestCodec
Encodes the name assignment to bytes.
encode(NamingRegisterResponse) - Method in class org.apache.reef.io.network.naming.serialization.NamingRegisterResponseCodec
Encodes a naming register response to bytes.
encode(NamingUnregisterRequest) - Method in class org.apache.reef.io.network.naming.serialization.NamingUnregisterRequestCodec
Encodes the naming un-registration request to bytes.
encode(List<T>) - Method in class org.apache.reef.io.network.util.ListCodec
 
encode(String) - Method in class org.apache.reef.io.network.util.StringCodec
 
encode(T) - Method in interface org.apache.reef.io.serialization.Codec
Encodes the given object into a Byte Array.
encode(T) - Method in class org.apache.reef.io.serialization.SerializableCodec
 
encode(Integer) - Method in class org.apache.reef.io.storage.util.IntegerCodec
 
encode(GeneratedMessage) - Method in class org.apache.reef.runtime.common.launch.REEFMessageCodec
 
encode(EvaluatorControl) - Method in class org.apache.reef.runtime.mesos.util.MesosRemoteManagerCodec
 
encode(T) - Method in interface org.apache.reef.wake.remote.Encoder
Encodes the given object into a Byte Array.
encode(byte[]) - Method in class org.apache.reef.wake.remote.impl.ByteCodec
Returns the byte array argument.
encode(T) - Method in class org.apache.reef.wake.remote.impl.MultiCodec
Encodes an object to a byte array.
encode(T) - Method in class org.apache.reef.wake.remote.impl.MultiEncoder
Encodes an object to a byte array.
encode(T) - Method in class org.apache.reef.wake.remote.impl.ObjectSerializableCodec
Encodes the object to bytes.
encode(RemoteEvent<T>) - Method in class org.apache.reef.wake.remote.impl.RemoteEventCodec
Encodes the remote event object to bytes.
encode(RemoteEvent<T>) - Method in class org.apache.reef.wake.remote.impl.RemoteEventEncoder
Encodes the remote event object to bytes.
encode(String) - Method in class org.apache.reef.wake.remote.impl.StringCodec
Returns a byte array representation of the string.
encode(byte[]) - Method in class org.apache.reef.wake.remote.transport.netty.ByteEncoder
 
Encoder<T> - Interface in org.apache.reef.wake.remote
Interface for serialization routines that translate back and forth between byte arrays with low latency.
encodeToStream(GroupCommunicationMessage, DataOutputStream) - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessageCodec
 
encodeToStream(T, DataOutputStream) - Method in interface org.apache.reef.io.network.impl.StreamingCodec
 
END_INDICATORS - Static variable in class org.apache.reef.util.logging.LogParser
 
endPackage() - Method in class org.apache.reef.tang.util.Tint
 
enqueueTasklet(VortexFunction<TInput, TOutput>, TInput, Optional<FutureCallback<TOutput>>) - Method in interface org.apache.reef.vortex.driver.VortexMaster
Submit a new Tasklet to be run sometime in the future, with an optional callback function on the result.
enqueueTasklets(VortexAggregateFunction<TOutput>, VortexFunction<TInput, TOutput>, VortexAggregatePolicy, List<TInput>, Optional<FutureCallback<AggregateResult<TInput, TOutput>>>) - Method in interface org.apache.reef.vortex.driver.VortexMaster
Submits aggregate-able Tasklets to be run sometime in the future, with an optional callback function on the aggregation progress.
ENTRY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
entrySet() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
entrySet() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
ENVIRONMENT - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
EnvironmentUtils - Class in org.apache.reef.util
Utils which detect environment settings.
Eps - Class in org.apache.reef.examples.group.bgd.parameters
Break criterion for the optimizer.
Eps() - Constructor for class org.apache.reef.examples.group.bgd.parameters.Eps
 
equals(Object) - Method in class org.apache.reef.client.LauncherStatus
Compare the State of two LauncherStatus objects.
equals(Object) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
equals(Object) - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition
 
equals(Object) - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
equals(Object) - Method in class org.apache.reef.io.network.group.impl.driver.IndexedMsg
 
equals(Object) - Method in class org.apache.reef.io.network.group.impl.driver.MsgKey
 
equals(Object) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
equals(Object) - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
equals(Object) - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
equals(Object) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
equals(Object) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
equals(Object) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
equals(Object) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
equals(Object) - Method in class org.apache.reef.io.network.util.StringIdentifier
Checks that another object is equal to this object.
equals(Object) - Method in class org.apache.reef.io.Tuple
 
equals(Object) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
equals(Object) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
equals(Object) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
equals(Object) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
equals(Object) - Method in class org.apache.reef.runtime.common.driver.catalog.RackDescriptorImpl
 
equals(Object) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
equals(Object) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
equals(Object) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
equals(Object) - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
equals(Object) - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
equals(Object) - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
equals(Object) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
equals(Object) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
equals(Object) - Method in class org.apache.reef.util.Optional
 
equals(Object) - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
equals(Object) - Method in class org.apache.reef.wake.examples.join.TupleEvent
 
equals(Object) - Method in interface org.apache.reef.wake.Identifier
Checks that another object is equal to this object.
equals(Object) - Method in class org.apache.reef.wake.remote.impl.SocketRemoteIdentifier
Checks that another object is equal to this object.
equals(Object) - Method in class org.apache.reef.wake.remote.impl.Tuple2
 
equals(Object) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
equals(Object) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
equals(Object) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
equals(Object) - Method in class org.apache.reef.wake.time.Time
 
error(ExecutorDriver, String) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
ERROR_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
ERROR_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
ErrorHandlerRID - Class in org.apache.reef.runtime.common.launch.parameters
The error handler remote identifier.
EStage<T> - Interface in org.apache.reef.wake
Stage that executes an event handler.
Eta - Class in org.apache.reef.examples.group.bgd.parameters
Break criterion for the optimizer.
Eta() - Constructor for class org.apache.reef.examples.group.bgd.parameters.Eta
 
EVALUATOR_ALLOCATED - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_BRIDGE_SUBMIT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_COMPLETED - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_CONFIGURATION - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
EVALUATOR_DISPATCHER_THREADS - Static variable in class org.apache.reef.client.DriverConfiguration
Number of threads allocated per evaluator to dispatch events from this Evaluator.
EVALUATOR_FAILED - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
EVALUATOR_IDENTIFIER - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
EVALUATOR_IDLENESS_THREAD_POOL_SIZE - Static variable in class org.apache.reef.client.DriverConfiguration
The number of Threads in a Driver to verify the completion of Evaluators.
EVALUATOR_IDLENESS_WAIT_IN_MS - Static variable in class org.apache.reef.client.DriverConfiguration
The number of Threads in a Driver to verify the completion of Evaluators.
evaluator_launch - Variable in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Deprecated.
EVALUATOR_LAUNCH - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_PRESERVER - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverRestartConfiguration
The Evaluator Preserver implementation used for YARN.
evaluator_release - Variable in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Deprecated.
EVALUATOR_REQUESTOR - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_STATUS_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
EVALUATOR_SUBMIT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
EVALUATOR_TIMEOUT - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
EVALUATOR_TIMEOUT - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
 
EVALUATOR_TIMEOUT - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
EVALUATOR_TIMEOUT - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
evaluatorAllocated(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time on evaluatorAllocated handler.
EvaluatorAllocatedHandlers - Class in org.apache.reef.driver.parameters
Called when an allocated evaluator is given to the client.
evaluatorCompleted(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling evaluatorCompleted handler.
EvaluatorCompletedHandlers - Class in org.apache.reef.driver.parameters
Called when an exception occurs on a running evaluator.
EvaluatorConfiguration - Class in org.apache.reef.runtime.common.evaluator
The runtime configuration of an evaluator.
EvaluatorConfiguration() - Constructor for class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
EvaluatorConfiguration - Class in org.apache.reef.runtime.common.evaluator.parameters
The evaluator configuration.
EvaluatorConfigurationProviders - Class in org.apache.reef.driver.parameters
Configuration provides whose Configurations will be mixed into the Evaluator Configuration.
EvaluatorConfigurationProviders() - Constructor for class org.apache.reef.driver.parameters.EvaluatorConfigurationProviders
 
EvaluatorContext - Class in org.apache.reef.runtime.common.driver.context
Driver-side representation of a Context on an Evaluator.
EvaluatorContext(String, String, EvaluatorDescriptor, Optional<String>, ConfigurationSerializer, ContextControlHandler, EvaluatorMessageDispatcher, ExceptionCodec, ContextRepresenters) - Constructor for class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
EvaluatorControl - Class in org.apache.reef.runtime.mesos.util
 
EvaluatorControl() - Constructor for class org.apache.reef.runtime.mesos.util.EvaluatorControl
Default constructor.
EvaluatorControl(EvaluatorLaunch, EvaluatorRelease) - Constructor for class org.apache.reef.runtime.mesos.util.EvaluatorControl
All-args constructor.
EvaluatorControl.Builder - Class in org.apache.reef.runtime.mesos.util
RecordBuilder for EvaluatorControl instances.
EVALUATORCONTROL_FIELD_NUMBER - Static variable in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
EvaluatorControlHandler - Class in org.apache.reef.runtime.common.driver.evaluator
This class handles the sending of Evaluator control messages to the Evaluator.
EvaluatorDescriptor - Interface in org.apache.reef.driver.evaluator
Metadata about an Evaluator.
evaluatorDescriptor - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Deprecated.
evaluatorDescriptor - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Deprecated.
EvaluatorDispatcherThreads - Class in org.apache.reef.driver.parameters
Number of threads allocated per evaluator to dispatch events from that Evaluator.
EvaluatorException - Exception in org.apache.reef.exception
Exception thrown to the Driver when an Evaluator becomes unusable.
EvaluatorException(String) - Constructor for exception org.apache.reef.exception.EvaluatorException
 
EvaluatorException(String, String, Throwable) - Constructor for exception org.apache.reef.exception.EvaluatorException
 
EvaluatorException(String, String) - Constructor for exception org.apache.reef.exception.EvaluatorException
 
EvaluatorException(String, Throwable) - Constructor for exception org.apache.reef.exception.EvaluatorException
 
evaluatorException - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Deprecated.
evaluatorFailed(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling evaluatorFailed handler.
EvaluatorFailedHandlers - Class in org.apache.reef.driver.parameters
Called when an exception occurs on a running evaluator.
EVALUATORHEARTBEAT_FIELD_NUMBER - Static variable in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
EvaluatorHeartbeatHandler - Class in org.apache.reef.runtime.common.driver.evaluator
Receives heartbeats from all Evaluators and dispatches them to the right EvaluatorManager instance.
evaluatorId - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Deprecated.
evaluatorId - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
EvaluatorIdentifier - Class in org.apache.reef.runtime.common.evaluator.parameters
The evaluator identifier.
EvaluatorIdlenessThreadPool - Class in org.apache.reef.runtime.common.driver.evaluator
Runs threads in a thread pool to check the completion of Evaluators on the closing of an EvaluatorManager in order to trigger Evaluator idleness checks.
EvaluatorIdlenessThreadPoolSize - Class in org.apache.reef.runtime.common.driver.parameters
The number of Threads in a Driver to verify the completion of Evaluators.
EvaluatorIdlenessWaitInMilliseconds - Class in org.apache.reef.runtime.common.driver.parameters
The number of Threads in a Driver to verify the completion of Evaluators.
EvaluatorInfoSerializer - Interface in org.apache.reef.webserver
Interface for EvaluatorInfoSerializer.
evaluatorIsClosed() - Method in class org.apache.reef.runtime.common.driver.task.TaskRepresenter
Check whether this evaluator is in closed state.
evaluatorIsClosing() - Method in class org.apache.reef.runtime.common.driver.task.TaskRepresenter
Check whether this evaluator is in closing state.
EvaluatorKilledByResourceManagerException - Exception in org.apache.reef.exception
Reported as part of a FailedEvaluator when the resource manager killed the Evaluator.
EvaluatorKilledByResourceManagerException(String, String) - Constructor for exception org.apache.reef.exception.EvaluatorKilledByResourceManagerException
 
EvaluatorLaunch - Class in org.apache.reef.runtime.mesos.util
 
EvaluatorLaunch() - Constructor for class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Default constructor.
EvaluatorLaunch(CharSequence, CharSequence) - Constructor for class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
All-args constructor.
evaluatorLaunch(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time to launch an evaluator.
EvaluatorLaunch.Builder - Class in org.apache.reef.runtime.mesos.util
RecordBuilder for EvaluatorLaunch instances.
EvaluatorListSerializer - Interface in org.apache.reef.webserver
Interface for EvaluatorListSerializer.
EvaluatorManager - Class in org.apache.reef.runtime.common.driver.evaluator
Manages a single Evaluator instance including all lifecycle instances: (AllocatedEvaluator, CompletedEvaluator, FailedEvaluator).
EvaluatorManager.EvaluatorDescriptorName - Class in org.apache.reef.runtime.common.driver.evaluator
The Evaluator Host.
EvaluatorManager.EvaluatorDescriptorName() - Constructor for class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager.EvaluatorDescriptorName
 
EvaluatorManager.EvaluatorIdentifier - Class in org.apache.reef.runtime.common.driver.evaluator
The Evaluator Identifier.
EvaluatorManager.EvaluatorIdentifier() - Constructor for class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager.EvaluatorIdentifier
 
EvaluatorManagerFactory - Class in org.apache.reef.runtime.common.driver.evaluator
Helper class that creates new EvaluatorManager instances from allocations.
EvaluatorMemory - Class in org.apache.reef.examples.group.bgd.parameters
The memory used for each Evaluator.
EvaluatorMemory() - Constructor for class org.apache.reef.examples.group.bgd.parameters.EvaluatorMemory
 
EvaluatorMessageDispatcher - Class in org.apache.reef.runtime.common.driver.evaluator
Central dispatcher for all Evaluator related events.
EvaluatorPreserver - Interface in org.apache.reef.runtime.common.driver
A interface to preserve evaluators across driver restarts.
EvaluatorPreservingEvaluatorAllocatedHandler - Class in org.apache.reef.driver.restart
Records allocated evaluators for recovery on driver restart by using a DriverRuntimeRestartManager.
EvaluatorPreservingEvaluatorCompletedHandler - Class in org.apache.reef.driver.restart
Removes an evaluator from the evaluators to restart after it has completed.
EvaluatorPreservingEvaluatorFailedHandler - Class in org.apache.reef.driver.restart
Removes an evaluator from the evaluators to restart after it has failed.
EvaluatorProcess - Interface in org.apache.reef.driver.evaluator
Defines the setup of an evaluator's process.
EvaluatorProcessFactory<T> - Interface in org.apache.reef.driver.evaluator
Factory to create new evaluator process setups.
EvaluatorRelease - Class in org.apache.reef.runtime.mesos.util
 
EvaluatorRelease() - Constructor for class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Default constructor.
EvaluatorRelease(CharSequence) - Constructor for class org.apache.reef.runtime.mesos.util.EvaluatorRelease
All-args constructor.
EvaluatorRelease.Builder - Class in org.apache.reef.runtime.mesos.util
RecordBuilder for EvaluatorRelease instances.
EvaluatorRequest - Class in org.apache.reef.driver.evaluator
A request for one ore more Evaluators.
EvaluatorRequest.Builder<T extends EvaluatorRequest.Builder> - Class in org.apache.reef.driver.evaluator
EvaluatorRequests are build using this Builder.
EvaluatorRequest.Builder() - Constructor for class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
 
EvaluatorRequestor - Interface in org.apache.reef.driver.evaluator
Interface through which Evaluators can be requested.
EvaluatorRequestorBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for EvaluatorRequestor.
EvaluatorRequestorBridge(EvaluatorRequestor, boolean, LoggingScopeFactory, Set<String>) - Constructor for class org.apache.reef.javabridge.EvaluatorRequestorBridge
 
EvaluatorRequestorImpl - Class in org.apache.reef.runtime.common.driver
Implementation of the EvaluatorRequestor that translates the request and hands it down to the underlying RM.
EvaluatorRequestorImpl(ResourceCatalog, ResourceRequestHandler, LoggingScopeFactory) - Constructor for class org.apache.reef.runtime.common.driver.EvaluatorRequestorImpl
 
EvaluatorRequestorImpl.Builder - Class in org.apache.reef.runtime.common.driver
EvaluatorRequest.Builder extended with a new submit method.
EvaluatorRequestorImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.EvaluatorRequestorImpl.Builder
 
evaluatorRequestorPassToCs() - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to pass EvaluatorRequestor from Java to .Net.
evaluatorRequestSubmitToJavaDriver(int) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to submit Evaluator request from CLR to Java driver.
EvaluatorResourceManagerErrorHandler - Class in org.apache.reef.runtime.common.driver.evaluator
The error handler receives all resourcemanager errors from all evaluators in the system.
EvaluatorRestartInfo - Class in org.apache.reef.driver.restart
An object that encapsulates the information needed to construct an EvaluatorManager for a recovered evaluator on restart.
EvaluatorRestartState - Enum in org.apache.reef.driver.restart
The state that the evaluator is in in the driver restart process.
EvaluatorRuntimeProtocol - Class in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.AddContextProto - Class in org.apache.reef.proto
Protobuf type AddContextProto
EvaluatorRuntimeProtocol.AddContextProto.Builder - Class in org.apache.reef.proto
Protobuf type AddContextProto
EvaluatorRuntimeProtocol.AddContextProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.ContextControlProto - Class in org.apache.reef.proto
Protobuf type ContextControlProto
EvaluatorRuntimeProtocol.ContextControlProto.Builder - Class in org.apache.reef.proto
Protobuf type ContextControlProto
EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.ContextMessageProto - Class in org.apache.reef.proto
Protobuf type ContextMessageProto
EvaluatorRuntimeProtocol.ContextMessageProto.Builder - Class in org.apache.reef.proto
Protobuf type ContextMessageProto
EvaluatorRuntimeProtocol.ContextMessageProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.DoneEvaluatorProto - Class in org.apache.reef.proto
Protobuf type DoneEvaluatorProto
EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder - Class in org.apache.reef.proto
Protobuf type DoneEvaluatorProto
EvaluatorRuntimeProtocol.DoneEvaluatorProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.EvaluatorControlProto - Class in org.apache.reef.proto
Protobuf type EvaluatorControlProto
EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder - Class in org.apache.reef.proto
Protobuf type EvaluatorControlProto
EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto - Class in org.apache.reef.proto
Protobuf type EvaluatorHeartbeatProto
EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder - Class in org.apache.reef.proto
Protobuf type EvaluatorHeartbeatProto
EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.KillEvaluatorProto - Class in org.apache.reef.proto
Protobuf type KillEvaluatorProto
EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder - Class in org.apache.reef.proto
Protobuf type KillEvaluatorProto
EvaluatorRuntimeProtocol.KillEvaluatorProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.RemoveContextProto - Class in org.apache.reef.proto
Protobuf type RemoveContextProto
EvaluatorRuntimeProtocol.RemoveContextProto.Builder - Class in org.apache.reef.proto
Protobuf type RemoveContextProto
EvaluatorRuntimeProtocol.RemoveContextProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.StartTaskProto - Class in org.apache.reef.proto
Protobuf type StartTaskProto
EvaluatorRuntimeProtocol.StartTaskProto.Builder - Class in org.apache.reef.proto
Protobuf type StartTaskProto
EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.StopEvaluatorProto - Class in org.apache.reef.proto
Protobuf type StopEvaluatorProto
EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder - Class in org.apache.reef.proto
Protobuf type StopEvaluatorProto
EvaluatorRuntimeProtocol.StopEvaluatorProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.StopTaskProto - Class in org.apache.reef.proto
Protobuf type StopTaskProto
EvaluatorRuntimeProtocol.StopTaskProto.Builder - Class in org.apache.reef.proto
Protobuf type StopTaskProto
EvaluatorRuntimeProtocol.StopTaskProtoOrBuilder - Interface in org.apache.reef.proto
 
EvaluatorRuntimeProtocol.SuspendTaskProto - Class in org.apache.reef.proto
Protobuf type SuspendTaskProto
EvaluatorRuntimeProtocol.SuspendTaskProto.Builder - Class in org.apache.reef.proto
Protobuf type SuspendTaskProto
EvaluatorRuntimeProtocol.SuspendTaskProtoOrBuilder - Interface in org.apache.reef.proto
 
Evaluators - Class in org.apache.reef.runtime.common.driver.evaluator
Manages all Evaluators.
evaluators - Variable in class org.apache.reef.webserver.AvroEvaluatorList
Deprecated.
EvaluatorSide - Annotation Type in org.apache.reef.annotations.audience
Annotates interfaces meant to be used by Evaluators.
evaluatorsInfo - Variable in class org.apache.reef.webserver.AvroEvaluatorsInfo
Deprecated.
EvaluatorStatusPOJO - Class in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of EvaluatorStatusProto.
EvaluatorStatusPOJO(ReefServiceProtos.EvaluatorStatusProto) - Constructor for class org.apache.reef.runtime.common.driver.evaluator.pojos.EvaluatorStatusPOJO
 
evaluatorSubmit(int) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to submit a Evaluator request at java side.
EvaluatorTimeout - Class in org.apache.reef.runtime.common.driver.parameters
The evaluator timeout (how long to wait before deciding an evaluator is dead.
EvaluatorTimeout() - Constructor for class org.apache.reef.runtime.common.driver.parameters.EvaluatorTimeout
 
EvaluatorTimeoutException - Exception in org.apache.reef.exception
Thrown if an Evaluator hasn't been reporting for a while.
EvaluatorTimeoutException(String) - Constructor for exception org.apache.reef.exception.EvaluatorTimeoutException
 
EvaluatorTimeoutException(String, String, Throwable) - Constructor for exception org.apache.reef.exception.EvaluatorTimeoutException
 
EvaluatorTimeoutException(String, String) - Constructor for exception org.apache.reef.exception.EvaluatorTimeoutException
 
EvaluatorTimeoutException(String, Throwable) - Constructor for exception org.apache.reef.exception.EvaluatorTimeoutException
 
EvaluatorToPartitionStrategy<V extends org.apache.hadoop.mapred.InputSplit> - Interface in org.apache.reef.io.data.loading.api
Interface that tracks the mapping between evaluators and the data partitions assigned to those evaluators.
EvaluatorType - Enum in org.apache.reef.driver.evaluator
Enumeration of all Evaluator types supported by REEF.
evaluatorType - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Deprecated.
EVENT_STREAMS - Static variable in class org.apache.reef.io.watcher.WatcherConfiguration
Types of EventStream where events subscribed by Watcher will be reported.
EventHandler<T> - Interface in org.apache.reef.wake
Handler to process an event.
EventHandlerIdlenessSource - Class in org.apache.reef.runtime.common.driver.idle
Checks for idleness of the Event handlers.
EventPrinter<T> - Class in org.apache.reef.wake.examples.join
Event printer.
EventPrinter() - Constructor for class org.apache.reef.wake.examples.join.EventPrinter
 
EventSource<T> - Interface in org.apache.reef.wake.examples.p2p
The pull side of the interface: Clients implement this and register it with the PullToPush class.
EventStream - Interface in org.apache.reef.io.watcher
Write events to a certain destination.
EventStreams - Class in org.apache.reef.io.watcher.param
Set of EventStreams.
EventType - Enum in org.apache.reef.io.watcher
Event types that Watcher subscribes.
EWMA - Class in org.apache.reef.wake.metrics
Exponentially weighted moving average.
EWMA(double, long, TimeUnit) - Constructor for class org.apache.reef.wake.metrics.EWMA
Constructs an EWMA object.
EWMAParameters - Class in org.apache.reef.wake.metrics
Default EWMA parameters.
Example - Interface in org.apache.reef.examples.group.bgd.data
Base interface for Examples for linear models.
ExampleList - Class in org.apache.reef.examples.group.bgd
The list of BGD examples.
ExampleList(DataSet<LongWritable, Text>, Parser<String>) - Constructor for class org.apache.reef.examples.group.bgd.ExampleList
 
exception - Variable in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Deprecated.
EXCEPTION_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
EXCEPTION_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
ExceptionCodec - Interface in org.apache.reef.runtime.common.utils
(De-)serializes exceptions.
ExceptionHandler - Class in org.apache.reef.io.network.group.impl.driver
 
ExceptionHandler() - Constructor for class org.apache.reef.io.network.group.impl.driver.ExceptionHandler
 
ExceptionHandlingEventHandler<T> - Class in org.apache.reef.util
An ExceptionHandler that wraps another one, but catches all exceptions thrown by that one and forwards them to an ExceptionHandler.
ExceptionHandlingEventHandler(EventHandler<T>, EventHandler<Throwable>) - Constructor for class org.apache.reef.util.ExceptionHandlingEventHandler
 
Exceptions - Class in org.apache.reef.util
Utility class to deal with Exceptions.
execute() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletExecutionRequest
Execute the function using the input.
executeAggregation(List<TOutput>) - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
Execute the aggregate function using the list of outputs.
executeFunction(TInput) - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
Execute the user specified function.
EXECUTOR_SHUTDOWN_TIMEOUT - Static variable in class org.apache.reef.wake.WakeParameters
 
ExecutorServiceConstructor - Class in org.apache.reef.runtime.local.client
Used to make instances of ExecutorService via tang.
exist() - Method in interface org.apache.reef.io.network.group.api.GroupChanges
 
exist() - Method in class org.apache.reef.io.network.group.impl.GroupChangesImpl
 
EXIT_PREFIX - Static variable in class org.apache.reef.util.logging.LoggingScopeImpl
 
expandEnvironmentVariables(String) - Static method in class org.apache.reef.runtime.local.process.RunnableProcess
Replace {{ENV_VAR}} placeholders with the values of the corresponding environment variables.
expandEnvironmentVariables(List<String>) - Static method in class org.apache.reef.runtime.local.process.RunnableProcess
Replace {{ENV_VAR}} placeholders with the values of the corresponding environment variables.
expectAckFor(ReefNetworkGroupCommProtos.GroupCommMessage.Type, String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
To be called before sending a ctrl msg to the task represented by this node.
expectAckFor(ReefNetworkGroupCommProtos.GroupCommMessage.Type, String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
This needs to happen in line rather than in a stage because we need to note.
ExpectedTaskException - Exception in org.apache.reef.tests.library.exceptions
Expected Exception thrown by a Task.
ExpectedTaskException() - Constructor for exception org.apache.reef.tests.library.exceptions.ExpectedTaskException
 
ExpectedTaskException(String) - Constructor for exception org.apache.reef.tests.library.exceptions.ExpectedTaskException
 
ExpectedTaskException(String, Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.ExpectedTaskException
 
ExpectedTaskException(Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.ExpectedTaskException
 
ExpectedTaskException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.reef.tests.library.exceptions.ExpectedTaskException
 
ExpectedTaskFailureHandler - Class in org.apache.reef.tests.library.driver
A handler for FailedTask that will throw a DriverSideFailure unless the FailedTask was triggered by an ExpectedTaskException in the Task.
ExpectedTaskFailureHandler() - Constructor for class org.apache.reef.tests.library.driver.ExpectedTaskFailureHandler
 
ExtensibleLocalRuntimeConfiguration - Class in org.apache.reef.runtime.local.client
A ConfigurationModule to configure the local resourcemanager with extensibility point.
ExtensibleLocalRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
 
ExtensibleYarnClientConfiguration - Class in org.apache.reef.runtime.yarn.client
An extensible ConfigurationModule for the YARN resourcemanager.
ExtensibleYarnClientConfiguration() - Constructor for class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
 
ExternalConstructor<T> - Interface in org.apache.reef.tang
This interface allows legacy classes to be injected by ConfigurationBuilderImpl.
ExternalMap<T> - Interface in org.apache.reef.io
A Map interface for data that can be swapped out to other processes, managed by native code, paged to disk, stored remotely, etc...

F

FAIL_DRIVER_ON_EVALUATOR_LOG_ERROR - Static variable in class org.apache.reef.client.DriverRestartConfiguration
Parameter to determine whether the driver should fail or continue if there are evaluator preservation log failures.
FAIL_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
FAIL = 2;
FailClient - Class in org.apache.reef.tests.fail.driver
Client for the test REEF job that fails on different stages of execution.
FailDriver - Class in org.apache.reef.tests.fail.driver
Driver which fails on receiving certain message class.
FailDriver(String, EvaluatorRequestor, Clock) - Constructor for class org.apache.reef.tests.fail.driver.FailDriver
 
FailDriver.FailMsgClassName - Class in org.apache.reef.tests.fail.driver
Name of the message class to specify the failing message handler.
FailDriver.FailMsgClassName() - Constructor for class org.apache.reef.tests.fail.driver.FailDriver.FailMsgClassName
 
FailDriverDelayedMsg - Class in org.apache.reef.tests.fail.driver
Driver which fails due to delayed message.
FailDriverDelayedMsg(EvaluatorRequestor, Clock) - Constructor for class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg
 
FailDriverDelayedMsg.ActiveContextHandler - Class in org.apache.reef.tests.fail.driver
Handler for ActiveContext.
FailDriverDelayedMsg.ActiveContextHandler() - Constructor for class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.ActiveContextHandler
 
FailDriverDelayedMsg.AllocatedEvaluatorHandler - Class in org.apache.reef.tests.fail.driver
Handler for AllocatedEvaluator.
FailDriverDelayedMsg.AllocatedEvaluatorHandler() - Constructor for class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.AllocatedEvaluatorHandler
 
FailDriverDelayedMsg.RunningTaskHandler - Class in org.apache.reef.tests.fail.driver
Handler for RunningTask.
FailDriverDelayedMsg.RunningTaskHandler() - Constructor for class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.RunningTaskHandler
 
FailDriverDelayedMsg.StartHandler - Class in org.apache.reef.tests.fail.driver
Handler for StartTime.
FailDriverDelayedMsg.StartHandler() - Constructor for class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.StartHandler
 
FailDriverDelayedMsg.TaskMessageHandler - Class in org.apache.reef.tests.fail.driver
Handler for TaskMessage.
FailDriverDelayedMsg.TaskMessageHandler() - Constructor for class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.TaskMessageHandler
 
FailDriverOnEvaluatorLogErrors - Class in org.apache.reef.driver.parameters
Whether to fail driver on Evaluator preservation log errors.
FAILED - Static variable in class org.apache.reef.client.LauncherStatus
 
failed(Throwable) - Static method in class org.apache.reef.client.LauncherStatus
 
failed(Optional<Throwable>) - Static method in class org.apache.reef.client.LauncherStatus
 
FAILED_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.State
FAILED = 4;
FailedContext - Interface in org.apache.reef.driver.context
Represents Context that failed.
FailedContextBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for FailedContext.
FailedContextBridge(FailedContext, ActiveContextBridgeFactory) - Constructor for class org.apache.reef.javabridge.FailedContextBridge
 
FailedContextHandler - Class in org.apache.reef.tests.watcher
Failing handler for ContextStart (throws exception upon start).
FailedContextImpl - Class in org.apache.reef.runtime.common.driver.context
Driver-Side representation of a failed context.
FailedContextImpl(String, String, Optional<String>, Optional<Throwable>, Optional<byte[]>, Optional<ActiveContext>, EvaluatorDescriptor, String) - Constructor for class org.apache.reef.runtime.common.driver.context.FailedContextImpl
 
failedContextList - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Deprecated.
FailedEvaluator - Interface in org.apache.reef.driver.evaluator
Represents an Evaluator that became unavailable.
FailedEvaluatorBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for FailedEvaluator.
FailedEvaluatorBridge(FailedEvaluator, EvaluatorRequestor, boolean, LoggingScopeFactory, ActiveContextBridgeFactory, Set<String>) - Constructor for class org.apache.reef.javabridge.FailedEvaluatorBridge
 
FailedJob - Class in org.apache.reef.client
An error message that REEF Client receives when there is a user error in REEF job.
FailedJob(String, String, Optional<String>, Optional<Throwable>, Optional<byte[]>) - Constructor for class org.apache.reef.client.FailedJob
 
FailedRuntime - Class in org.apache.reef.client
Error message that REEF Client gets when there is an error in REEF resourcemanager.
FailedRuntime(ReefServiceProtos.RuntimeErrorProto) - Constructor for class org.apache.reef.client.FailedRuntime
Create a new Failure object out of protobuf data.
FailedTask - Class in org.apache.reef.driver.task
An error message that REEF Driver gets from a failed Task.
FailedTask(String, String, Optional<String>, Optional<Throwable>, Optional<byte[]>, Optional<ActiveContext>) - Constructor for class org.apache.reef.driver.task.FailedTask
 
failedTask - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Deprecated.
FailedTaskBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for FailedTask.
FailedTaskBridge(FailedTask, ActiveContextBridgeFactory) - Constructor for class org.apache.reef.javabridge.FailedTaskBridge
 
FailedTaskStartHandler - Class in org.apache.reef.tests.watcher
Failing handler for TaskStart (throws exception upon start).
failTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
FailTask - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we create it.
FailTask() - Constructor for class org.apache.reef.tests.fail.task.FailTask
 
FailTaskCall - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we run it.
FailTaskCall() - Constructor for class org.apache.reef.tests.fail.task.FailTaskCall
 
FailTaskClose - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we close it.
FailTaskClose() - Constructor for class org.apache.reef.tests.fail.task.FailTaskClose
 
FailTaskMsg - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we send it a message.
FailTaskMsg() - Constructor for class org.apache.reef.tests.fail.task.FailTaskMsg
 
FailTaskStart - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we invoke it.
FailTaskStart() - Constructor for class org.apache.reef.tests.fail.task.FailTaskStart
 
FailTaskStop - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we stop it.
FailTaskStop() - Constructor for class org.apache.reef.tests.fail.task.FailTaskStop
 
FailTaskStop.CloseEventHandler - Class in org.apache.reef.tests.fail.task
Handler for CloseEvent.
FailTaskStop.CloseEventHandler() - Constructor for class org.apache.reef.tests.fail.task.FailTaskStop.CloseEventHandler
 
FailTaskSuspend - Class in org.apache.reef.tests.fail.task
A basic task that just fails when we invoke it.
FailTaskSuspend() - Constructor for class org.apache.reef.tests.fail.task.FailTaskSuspend
 
Failure - Interface in org.apache.reef.common
Common interface for all error messages in REEF.
failure - Variable in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Deprecated.
failure - Variable in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Deprecated.
FailureDriver - Class in org.apache.reef.tests.evaluator.failure
Driver for failure test.
FailureDriver(int, int, EvaluatorRequestor) - Constructor for class org.apache.reef.tests.evaluator.failure.FailureDriver
 
FailureProbability - Class in org.apache.reef.examples.group.broadcast.parameters
 
FailureProbability() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.FailureProbability
 
FailureREEF - Class in org.apache.reef.tests.evaluator.failure
Entry point class for REEF failure test.
FailureREEF.Local - Class in org.apache.reef.tests.evaluator.failure
Command line parameter = true to run locally, or false to run on YARN.
FailureREEF.Local() - Constructor for class org.apache.reef.tests.evaluator.failure.FailureREEF.Local
 
FailureREEF.TimeOut - Class in org.apache.reef.tests.evaluator.failure
Number of minutes before timeout.
FailureREEF.TimeOut() - Constructor for class org.apache.reef.tests.evaluator.failure.FailureREEF.TimeOut
 
FIFTEEN_MINUTES - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
FileEventStream - Class in org.apache.reef.io.watcher
Write events to a file in the root directory of the driver.
FileEventStream.Path - Class in org.apache.reef.io.watcher
 
FileEventStream.Path() - Constructor for class org.apache.reef.io.watcher.FileEventStream.Path
 
FileResource - Interface in org.apache.reef.runtime.common.files
A File Resource with a FileType for use by Runtimes.
FileResourceImpl - Class in org.apache.reef.runtime.common.files
Default POJO implementation of FileResource.
FileResourceImpl.Builder - Class in org.apache.reef.runtime.common.files
Builder used to create FileResource instances.
FileResourceImpl.Builder() - Constructor for class org.apache.reef.runtime.common.files.FileResourceImpl.Builder
 
fileSystemUrl - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Deprecated.
FileSystemUrl - Class in org.apache.reef.runtime.yarn.driver.parameters
The file system URL.
FileType - Enum in org.apache.reef.runtime.common.files
Type of a File Resource used by Runtimes.
filter(ArrayList<String>, String, String) - Static method in class org.apache.reef.util.logging.LogParser
filter array list of lines and get the last portion of the line separated by the token, like ":::".
FINAL_STATUS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
finalise() - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
This signals to the service that no more.
finalise() - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
findStages(ArrayList<String>, String[]) - Static method in class org.apache.reef.util.logging.LogParser
find lines that contain stage indicators.
FINISHED_TIME - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
fireEvaluatorAllocatedEvent() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Fires the EvaluatorAllocatedEvent to the handlers.
FIVE_MINUTES - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
FlatTopology - Class in org.apache.reef.io.network.group.impl.driver
Implements a one level Tree Topology.
FlexiblePreemptionEvent - Interface in org.apache.reef.driver
Represents a flexible preemption request: It contains:
flush() - Method in class org.apache.reef.io.storage.FramingOutputStream
 
flush() - Method in class org.apache.reef.util.logging.CLRBufferedLogHandler
 
flush() - Method in class org.apache.reef.util.logging.DFSHandler
 
FORCE_CLOSED - Static variable in class org.apache.reef.client.LauncherStatus
 
forkInjector() - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
forkInjector(Configuration...) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
forkInjector(Configuration...) - Method in interface org.apache.reef.tang.Injector
Create a copy of this Injector that inherits the instances that were already created by this Injector, but reflects additional Configuration objects.
forkInjector() - Method in interface org.apache.reef.tang.Injector
 
ForkPoolStage<T> - Class in org.apache.reef.wake.impl
This Wake event handling stage uses a ForkJoinPool to submit tasks.
ForkPoolStage(String, EventHandler<T>, WakeSharedPool) - Constructor for class org.apache.reef.wake.impl.ForkPoolStage
 
ForkPoolStage(EventHandler<T>, WakeSharedPool) - Constructor for class org.apache.reef.wake.impl.ForkPoolStage
 
format(LogRecord) - Method in class org.apache.reef.util.logging.ThreadLogFormatter
Format the log string.
FORMATTER_OPTION - Static variable in class org.apache.reef.util.logging.DFSHandler
 
formatVariable(String) - Static method in class org.apache.reef.util.OSUtils
Formats the given variable for expansion by Windows (%VARIABLE%) or Linux ($VARIABLE).
frameworkMessage(ExecutorDriver, byte[]) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
FramingInputStream - Class in org.apache.reef.io.storage
 
FramingInputStream(InputStream) - Constructor for class org.apache.reef.io.storage.FramingInputStream
 
FramingOutputStream - Class in org.apache.reef.io.storage
 
FramingOutputStream(OutputStream) - Constructor for class org.apache.reef.io.storage.FramingOutputStream
 
FramingTupleDeserializer<K,V> - Class in org.apache.reef.io.storage
 
FramingTupleDeserializer(Deserializer<K, InputStream>, Deserializer<V, InputStream>) - Constructor for class org.apache.reef.io.storage.FramingTupleDeserializer
 
FramingTupleSerializer<K,V> - Class in org.apache.reef.io.storage
 
FramingTupleSerializer(Serializer<K, OutputStream>, Serializer<V, OutputStream>) - Constructor for class org.apache.reef.io.storage.FramingTupleSerializer
 
from(String, byte[]) - Static method in class org.apache.reef.evaluator.context.ContextMessage
 
from(Configuration, Class<? extends Name<?>>...) - Static method in class org.apache.reef.examples.group.bgd.utils.SubConfiguration
 
from(String, byte[]) - Static method in class org.apache.reef.task.TaskMessage
 
fromAvro(AvroConfiguration) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
Converts a given AvroConfiguration to Configuration.
fromAvro(AvroConfiguration, ClassHierarchy) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
Converts a given AvroConfiguration to Configuration.
fromAvro(AvroNode) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
Deserialize the ClassHierarchy from the AvroNode.
fromByteArray(byte[]) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Deserializes a ClassHierarchy from a byte[] created with toByteArray().
fromByteArray(byte[]) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromByteArray(byte[], ClassHierarchy) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromByteArray(byte[]) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Loads a Configuration from a byte[] created with toByteArray().
fromByteArray(byte[], ClassHierarchy) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Loads a Configuration from a byte[] created with toByteArray().
fromByteArray(byte[]) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
fromBytes(byte[]) - Method in class org.apache.reef.javabridge.utils.DefinedRuntimesSerializer
Deserializes avro definition.
fromBytes(byte[]) - Method in interface org.apache.reef.runtime.common.utils.ExceptionCodec
Deserializes a Throwable that has been serialized using toBytes().
fromBytes(Optional<byte[]>) - Method in interface org.apache.reef.runtime.common.utils.ExceptionCodec
 
fromBytes(byte[]) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Convert bytes to AvroHttpRequest.
fromCommandLine(String[]) - Static method in class org.apache.reef.examples.group.bgd.BGDClient
 
fromConfiguration(Configuration...) - Static method in class org.apache.reef.runtime.common.REEFEnvironment
Create a new REEF environment.
fromConfiguration(UserCredentials, Configuration...) - Static method in class org.apache.reef.runtime.common.REEFEnvironment
Create a new REEF environment.
fromEnvironment() - Static method in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
 
fromEnvironment() - Static method in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
 
fromFile(File) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Loads a ClassHierarchy from a file created with toFile().
fromFile(File) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromFile(File, ClassHierarchy) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromFile(File) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Loads a Configuration from a File created with toFile().
fromFile(File, ClassHierarchy) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Loads a Configuration from a File created with toFile().
fromFile(File) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
fromFile(File) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Convert a file to AvroHttpRequest.
fromProto(ReefServiceProtos.State) - Static method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Get a driver-side state given the proto.
fromString(String) - Static method in class org.apache.reef.io.data.loading.impl.AvroEvaluatorRequestSerializer
Deserialize EvaluatorRequest.
fromString(String) - Method in class org.apache.reef.runtime.multi.utils.MultiRuntimeDefinitionSerializer
Deserializes avro definition.
fromString(String) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Deserializes a ClassHierarchy from a String created with toString().
fromString(String) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromString(String, ClassHierarchy) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromString(String) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Decodes a String generated via toString().
fromString(String, ClassHierarchy) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Decodes a String generated via toString().
fromString(String) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
fromString(String) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Convert JSON String to AvroHttpRequest.
fromTextFile(File) - Static method in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
Returns a HDInsight runtime configuration from the credentials stored in the given file.
fromTextFile(File) - Static method in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
Returns an UNSAFE HDInsight runtime configuration from the credentials stored in the given file.
fromTextFile(File) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Loads a ClassHierarchy from a text file created with toTextFile().
fromTextFile(File) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromTextFile(File, ClassHierarchy) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
fromTextFile(File) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Loads a Configuration from a File created with toFile().
fromTextFile(File, ClassHierarchy) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Loads a Configuration from a File created with toFile() with ClassHierarchy.
fromTextFile(File) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
FSCheckpointID - Class in org.apache.reef.io.checkpoint.fs
A FileSystem based checkpoint ID contains reference to the Path where the checkpoint has been saved.
FSCheckpointID() - Constructor for class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
FSCheckpointID(Path) - Constructor for class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
FSCheckpointService - Class in org.apache.reef.io.checkpoint.fs
A FileSystem based CheckpointService.
FSCheckpointService(FileSystem, Path, CheckpointNamingService, short) - Constructor for class org.apache.reef.io.checkpoint.fs.FSCheckpointService
 
FSCheckPointServiceConfiguration - Class in org.apache.reef.io.checkpoint.fs
ConfigurationModule for the FSCheckpointService.
FSCheckPointServiceConfiguration() - Constructor for class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration
 
FSCheckPointServiceConfiguration.FileSystemConstructor - Class in org.apache.reef.io.checkpoint.fs
Constructor for Hadoop FileSystem instances.
FSCheckPointServiceConfiguration.FileSystemConstructor(boolean) - Constructor for class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration.FileSystemConstructor
 
FULL_ARG_CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
FULL_ARG_CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
FULL_CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
FULL_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
fullArgClassName - Variable in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Deprecated.
fullArgClassName - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
fullClassName - Variable in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Deprecated.
fullName - Variable in class org.apache.reef.tang.implementation.avro.AvroNode
Deprecated.
FUTURE_CALLBACK_THREAD_POOL_SIZE - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Size of threadpool for callbacks on VortexFuture.
FutureCallback<V> - Interface in org.apache.reef.vortex.api
A callback for accepting the results of a VortexFuture computation asynchronously.

G

Gather - Interface in org.apache.reef.io.network.group.api.operators
MPI Gather Operator.
Gather.Receiver<T> - Interface in org.apache.reef.io.network.group.api.operators
Receiver or Root.
Gather.Sender<T> - Interface in org.apache.reef.io.network.group.api.operators
Senders or non-roots.
Gather_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
Gather = 2;
GatherOperatorSpec - Class in org.apache.reef.io.network.group.impl.config
The specification for the Gather operator.
GatherOperatorSpec(String, Class<? extends Codec>) - Constructor for class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec
 
GatherOperatorSpec.Builder - Class in org.apache.reef.io.network.group.impl.config
 
GatherOperatorSpec.Builder() - Constructor for class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec.Builder
 
GatherReceiver<T> - Class in org.apache.reef.io.network.group.impl.operators
 
GatherReceiver(String, String, String, Codec<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient) - Constructor for class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
GatherSender<T> - Class in org.apache.reef.io.network.group.impl.operators
 
GatherSender(String, String, String, Codec<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient) - Constructor for class org.apache.reef.io.network.group.impl.operators.GatherSender
 
get(int) - Method in class org.apache.reef.bridge.message.Acknowledgement
 
get(int) - Method in class org.apache.reef.bridge.message.BridgeInterop
 
get(int) - Method in class org.apache.reef.bridge.message.Header
 
get(int) - Method in class org.apache.reef.bridge.message.Protocol
 
get(int) - Method in class org.apache.reef.bridge.message.SetupBridge
 
get(int) - Method in class org.apache.reef.bridge.message.SystemOnStart
 
get() - Method in class org.apache.reef.client.JobMessage
Get the message sent by the Job.
get() - Method in interface org.apache.reef.driver.context.ContextMessage
 
get() - Method in interface org.apache.reef.driver.task.TaskMessage
 
get() - Method in class org.apache.reef.evaluator.context.ContextMessage
 
get(int) - Method in class org.apache.reef.examples.group.utils.math.DenseVector
 
get(int) - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
Access the value of the Vector at dimension i.
get(int) - Method in class org.apache.reef.examples.group.utils.math.SparseVector
 
get(int) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
get(CharSequence) - Method in interface org.apache.reef.io.ExternalMap
Element access.
get() - Method in interface org.apache.reef.io.Message
Message payload.
get(K) - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
get(L) - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
get() - Method in class org.apache.reef.io.network.group.impl.utils.CountingSemaphore
 
get(K) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
get(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
get(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
get(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
get(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
get(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
get(Identifier, Callable<InetSocketAddress>) - Method in class org.apache.reef.io.network.naming.NameCache
Gets an address for an identifier.
get(CharSequence) - Method in class org.apache.reef.io.storage.ram.CodecRamMap
 
get(CharSequence) - Method in class org.apache.reef.io.storage.ram.RamMap
 
get(int) - Method in class org.apache.reef.io.watcher.common.AvroFailure
 
get(int) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
get(int) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
get(int) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
get(int) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
get(int) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
get(int) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
get - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Deprecated.
get(int) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
get(int) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
get(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
get(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
get(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
get(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
get(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
get - Variable in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Deprecated.
get(int) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
get(int) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
get(int) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
get - Variable in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Deprecated.
get(int) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
get - Variable in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Deprecated.
get(int) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
get(int) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
get(int) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
get(int) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
get(int) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
get(int) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
 
get(int) - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
get() - Method in class org.apache.reef.javabridge.CompletedTaskBridge
 
get() - Method in class org.apache.reef.javabridge.ContextMessageBridge
 
get() - Method in class org.apache.reef.javabridge.SuspendedTaskBridge
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
get(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
get() - Method in class org.apache.reef.runtime.common.driver.context.ContextMessageImpl
 
get(String) - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
 
get() - Method in class org.apache.reef.runtime.common.driver.task.CompletedTaskImpl
 
get() - Method in class org.apache.reef.runtime.common.driver.task.SuspendedTaskImpl
 
get() - Method in class org.apache.reef.runtime.common.driver.task.TaskMessageImpl
 
get(int) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
get(int) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
get(int) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
get(int) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
get(int) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
get() - Method in class org.apache.reef.runtime.yarn.client.unmanaged.YarnProxyUser
Get the YARN proxy user information.
get(int) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
get(int) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
get(int) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
get(int) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
get(int) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
get(int) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
get(int) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
 
get(int) - Method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
get(String) - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
get() - Method in class org.apache.reef.tang.InjectionFuture
 
get(long, TimeUnit) - Method in class org.apache.reef.tang.InjectionFuture
 
get(String) - Method in interface org.apache.reef.tang.types.Node
 
get(Object) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
get(Object) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
get() - Method in interface org.apache.reef.task.events.CloseEvent
 
get() - Method in interface org.apache.reef.task.events.DriverMessage
 
get() - Method in interface org.apache.reef.task.events.SuspendEvent
 
get() - Method in class org.apache.reef.task.TaskMessage
 
get(K, Callable<V>) - Method in interface org.apache.reef.util.cache.Cache
Returns a value for the key if cached; otherwise creates, caches and returns.
get(K, Callable<V>) - Method in class org.apache.reef.util.cache.CacheImpl
 
get() - Method in class org.apache.reef.util.Optional
 
get() - Method in class org.apache.reef.util.SetOnce
 
get() - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
 
get(long, TimeUnit) - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
 
get() - Method in class org.apache.reef.vortex.api.VortexFuture
Infinitely wait for the result of the task.
get(long, TimeUnit) - Method in class org.apache.reef.vortex.api.VortexFuture
Wait a certain period of time for the result of the task.
get(SocketAddress) - Method in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Returns a link for the remote address if already cached; otherwise, returns null.
get(SocketAddress) - Method in interface org.apache.reef.wake.remote.transport.Transport
Returns a link for the remote address if already cached; otherwise, returns null.
get(int) - Method in class org.apache.reef.webserver.AvroDriverInfo
 
get(int) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
 
get(int) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
 
get(int) - Method in class org.apache.reef.webserver.AvroEvaluatorList
 
get(int) - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
get(int) - Method in class org.apache.reef.webserver.AvroHttpRequest
 
get(int) - Method in class org.apache.reef.webserver.AvroReefServiceInfo
 
get(int) - Method in class org.apache.reef.webserver.HeaderEntry
 
get(String) - Method in class org.apache.reef.webserver.ReefEventStateManager
get a value from evaluators by key.
get15mEWMAThp() - Method in class org.apache.reef.wake.metrics.Meter
Gets the 15-minute EWMA throughput.
get1mEWMAThp() - Method in class org.apache.reef.wake.metrics.Meter
Gets the 1-minute EWMA throughput.
get5mEWMAThp() - Method in class org.apache.reef.wake.metrics.Meter
Gets the 5-minute EWMA throughput.
getActiveContext() - Method in interface org.apache.reef.driver.task.CompletedTask
 
getActiveContext() - Method in class org.apache.reef.driver.task.FailedTask
Access the context the task ran (and crashed) on, if it could be recovered.
getActiveContext() - Method in interface org.apache.reef.driver.task.RunningTask
 
getActiveContext() - Method in interface org.apache.reef.driver.task.SuspendedTask
 
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Gets the value of the 'activeContext' field.
getActiveContext() - Method in class org.apache.reef.javabridge.CompletedTaskBridge
 
getActiveContext() - Method in class org.apache.reef.javabridge.FailedTaskBridge
 
getActiveContext() - Method in class org.apache.reef.javabridge.RunningTaskBridge
 
getActiveContext() - Method in class org.apache.reef.javabridge.SuspendedTaskBridge
 
getActiveContext() - Method in class org.apache.reef.runtime.common.driver.task.CompletedTaskImpl
 
getActiveContext() - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
getActiveContext() - Method in class org.apache.reef.runtime.common.driver.task.SuspendedTaskImpl
 
getActiveContextBridge(ActiveContext) - Method in class org.apache.reef.javabridge.ActiveContextBridgeFactory
Instantiates a new ActiveContextBridge.
getActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Gets the Builder instance for the 'activeContext' field and creates one if it doesn't exist yet.
getActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Gets the Builder instance for the 'activeContext' field and creates one if it doesn't exist yet.
getActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Gets the Builder instance for the 'activeContext' field and creates one if it doesn't exist yet.
getActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Gets the Builder instance for the 'activeContext' field and creates one if it doesn't exist yet.
getActiveContextHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getActiveCount() - Method in class org.apache.reef.wake.impl.ThreadPoolStage
Gets the active count of this stage.
getActiveSlaveTasks() - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
 
getActiveSlaveTasks() - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getAddContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
getAddContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .AddContextProto add_context = 5;
getAddContext() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .AddContextProto add_context = 5;
getAddContextBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
getAddContextOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
getAddContextOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .AddContextProto add_context = 5;
getAddContextOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .AddContextProto add_context = 5;
getAddress() - Method in interface org.apache.reef.io.naming.NameAssignment
Returns an address of this object.
getAddress() - Method in class org.apache.reef.io.network.naming.NameAssignmentTuple
Gets an address.
getAggregatedInputs() - Method in class org.apache.reef.vortex.api.AggregateResult
 
getAggregatedInputs() - Method in class org.apache.reef.vortex.api.AggregateResultSynchronous
 
getAggregateFunction() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
 
getAggregateFunctionId() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregateExecutionRequest
 
getAggregateFunctionId() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
 
getAggregateResult() - Method in class org.apache.reef.vortex.api.AggregateResult
 
getAggregateResult() - Method in class org.apache.reef.vortex.api.AggregateResultSynchronous
 
getAliasLanguage() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_language = 9;
getAliasLanguage() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string alias_language = 9;
getAliasLanguage() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string alias_language = 9;
getAliasLanguageBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_language = 9;
getAliasLanguageBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string alias_language = 9;
getAliasLanguageBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string alias_language = 9;
getAliasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_name = 8;
getAliasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string alias_name = 8;
getAliasName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string alias_name = 8;
getAliasNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_name = 8;
getAliasNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string alias_name = 8;
getAliasNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string alias_name = 8;
getAll(Set<? extends CharSequence>) - Method in interface org.apache.reef.io.ExternalMap
 
getAll(Set<? extends CharSequence>) - Method in class org.apache.reef.io.storage.ram.CodecRamMap
 
getAll(Set<? extends CharSequence>) - Method in class org.apache.reef.io.storage.ram.RamMap
 
getAllClasspathJars() - Static method in class org.apache.reef.util.EnvironmentUtils
Get a set of all classpath entries EXCEPT of those under $JAVA_HOME, $YARN_HOME, and $HADOOP_HOME.
getAllClasspathJars(String...) - Static method in class org.apache.reef.util.EnvironmentUtils
Get a set of all classpath entries EXCEPT of those under excludeEnv directories.
getAllConstructors() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
getAllConstructors() - Method in interface org.apache.reef.tang.types.ClassNode
 
GetAllIterable<T> - Class in org.apache.reef.io.storage.util
 
GetAllIterable(Set<? extends CharSequence>, ExternalMap<T>) - Constructor for class org.apache.reef.io.storage.util.GetAllIterable
 
getAllocatedEvaluatorBridge(AllocatedEvaluator, String) - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridgeFactory
Instantiates a new AllocatedEvaluatorBridge.
getAllocatedEvaluatorHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getAllocatedMB() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getAllocatedVCores() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getAmContainerLogs() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getAmContainerSpec() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getAmHostHttpAddress() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getApp() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationResponse
 
getAppAttemptId() - Static method in class org.apache.reef.runtime.yarn.util.YarnUtilities
 
getAppAttemptId(String) - Static method in class org.apache.reef.runtime.yarn.util.YarnUtilities
 
getApplication(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.HDInsightInstance
Gets the application state given a YARN application ID.
getApplicationAcls() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
getApplicationId() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionHandler
Get the RM application ID.
getApplicationId() - Method in class org.apache.reef.runtime.hdinsight.client.HDInsightJobSubmissionHandler
Get the RM application ID.
getApplicationId() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationID
 
getApplicationId() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getApplicationID() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.HDInsightInstance
Request an ApplicationId from the cluster.
getApplicationId() - Method in class org.apache.reef.runtime.local.client.LocalJobSubmissionHandler
Get the RM application ID.
getApplicationId() - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
 
getApplicationId() - Static method in class org.apache.reef.runtime.yarn.util.YarnUtilities
 
getApplicationName() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getApplicationState() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationResponse
 
getApplicationStates() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ListApplicationResponse
 
getApplicationTags() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getApplicationType() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getApplicationType() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getApplicationURL(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.HDInsightInstance
 
getApps() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ListApplicationResponse
 
getArgs() - Method in class org.apache.reef.tang.implementation.Constructor
 
getArgs() - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
getArgs(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgs(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
repeated .ConstructorArg args = 2;
getArgs(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
repeated .ConstructorArg args = 2;
getArgs(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgs(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
repeated .InjectionPlan args = 1;
getArgs(int) - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.ConstructorOrBuilder
repeated .InjectionPlan args = 1;
getArgs() - Method in interface org.apache.reef.tang.types.ConstructorDef
 
getArgsBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgsBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgsBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgsBuilderList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgsCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgsCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
repeated .ConstructorArg args = 2;
getArgsCount() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
repeated .ConstructorArg args = 2;
getArgsCount() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgsCount() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
repeated .InjectionPlan args = 1;
getArgsCount() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.ConstructorOrBuilder
repeated .InjectionPlan args = 1;
getArgsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
repeated .ConstructorArg args = 2;
getArgsList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
repeated .ConstructorArg args = 2;
getArgsList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgsList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
repeated .InjectionPlan args = 1;
getArgsList() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.ConstructorOrBuilder
repeated .InjectionPlan args = 1;
getArgsOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgsOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
repeated .ConstructorArg args = 2;
getArgsOrBuilder(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
repeated .ConstructorArg args = 2;
getArgsOrBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgsOrBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
repeated .InjectionPlan args = 1;
getArgsOrBuilder(int) - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.ConstructorOrBuilder
repeated .InjectionPlan args = 1;
getArgsOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
getArgsOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
repeated .ConstructorArg args = 2;
getArgsOrBuilderList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
repeated .ConstructorArg args = 2;
getArgsOrBuilderList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
getArgsOrBuilderList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
repeated .InjectionPlan args = 1;
getArgsOrBuilderList() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.ConstructorOrBuilder
repeated .InjectionPlan args = 1;
getAsError() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Gets the value of the 'asError' field.
getAsError() - Method in class org.apache.reef.io.watcher.common.AvroFailure
Gets the value of the 'asError' field.
getAspect() - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getAspect() - Method in interface org.apache.reef.tang.Injector
Allows InjectionFuture to tell the aspect when get() is invoked.
getBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Gets the value of the 'base' field.
getBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Gets the value of the 'base' field.
getBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Gets the value of the 'base' field.
getBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Gets the value of the 'base' field.
getBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Gets the value of the 'base' field.
getBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Gets the value of the 'base' field.
getBaseBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Gets the Builder instance for the 'base' field and creates one if it doesn't exist yet.
getBaseBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Gets the Builder instance for the 'base' field and creates one if it doesn't exist yet.
getBaseBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Gets the Builder instance for the 'base' field and creates one if it doesn't exist yet.
getBindings() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Gets the value of the 'Bindings' field.
getBindings() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Gets the value of the 'Bindings' field.
getBoundConstructor(ClassNode<T>) - Method in interface org.apache.reef.tang.Configuration
Return the bound constructor.
getBoundConstructor(ClassNode<T>) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundConstructors() - Method in interface org.apache.reef.tang.Configuration
 
getBoundConstructors() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundImplementation(ClassNode<T>) - Method in interface org.apache.reef.tang.Configuration
Returns the bound implementation.
getBoundImplementation(ClassNode<T>) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundImplementations() - Method in interface org.apache.reef.tang.Configuration
 
getBoundImplementations() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundList(NamedParameterNode<List<?>>) - Method in interface org.apache.reef.tang.Configuration
Get the list bound to a given NamedParameterNode.
getBoundList(NamedParameterNode<List<?>>) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundLists() - Method in interface org.apache.reef.tang.Configuration
 
getBoundLists() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundNamedParameters() - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
getBoundSet(NamedParameterNode<Set<?>>) - Method in interface org.apache.reef.tang.Configuration
Obtain the set of class hierarchy nodes or strings that were bound to a given NamedParameterNode.
getBoundSet(NamedParameterNode<Set<?>>) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBoundSets() - Method in interface org.apache.reef.tang.Configuration
 
getBoundSets() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getBridgeExeName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getBroadcastReceiver(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
The broadcast receiver configured on this communication group.
getBroadcastReceiver(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getBroadcastSender(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
The broadcast sender configured on this communication group.
getBroadcastSender(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getBuilder() - Method in class org.apache.reef.tang.formats.CommandLine
 
getBuilder() - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
getBuilder() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getCause() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Gets the value of the 'cause' field.
getCause() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Gets the value of the 'cause' field.
getCause() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getChildren() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
getChildren() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getChildren() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
getChildren() - Method in class org.apache.reef.io.network.group.impl.driver.TopologySimpleNode
 
getChildren() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getChildren() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the value of the 'children' field.
getChildren() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Gets the value of the 'children' field.
getChildren() - Method in class org.apache.reef.tang.implementation.Constructor
Get child elements of the injection plan tree.
getChildren() - Method in class org.apache.reef.tang.implementation.InjectionPlan
Get child elements of the injection plan tree.
getChildren() - Method in class org.apache.reef.tang.implementation.Subplan
Get child elements of the injection plan tree.
getChildren() - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
getChildren(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildren(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
repeated .Node children = 6;
getChildren(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
repeated .Node children = 6;
getChildren() - Method in interface org.apache.reef.tang.types.Node
 
getChildren() - Method in interface org.apache.reef.tang.types.Traversable
 
getChildrenBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildrenBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildrenCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildrenCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
repeated .Node children = 6;
getChildrenCount() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
repeated .Node children = 6;
getChildrenData() - Method in class org.apache.reef.io.network.group.impl.utils.ScatterData
Returns a map of data that is assigned to this node's children.
getChildrenList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildrenList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
repeated .Node children = 6;
getChildrenList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
repeated .Node children = 6;
getChildrenOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildrenOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
repeated .Node children = 6;
getChildrenOrBuilder(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
repeated .Node children = 6;
getChildrenOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
getChildrenOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
repeated .Node children = 6;
getChildrenOrBuilderList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
repeated .Node children = 6;
getClass(String) - Static method in class org.apache.reef.io.network.group.impl.utils.Utils
 
getClassHierarchy() - Method in interface org.apache.reef.tang.Configuration
Configuration objects are associated with the ClassHierarchy objects that were used during validation.
getClassHierarchy() - Method in interface org.apache.reef.tang.ConfigurationBuilder
Each ConfigurationBuilder instance is associated with a ClassHierarchy.
getClassHierarchy() - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
getClassHierarchy() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getClassLocation(Class<?>) - Static method in class org.apache.reef.util.EnvironmentUtils
 
getClassName() - Method in class org.apache.reef.bridge.message.Header.Builder
Gets the value of the 'className' field.
getClassName() - Method in class org.apache.reef.bridge.message.Header
Gets the value of the 'className' field.
getClassName() - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
getClassName() - Method in interface org.apache.reef.tang.types.ConstructorDef
 
getClassName() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required string className = 1;
getClassName() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
required string className = 1;
getClassName() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBufOrBuilder
required string className = 1;
getClassNameBytes() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required string className = 1;
getClassNameBytes() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
required string className = 1;
getClassNameBytes() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBufOrBuilder
required string className = 1;
getClassNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the value of the 'classNode' field.
getClassNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Gets the value of the 'classNode' field.
getClassNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
getClassNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .ClassNode class_node = 3;
getClassNode() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .ClassNode class_node = 3;
getClassNodeBuilder() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the Builder instance for the 'classNode' field and creates one if it doesn't exist yet.
getClassNodeBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
getClassNodeOrBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
getClassNodeOrBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .ClassNode class_node = 3;
getClassNodeOrBuilder() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .ClassNode class_node = 3;
getClassSchema() - Static method in class org.apache.reef.bridge.message.Acknowledgement
 
getClassSchema() - Static method in class org.apache.reef.bridge.message.BridgeInterop
 
getClassSchema() - Static method in class org.apache.reef.bridge.message.Header
 
getClassSchema() - Static method in enum org.apache.reef.bridge.message.MessageType
 
getClassSchema() - Static method in class org.apache.reef.bridge.message.Protocol
 
getClassSchema() - Static method in class org.apache.reef.bridge.message.SetupBridge
 
getClassSchema() - Static method in class org.apache.reef.bridge.message.SystemOnStart
 
getClassSchema() - Static method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
getClassSchema() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
getClassSchema() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
getClassSchema() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
getClassSchema() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
getClassSchema() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.common.AvroFailure
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
getClassSchema() - Static method in enum org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorType
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
getClassSchema() - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
getClassSchema() - Static method in class org.apache.reef.javabridge.avro.AvroFailedTask
 
getClassSchema() - Static method in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
getClassSchema() - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
getClassSchema() - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
getClassSchema() - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
getClassSchema() - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
getClassSchema() - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
getClassSchema() - Static method in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
getClassSchema() - Static method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
getClassSchema() - Static method in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
getClassSchema() - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
getClassSchema() - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
getClassSchema() - Static method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
getClassSchema() - Static method in class org.apache.reef.tang.implementation.avro.AvroNode
 
getClassSchema() - Static method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroDriverInfo
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroEvaluatorEntry
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroEvaluatorInfo
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroEvaluatorList
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroHttpRequest
 
getClassSchema() - Static method in class org.apache.reef.webserver.AvroReefServiceInfo
 
getClassSchema() - Static method in class org.apache.reef.webserver.HeaderEntry
 
getClosedContext(ActiveContext) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getClosedContextHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getClusterId() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getCodec() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getCommand() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Commands
 
getCommand() - Method in class org.apache.reef.runtime.local.process.RunnableProcess
 
getCommand() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Gets the value of the 'command' field.
getCommand() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Gets the value of the 'command' field.
getCommandLine() - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
getCommandLine() - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
 
getCommandLine() - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
getCommandLines() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Gets the value of the 'commandLines' field.
getCommandLines() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Gets the value of the 'commandLines' field.
getCommands() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
getCommunicationGroup(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.GroupCommClient
 
getCommunicationGroup(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.GroupCommClientImpl
 
getCompletedEvaluatorHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getCompletedTaskHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getCompletedTime() - Method in interface org.apache.reef.driver.restart.DriverRestartCompleted
 
getComponentName() - Method in class org.apache.reef.runtime.common.driver.idle.IdleMessage
 
getComputeContextIdPrefix() - Method in interface org.apache.reef.io.data.loading.api.DataLoadingService
 
getComputeContextIdPrefix() - Method in class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
 
getConfiguration() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getConfiguration() - Static method in class org.apache.reef.io.network.group.impl.driver.GroupCommService
 
getConfiguration(int) - Static method in class org.apache.reef.io.network.group.impl.driver.GroupCommService
 
getConfiguration() - Method in class org.apache.reef.io.TcpPortConfigurationProvider
returns a configuration for the class that implements TcpPortProvider so that class can be instantiated.
getConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string configuration = 2;
getConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
required string configuration = 2;
getConfiguration() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder
required string configuration = 2;
getConfiguration() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getConfiguration() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getConfiguration() - Method in interface org.apache.reef.tang.ConfigurationProvider
 
getConfiguration() - Method in class org.apache.reef.vortex.driver.VortexJobConf
Convert to the Tang Configuration.
getConfiguration() - Method in class org.apache.reef.wake.remote.address.HostnameBasedLocalAddressProvider
 
getConfiguration() - Method in class org.apache.reef.wake.remote.address.LoopbackLocalAddressProvider
 
getConfigurationBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string configuration = 2;
getConfigurationBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
required string configuration = 2;
getConfigurationBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder
required string configuration = 2;
getConnectionFactory(Identifier) - Method in class org.apache.reef.io.network.impl.NetworkConnectionServiceImpl
Gets a ConnectionFactory.
getConnectionFactory(Identifier) - Method in interface org.apache.reef.io.network.NetworkConnectionService
Gets an instance of ConnectionFactory which is registered by the registerConnectionFactory method.
getConnectionFactoryId() - Method in interface org.apache.reef.io.network.ConnectionFactory
 
getConnectionFactoryId() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getConstructor() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
getConstructor() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Constructor constructor = 2;
getConstructor() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Constructor constructor = 2;
getConstructorArgs() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Gets the value of the 'constructorArgs' field.
getConstructorArgs() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Gets the value of the 'constructorArgs' field.
getConstructorBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
getConstructorDef() - Method in class org.apache.reef.tang.implementation.Constructor
 
getConstructorDef(ClassNode<?>...) - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
getConstructorDef(ClassNode<?>...) - Method in interface org.apache.reef.tang.types.ClassNode
 
getConstructorDef() - Method in class org.apache.reef.wake.profiler.Vertex
 
getConstructorOrBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
getConstructorOrBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Constructor constructor = 2;
getConstructorOrBuilder() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Constructor constructor = 2;
getContainerAllocationList() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEvent
 
getContainerAllocationList() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
getContainerID() - Method in interface org.apache.reef.runtime.local.driver.Container
 
getContainerID() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
getContainerIdString() - Static method in class org.apache.reef.runtime.yarn.util.YarnUtilities
 
getContainerLaunchContext(List<String>, Map<String, LocalResource>, byte[]) - Static method in class org.apache.reef.runtime.yarn.util.YarnTypes
 
getContainerLaunchContext(List<String>, Map<String, LocalResource>, byte[], ApplicationId) - Static method in class org.apache.reef.runtime.yarn.util.YarnTypes
Gets a LaunchContext and sets the environment variable YarnUtilities.REEF_YARN_APPLICATION_ID_ENV_VAR for REEF Evaluators.
getContext(String) - Method in class org.apache.reef.runtime.common.driver.context.ContextRepresenters
Fetch the context with the given ID.
getContextConfiguration(AllocatedEvaluator) - Method in interface org.apache.reef.io.data.loading.api.DataLoadingService
 
getContextConfiguration(AllocatedEvaluator) - Method in class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
 
getContextConfiguration() - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
 
getContextConfiguration() - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
getContextConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string context_configuration = 2;
getContextConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
required string context_configuration = 2;
getContextConfiguration() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
required string context_configuration = 2;
getContextConfigurationBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string context_configuration = 2;
getContextConfigurationBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
required string context_configuration = 2;
getContextConfigurationBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
required string context_configuration = 2;
getContextControl() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
getContextControl() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .ContextControlProto context_control = 3;
getContextControl() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .ContextControlProto context_control = 3;
getContextControlBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
getContextControlOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
getContextControlOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .ContextControlProto context_control = 3;
getContextControlOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .ContextControlProto context_control = 3;
getContextId() - Method in interface org.apache.reef.driver.task.TaskMessage
 
getContextId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Gets the value of the 'contextId' field.
getContextId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Gets the value of the 'contextId' field.
getContextId() - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
getContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required string context_id = 1;
getContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
required string context_id = 1;
getContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProtoOrBuilder
required string context_id = 1;
getContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
required string context_id = 1;
getContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
required string context_id = 1;
getContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProtoOrBuilder
required string context_id = 1;
getContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string context_id = 1;
getContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
required string context_id = 1;
getContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder
required string context_id = 1;
getContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required string context_id = 2;
getContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
required string context_id = 2;
getContextId() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
required string context_id = 2;
getContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string context_id = 2;
getContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required string context_id = 2;
getContextId() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required string context_id = 2;
getContextId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
getContextId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
getContextId() - Method in class org.apache.reef.runtime.common.driver.task.TaskMessageImpl
 
getContextID() - Method in exception org.apache.reef.runtime.common.evaluator.context.ContextClientCodeException
 
getContextId() - Method in exception org.apache.reef.runtime.common.evaluator.task.TaskClientCodeException
 
getContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required string context_id = 1;
getContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
required string context_id = 1;
getContextIdBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProtoOrBuilder
required string context_id = 1;
getContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
required string context_id = 1;
getContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
required string context_id = 1;
getContextIdBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProtoOrBuilder
required string context_id = 1;
getContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string context_id = 1;
getContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
required string context_id = 1;
getContextIdBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder
required string context_id = 1;
getContextIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required string context_id = 2;
getContextIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
required string context_id = 2;
getContextIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
required string context_id = 2;
getContextIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string context_id = 2;
getContextIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required string context_id = 2;
getContextIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required string context_id = 2;
getContextMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
getContextMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .ContextMessageProto context_message = 2;
getContextMessage() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .ContextMessageProto context_message = 2;
getContextMessage(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessage(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessage(int) - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
getContextMessageBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageBuilderList() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageCount() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageCount() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageCount() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getContextMessageList() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageList() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageList() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageList() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
getContextMessageOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
getContextMessageOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .ContextMessageProto context_message = 2;
getContextMessageOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .ContextMessageProto context_message = 2;
getContextMessageOrBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageOrBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageOrBuilder(int) - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageOrBuilderList() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageOrBuilderList() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContextMessageOrBuilderList() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
getContexts() - Method in class org.apache.reef.webserver.ReefEventStateManager
get a map of contexts.
getContextState() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required .ContextStatusProto.State context_state = 1;
getContextState() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
required .ContextStatusProto.State context_state = 1;
getContextState() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
required .ContextStatusProto.State context_state = 1;
getContextState() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
getContextStatus(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatus(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
repeated .ContextStatusProto context_status = 3;
getContextStatus(int) - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
repeated .ContextStatusProto context_status = 3;
getContextStatusBuilder(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatusBuilderList() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatusCollection() - Method in class org.apache.reef.runtime.common.evaluator.context.ContextManager
 
getContextStatusCount() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatusCount() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
repeated .ContextStatusProto context_status = 3;
getContextStatusCount() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
repeated .ContextStatusProto context_status = 3;
getContextStatusList() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatusList() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
repeated .ContextStatusProto context_status = 3;
getContextStatusList() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
repeated .ContextStatusProto context_status = 3;
getContextStatusOrBuilder(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatusOrBuilder(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
repeated .ContextStatusProto context_status = 3;
getContextStatusOrBuilder(int) - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
repeated .ContextStatusProto context_status = 3;
getContextStatusOrBuilderList() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
getContextStatusOrBuilderList() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
repeated .ContextStatusProto context_status = 3;
getContextStatusOrBuilderList() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
repeated .ContextStatusProto context_status = 3;
getCores() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Gets the value of the 'cores' field.
getCores() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Gets the value of the 'cores' field.
getCount() - Method in class org.apache.reef.vortex.api.VortexAggregatePolicy
 
getCount() - Method in interface org.apache.reef.wake.metrics.Histogram
Returns the number of recorded values.
getCount() - Method in class org.apache.reef.wake.metrics.Meter
Gets the count.
getCount() - Method in class org.apache.reef.wake.metrics.UniformHistogram
Returns the number of recorded values.
getCredentials() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
getCurrent() - Method in class org.apache.reef.wake.time.runtime.LogicalTimer
Get current time in milliseconds since the beginning of the epoch (01/01/1970).
getCurrent() - Method in class org.apache.reef.wake.time.runtime.RealTimer
Get current time in milliseconds since the beginning of the epoch (01/01/1970).
getCurrent() - Method in interface org.apache.reef.wake.time.runtime.Timer
Get current time in milliseconds since the beginning of the epoch (01/01/1970).
getCurrentOffset() - Method in class org.apache.reef.io.storage.FramingOutputStream
 
getData() - Method in class org.apache.reef.common.AbstractFailure
 
getData() - Method in interface org.apache.reef.common.Failure
 
getData() - Method in interface org.apache.reef.io.network.group.api.task.NodeStruct
 
getData() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getData() - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
getData(GroupCommunicationMessage) - Static method in class org.apache.reef.io.network.group.impl.utils.Utils
 
getData() - Method in class org.apache.reef.io.network.impl.NSMessage
Gets data.
getData() - Method in interface org.apache.reef.io.network.Message
Gets data.
getData() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
required bytes data = 1;
getData() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
required bytes data = 1;
getData() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBodyOrBuilder
required bytes data = 1;
getData() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
required bytes data = 1;
getData() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
required bytes data = 1;
getData() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBufOrBuilder
required bytes data = 1;
getData() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Gets the value of the 'data' field.
getData() - Method in class org.apache.reef.io.watcher.common.AvroFailure
Gets the value of the 'data' field.
getData() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Gets the value of the 'data' field.
getData() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Gets the value of the 'data' field.
getData() - Method in class org.apache.reef.wake.remote.impl.TransportEvent
Gets the data.
getData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required bytes data = 1;
getData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
required bytes data = 1;
getData() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBufOrBuilder
required bytes data = 1;
getData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required bytes data = 2;
getData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
required bytes data = 2;
getData() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBufOrBuilder
required bytes data = 2;
getDataCodecClass() - Method in interface org.apache.reef.io.network.group.api.config.OperatorSpec
 
getDataCodecClass() - Method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec
 
getDataCodecClass() - Method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec
 
getDataCodecClass() - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec
 
getDataCodecClass() - Method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec
 
getDateTime() - Method in class org.apache.reef.bridge.message.SystemOnStart.Builder
Gets the value of the 'dateTime' field.
getDateTime() - Method in class org.apache.reef.bridge.message.SystemOnStart
Gets the value of the 'dateTime' field.
getDefaultClassHierarchy() - Method in class org.apache.reef.tang.implementation.TangImpl
 
getDefaultClassHierarchy(URL[], Class<? extends ExternalConstructor<?>>[]) - Method in class org.apache.reef.tang.implementation.TangImpl
 
getDefaultClassHierarchy() - Method in interface org.apache.reef.tang.Tang
 
getDefaultClassHierarchy(URL[], Class<? extends ExternalConstructor<?>>[]) - Method in interface org.apache.reef.tang.Tang
Get a default class hierarchy.
getDefaultImplementation() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'defaultImplementation' field.
getDefaultImplementation() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'defaultImplementation' field.
getDefaultImplementation() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
getDefaultImplementation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
optional string default_implementation = 7;
getDefaultImplementation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
optional string default_implementation = 7;
getDefaultImplementation() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
optional string default_implementation = 7;
getDefaultImplementation() - Method in interface org.apache.reef.tang.types.ClassNode
 
getDefaultImplementationBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
optional string default_implementation = 7;
getDefaultImplementationBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
optional string default_implementation = 7;
getDefaultImplementationBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
optional string default_implementation = 7;
getDefaultInstance() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
getDefaultInstance() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
getDefaultInstance() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
getDefaultInstance() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
getDefaultInstance() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
getDefaultInstance() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
getDefaultInstance() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
getDefaultInstance() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
getDefaultInstance() - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
getDefaultInstanceAsStrings() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
getDefaultInstanceAsStrings() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
getDefaultInstanceForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
getDefaultInstanceForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
getDefaultInstanceForType() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
getDefaultInstanceForType() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
getDefaultRuntimeName() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the value of the 'defaultRuntimeName' field.
getDefaultRuntimeName() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Gets the value of the 'defaultRuntimeName' field.
getDefaultRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Gets the value of the 'defaultRuntimeName' field.
getDefaultRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Gets the value of the 'defaultRuntimeName' field.
getDefaultSerializer() - Static method in class org.apache.reef.tang.Configurations
Get the default configuration serializer.
getDefinedRuntimes() - Method in class org.apache.reef.javabridge.EvaluatorRequestorBridge
 
getDelegatedPlan() - Method in class org.apache.reef.tang.implementation.Subplan
 
getDescription() - Method in class org.apache.reef.common.AbstractFailure
 
getDescription() - Method in interface org.apache.reef.common.Failure
 
getDescription() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Gets the value of the 'description' field.
getDescription() - Method in class org.apache.reef.io.watcher.common.AvroFailure
Gets the value of the 'description' field.
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
getDescriptor() - Static method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
getDescriptor() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
getDescriptor() - Static method in class org.apache.reef.proto.ClientRuntimeProtocol
 
getDescriptor() - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
getDescriptor() - Static method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
getDescriptor() - Static method in class org.apache.reef.proto.REEFProtocol
 
getDescriptor() - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
getDescriptor() - Static method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
getDescriptor() - Static method in enum org.apache.reef.proto.ReefServiceProtos.State
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
getDescriptor() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
getDescriptor() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
getDescriptor() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos
 
getDescriptor() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
getDescriptor() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
getDescriptor() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
getDescriptor() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
getDescriptor() - Static method in class org.apache.reef.wake.test.proto.TestProtos
 
getDescriptor() - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
getDescriptor() - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
getDescriptorForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
getDescriptorForType() - Method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
getDescriptorForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
getDescriptorForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
getDescriptorForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
getDescriptorForType() - Method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
getDescriptorForType() - Method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
getDescriptorForType() - Method in enum org.apache.reef.proto.ReefServiceProtos.State
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
getDescriptorForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
getDescriptorForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
getDescriptorForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
getDescriptorForType() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
getDestid() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getDestId() - Method in class org.apache.reef.io.network.impl.NSMessage
Gets a destination identifier.
getDestId() - Method in interface org.apache.reef.io.network.Message
Gets a destination identifier.
getDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string destid = 3;
getDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required string destid = 3;
getDestid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required string destid = 3;
getDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string destid = 3;
getDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
required string destid = 3;
getDestid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
required string destid = 3;
getDestidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string destid = 3;
getDestidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required string destid = 3;
getDestidBytes() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required string destid = 3;
getDestidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string destid = 3;
getDestidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
required string destid = 3;
getDestidBytes() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
required string destid = 3;
getDestination() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getDfsJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Gets the value of the 'dfsJobSubmissionFolder' field.
getDfsJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Gets the value of the 'dfsJobSubmissionFolder' field.
getDiagnostics() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEvent
 
getDiagnostics() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
getDiagnostics() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getDimensions() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getDocumentation() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'documentation' field.
getDocumentation() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'documentation' field.
getDocumentation() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
getDocumentation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string documentation = 5;
getDocumentation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string documentation = 5;
getDocumentation() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string documentation = 5;
getDocumentation() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
getDocumentationBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string documentation = 5;
getDocumentationBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string documentation = 5;
getDocumentationBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string documentation = 5;
getDoneEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
getDoneEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .DoneEvaluatorProto done_evaluator = 6;
getDoneEvaluator() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .DoneEvaluatorProto done_evaluator = 6;
getDoneEvaluatorBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
getDoneEvaluatorOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
getDoneEvaluatorOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .DoneEvaluatorProto done_evaluator = 6;
getDoneEvaluatorOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .DoneEvaluatorProto done_evaluator = 6;
getDriverClasspath() - Method in class org.apache.reef.runtime.common.files.ClasspathProvider
 
getDriverClasspathPrefix() - Method in interface org.apache.reef.runtime.common.files.RuntimeClasspathProvider
 
getDriverClasspathPrefix() - Method in class org.apache.reef.runtime.hdinsight.HDInsightClasspathProvider
 
getDriverClasspathPrefix() - Method in class org.apache.reef.runtime.local.LocalClasspathProvider
 
getDriverClasspathPrefix() - Method in class org.apache.reef.runtime.mesos.MesosClasspathProvider
 
getDriverClasspathPrefix() - Method in class org.apache.reef.runtime.yarn.YarnClasspathProvider
 
getDriverClasspathSuffix() - Method in interface org.apache.reef.runtime.common.files.RuntimeClasspathProvider
 
getDriverClasspathSuffix() - Method in class org.apache.reef.runtime.hdinsight.HDInsightClasspathProvider
 
getDriverClasspathSuffix() - Method in class org.apache.reef.runtime.local.LocalClasspathProvider
 
getDriverClasspathSuffix() - Method in class org.apache.reef.runtime.mesos.MesosClasspathProvider
 
getDriverClasspathSuffix() - Method in class org.apache.reef.runtime.yarn.YarnClasspathProvider
 
getDriverConfiguration() - Static method in class org.apache.reef.examples.hellohttp.HelloREEFHttp
 
getDriverConfiguration() - Static method in class org.apache.reef.javabridge.generic.JobClient
 
getDriverConfiguration(URI, String, String, Configuration) - Method in interface org.apache.reef.runtime.common.client.DriverConfigurationProvider
Generates driver configuration.
getDriverConfiguration(URI, String, String, Configuration) - Method in class org.apache.reef.runtime.yarn.client.YarnDriverConfigurationProviderImpl
 
getDriverConfigurationName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
The name under which the driver configuration will be stored in REEF_BASE_FOLDER/LOCAL_FOLDER.
getDriverConfigurationPath() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getDriverEndpointIdentifier() - Method in class org.apache.reef.webserver.ReefEventStateManager
get driver endpoint identifier.
getDriverHttpEndpoint() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getDriverId() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getDriverId() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getDriverLauncherExeFile() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
reef/BRIDGE_EXE_NAME.
getDriverMemory() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'driverMemory' field.
getDriverMemory() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'driverMemory' field.
getDriverMemory() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getDriverMemory() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getDriverRecoveryTimeout() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Gets the value of the 'driverRecoveryTimeout' field.
getDriverRecoveryTimeout() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Gets the value of the 'driverRecoveryTimeout' field.
getDriverRemoteIdentifier() - Method in class org.apache.reef.runtime.common.evaluator.DefaultDriverConnection
 
getDriverRemoteIdentifier() - Method in interface org.apache.reef.runtime.common.evaluator.DriverConnection
 
getDriverRestartActiveContextHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getDriverRestartCompletedHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getDriverRestartFailedEvaluatorHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getDriverRestartRunningTaskHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getDriverStderrFileName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Gets the value of the 'driverStderrFilePath' field.
getDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Gets the value of the 'driverStderrFilePath' field.
getDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'driverStderrFilePath' field.
getDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'driverStderrFilePath' field.
getDriverStdoutFileName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Gets the value of the 'driverStdoutFilePath' field.
getDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Gets the value of the 'driverStdoutFilePath' field.
getDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'driverStdoutFilePath' field.
getDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'driverStdoutFilePath' field.
getDst() - Method in class org.apache.reef.io.network.group.impl.driver.MsgKey
 
getDuration(long) - Method in class org.apache.reef.wake.time.runtime.LogicalTimer
Deprecated.
[REEF-1532] Prefer passing Time object instead of the numeric timestamp. Remove after release 0.16.
getDuration(Time) - Method in class org.apache.reef.wake.time.runtime.LogicalTimer
Get the number of milliseconds between current time as tracked by the Timer implementation and a given event.
getDuration(long) - Method in class org.apache.reef.wake.time.runtime.RealTimer
Deprecated.
[REEF-1532] Prefer passing Time object instead of the numeric timestamp. Remove after release 0.16.
getDuration(Time) - Method in class org.apache.reef.wake.time.runtime.RealTimer
Get the number of milliseconds from current system time to the given event.
getDuration(long) - Method in interface org.apache.reef.wake.time.runtime.Timer
Deprecated.
[REEF-1532] Prefer passing Time object instead of the numeric timestamp. Remove after release 0.16.
getDuration(Time) - Method in interface org.apache.reef.wake.time.runtime.Timer
Get the number of milliseconds between current time as tracked by the Timer implementation and the given event.
getElapsedTime() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getEncoding() - Method in class org.apache.reef.util.logging.DFSHandler
 
getEntry() - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
getEntryPlans() - Method in class org.apache.reef.tang.implementation.ListInjectionPlan
 
getEntryPlans() - Method in class org.apache.reef.tang.implementation.SetInjectionPlan
 
getEnvironment() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
getEps() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getError() - Method in class org.apache.reef.client.LauncherStatus
 
getError() - Method in exception org.apache.reef.exception.NonSerializableException
 
getError() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bytes error = 5;
getError() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional bytes error = 5;
getError() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional bytes error = 5;
getError() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
optional bytes error = 3;
getError() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
optional bytes error = 3;
getError() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
optional bytes error = 3;
getError() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
getError() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.EvaluatorStatusPOJO
 
getError() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEvent
 
getError() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
getErrorBytes() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getErrorManager() - Method in class org.apache.reef.util.logging.DFSHandler
 
getEta() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getEvaluatorClasspath() - Method in class org.apache.reef.runtime.common.files.ClasspathProvider
 
getEvaluatorClasspathPrefix() - Method in interface org.apache.reef.runtime.common.files.RuntimeClasspathProvider
 
getEvaluatorClasspathPrefix() - Method in class org.apache.reef.runtime.hdinsight.HDInsightClasspathProvider
 
getEvaluatorClasspathPrefix() - Method in class org.apache.reef.runtime.local.LocalClasspathProvider
 
getEvaluatorClasspathPrefix() - Method in class org.apache.reef.runtime.mesos.MesosClasspathProvider
 
getEvaluatorClasspathPrefix() - Method in class org.apache.reef.runtime.yarn.YarnClasspathProvider
 
getEvaluatorClasspathSuffix() - Method in interface org.apache.reef.runtime.common.files.RuntimeClasspathProvider
 
getEvaluatorClasspathSuffix() - Method in class org.apache.reef.runtime.hdinsight.HDInsightClasspathProvider
 
getEvaluatorClasspathSuffix() - Method in class org.apache.reef.runtime.local.LocalClasspathProvider
 
getEvaluatorClasspathSuffix() - Method in class org.apache.reef.runtime.mesos.MesosClasspathProvider
 
getEvaluatorClasspathSuffix() - Method in class org.apache.reef.runtime.yarn.YarnClasspathProvider
 
getEvaluatorConf() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceLaunchEvent
 
getEvaluatorConf() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
getEvaluatorConfigurationName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getEvaluatorConfigurationPath() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getEvaluatorControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorControl() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorControlBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorControlOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorControlOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorControlOrBuilder() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .EvaluatorControlProto evaluatorControl = 5;
getEvaluatorDescriptor() - Method in interface org.apache.reef.driver.context.ContextBase
 
getEvaluatorDescriptor() - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
 
getEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Gets the value of the 'evaluatorDescriptor' field.
getEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Gets the value of the 'evaluatorDescriptor' field.
getEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Gets the value of the 'evaluatorDescriptor' field.
getEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Gets the value of the 'evaluatorDescriptor' field.
getEvaluatorDescriptor() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getEvaluatorDescriptor() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
getEvaluatorDescriptor() - Method in class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
getEvaluatorDescriptor() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getEvaluatorDescriptor() - Method in class org.apache.reef.runtime.common.driver.context.FailedContextImpl
 
getEvaluatorDescriptor() - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
getEvaluatorDescriptor() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
 
getEvaluatorDescriptor(String) - Method in class org.apache.reef.webserver.ReefEventStateManager
getEvaluatorDescriptor.
getEvaluatorDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Gets the Builder instance for the 'evaluatorDescriptor' field and creates one if it doesn't exist yet.
getEvaluatorDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Gets the Builder instance for the 'evaluatorDescriptor' field and creates one if it doesn't exist yet.
getEvaluatorDescriptorString() - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
getEvaluatorDescriptorString() - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
Gets the serialized evaluator descriptor from the Java allocated evaluator.
getEvaluatorDescriptorString() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getEvaluatorDescriptorString() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
getEvaluatorDescriptorString(EvaluatorDescriptor) - Static method in class org.apache.reef.javabridge.Utilities
 
getEvaluatorException() - Method in interface org.apache.reef.driver.evaluator.FailedEvaluator
 
getEvaluatorException() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Gets the value of the 'evaluatorException' field.
getEvaluatorException() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Gets the value of the 'evaluatorException' field.
getEvaluatorFolderPrefix() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getEvaluatorHeartBeat() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorHeartBeat() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorHeartBeat() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorHeartBeatBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorHeartBeatOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorHeartBeatOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorHeartBeatOrBuilder() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
getEvaluatorId() - Method in interface org.apache.reef.driver.context.ContextBase
 
getEvaluatorId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Gets the value of the 'evaluatorId' field.
getEvaluatorId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Gets the value of the 'evaluatorId' field.
getEvaluatorId() - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
getEvaluatorId() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getEvaluatorId() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
getEvaluatorId() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required string evaluator_id = 1;
getEvaluatorId() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
required string evaluator_id = 1;
getEvaluatorId() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
required string evaluator_id = 1;
getEvaluatorId() - Method in class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
getEvaluatorId() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getEvaluatorId() - Method in class org.apache.reef.runtime.common.driver.context.FailedContextImpl
 
getEvaluatorId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'evaluatorId' field.
getEvaluatorId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'evaluatorId' field.
getEvaluatorIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required string evaluator_id = 1;
getEvaluatorIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
required string evaluator_id = 1;
getEvaluatorIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
required string evaluator_id = 1;
getEvaluatorLaunch() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Gets the value of the 'evaluator_launch' field.
getEvaluatorLaunch() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Gets the value of the 'evaluator_launch' field.
getEvaluatorLaunchBuilder() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Gets the Builder instance for the 'evaluator_launch' field and creates one if it doesn't exist yet.
getEvaluatorNodeDescriptor(String) - Method in class org.apache.reef.webserver.ReefEventStateManager
get Evaluator NodeDescriptor.
getEvaluatorNumber() - Method in class org.apache.reef.javabridge.EvaluatorRequestorBridge
 
getEvaluatorRelease() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Gets the value of the 'evaluator_release' field.
getEvaluatorRelease() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Gets the value of the 'evaluator_release' field.
getEvaluatorReleaseBuilder() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Gets the Builder instance for the 'evaluator_release' field and creates one if it doesn't exist yet.
getEvaluatorRequest() - Method in interface org.apache.reef.driver.FlexiblePreemptionEvent
 
getEvaluatorRequestorBridge() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getEvaluatorRestartState(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
 
getEvaluatorRestartState() - Method in class org.apache.reef.driver.restart.EvaluatorRestartInfo
 
getEvaluators() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Gets the value of the 'evaluators' field.
getEvaluators() - Method in class org.apache.reef.webserver.AvroEvaluatorList
Gets the value of the 'evaluators' field.
getEvaluators() - Method in class org.apache.reef.webserver.ReefEventStateManager
get evaluator map.
getEvaluatorsInfo() - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo.Builder
Gets the value of the 'evaluatorsInfo' field.
getEvaluatorsInfo() - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
Gets the value of the 'evaluatorsInfo' field.
getEvaluatorStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStatus() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStatusBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStatusOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStatusOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStatusOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
required .EvaluatorStatusProto evaluator_status = 2;
getEvaluatorStderrFileName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getEvaluatorStdoutFileName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getEvaluatorType() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Gets the value of the 'evaluatorType' field.
getEvaluatorType() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Gets the value of the 'evaluatorType' field.
getEvent() - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Gets the actual event.
getExamples() - Method in class org.apache.reef.examples.group.bgd.ExampleList
 
getException() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Gets the value of the 'exception' field.
getException() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Gets the value of the 'exception' field.
getException() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes exception = 4;
getException() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
optional bytes exception = 4;
getException() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
optional bytes exception = 4;
getException() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional bytes exception = 3;
getException() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
optional bytes exception = 3;
getException() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
optional bytes exception = 3;
getException() - Method in class org.apache.reef.vortex.api.AggregateResult
If an aggregation fails, VortexAggregateException will be thrown, otherwise the Exception that caused the Tasklet to fail will be thrown directly.
getException() - Method in class org.apache.reef.vortex.api.AggregateResultSynchronous
If an aggregation fails, VortexAggregateException will be thrown, otherwise the Exception that caused the Tasklet to fail will be thrown directly.
getException() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationFailureReport
 
getException() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletFailureReport
 
getException() - Method in class org.apache.reef.wake.time.runtime.event.RuntimeStop
 
getExitCode() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEvent
 
getExitCode() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
getExpectedEvaluatorIds() - Method in interface org.apache.reef.driver.restart.DriverRestarted
 
getExpectedEvaluatorIds() - Method in class org.apache.reef.driver.restart.DriverRestartedImpl
 
getExpectedEvaluatorIds() - Method in class org.apache.reef.javabridge.DriverRestartedBridge
 
getFailedContext(ContextStatusPOJO) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getFailedContextForEvaluatorFailure() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getFailedContextHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getFailedContextList() - Method in interface org.apache.reef.driver.evaluator.FailedEvaluator
 
getFailedContextList() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Gets the value of the 'failedContextList' field.
getFailedContextList() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Gets the value of the 'failedContextList' field.
getFailedContexts() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getFailedContextsForEvaluatorFailure() - Method in class org.apache.reef.runtime.common.driver.context.ContextRepresenters
Create the failed contexts for a FailedEvaluator event.
getFailedEvaluatorHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getFailedTask() - Method in interface org.apache.reef.driver.evaluator.FailedEvaluator
 
getFailedTask() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Gets the value of the 'failedTask' field.
getFailedTask() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Gets the value of the 'failedTask' field.
getFailedTask() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getFailedTaskBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Gets the Builder instance for the 'failedTask' field and creates one if it doesn't exist yet.
getFailedTaskHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getFailedTaskSerializedAvro() - Method in class org.apache.reef.javabridge.FailedTaskBridge
 
getFailure() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Gets the value of the 'failure' field.
getFailure() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Gets the value of the 'failure' field.
getFailure() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Gets the value of the 'failure' field.
getFailure() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Gets the value of the 'failure' field.
getFailureBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Gets the Builder instance for the 'failure' field and creates one if it doesn't exist yet.
getFailureBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Gets the Builder instance for the 'failure' field and creates one if it doesn't exist yet.
getFeatureLength() - Method in class org.apache.reef.examples.group.bgd.data.SparseExample
 
getFileSet() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceLaunchEvent
 
getFileSet() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
getFileSystemUrl() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Gets the value of the 'fileSystemUrl' field.
getFileSystemUrl() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Gets the value of the 'fileSystemUrl' field.
getFilter() - Method in class org.apache.reef.util.logging.DFSHandler
 
getFilteredLinesFromFile(String, String, String, String) - Static method in class org.apache.reef.util.logging.LogParser
Get lines from a given file with a specified filter, trim the line by removing strings before removeBeforeToken and after removeAfterToken.
getFilteredLinesFromFile(String, String) - Static method in class org.apache.reef.util.logging.LogParser
get lines from given file with specified filter.
getFinalStatus() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getFinishedTime() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getFirst() - Method in class org.apache.reef.io.network.util.Pair
 
getFirst() - Method in class org.apache.reef.wake.impl.MergingEventHandler.Pair
 
getFolder() - Method in interface org.apache.reef.runtime.local.driver.Container
 
getFolder() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
getFormattedDeadlockInfo(String, String, String) - Static method in class org.apache.reef.util.ThreadLogger
Produces a String representation of threads that are deadlocked, including lock information.
getFormattedDeadlockInfo(String) - Static method in class org.apache.reef.util.ThreadLogger
Same as getFormattedDeadlockInfo(prefix, "\n\t", "\n\t\t").
getFormattedThreadList(String, String, String) - Static method in class org.apache.reef.util.ThreadLogger
Produces a String representation of the currently running threads.
getFormattedThreadList(String) - Static method in class org.apache.reef.util.ThreadLogger
Same as getFormattedThreadList(prefix, "\n\t", "\n\t\t").
getFormatter() - Method in class org.apache.reef.util.logging.DFSHandler
 
getFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Gets the value of the 'fullArgClassName' field.
getFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Gets the value of the 'fullArgClassName' field.
getFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'fullArgClassName' field.
getFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'fullArgClassName' field.
getFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required string full_arg_class_name = 1;
getFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
required string full_arg_class_name = 1;
getFullArgClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
required string full_arg_class_name = 1;
getFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string full_arg_class_name = 2;
getFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required string full_arg_class_name = 2;
getFullArgClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required string full_arg_class_name = 2;
getFullArgClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required string full_arg_class_name = 1;
getFullArgClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
required string full_arg_class_name = 1;
getFullArgClassNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
required string full_arg_class_name = 1;
getFullArgClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string full_arg_class_name = 2;
getFullArgClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required string full_arg_class_name = 2;
getFullArgClassNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required string full_arg_class_name = 2;
getFullArgName() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
getFullArgName() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
getFullClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Gets the value of the 'fullClassName' field.
getFullClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Gets the value of the 'fullClassName' field.
getFullClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
required string full_class_name = 1;
getFullClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
required string full_class_name = 1;
getFullClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
required string full_class_name = 1;
getFullClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
required string full_class_name = 1;
getFullClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
required string full_class_name = 1;
getFullClassNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
required string full_class_name = 1;
getFullName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the value of the 'fullName' field.
getFullName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Gets the value of the 'fullName' field.
getFullName() - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
getFullName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string full_name = 2;
getFullName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
required string full_name = 2;
getFullName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
required string full_name = 2;
getFullName() - Method in interface org.apache.reef.tang.types.Node
 
getFullName(Type) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Return the full name of the raw type of the provided Type.
getFullName(Field) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Return the full name of the provided field.
getFullNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string full_name = 2;
getFullNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
required string full_name = 2;
getFullNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
required string full_name = 2;
getFunction() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
 
getFunction() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletExecutionRequest
Get function of the tasklet.
getGatherReceiver(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
Return the gather receiver configured on this communication group.
getGatherReceiver(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getGatherSender(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
Return the gather sender configured on this communication group.
getGatherSender(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getGCM(Message<GroupCommunicationMessage>) - Static method in class org.apache.reef.io.network.group.impl.utils.Utils
Extract a group communication message object from a message.
getGet() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Gets the value of the 'get' field.
getGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Gets the value of the 'get' field.
getGlobalFileSet() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getGlobalFileSet() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getGlobalFolder() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getGlobalFolderName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getGlobalFolderPath() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getGraphvizString(Configuration, boolean, boolean) - Static method in class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
Produce a Graphviz DOT string for a given TANG configuration.
getGraphvizString(InjectionPlan<?>, boolean) - Static method in class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
Produce a Graphviz DOT string for a given TANG injection plan.
getGridSize() - Method in class org.apache.reef.examples.group.bgd.utils.StepSizes
 
getGroupCommFailedEvaluatorStage() - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommServiceDriver
Not user facing but used the Group Communication Service class.
getGroupCommFailedEvaluatorStage() - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
getGroupCommFailedTaskStage() - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommServiceDriver
Not user facing but used the Group Communication Service class.
getGroupCommFailedTaskStage() - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
getGroupCommRunningTaskStage() - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommServiceDriver
Not user facing but used the Group Communication Service class.
getGroupCommRunningTaskStage() - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
getGroupName() - Method in class org.apache.reef.io.network.group.api.operators.AbstractGroupCommOperator
 
getGroupName() - Method in interface org.apache.reef.io.network.group.api.operators.GroupCommOperator
 
getGroupName() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getGroupname() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
getGroupName() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getGroupname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string groupname = 4;
getGroupname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional string groupname = 4;
getGroupname() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional string groupname = 4;
getGroupnameBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string groupname = 4;
getGroupnameBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional string groupname = 4;
getGroupnameBytes() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional string groupname = 4;
getHandler(String, Class<? extends T>) - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
getHandler(String, Class<? extends T>) - Method in class org.apache.reef.runtime.mesos.util.MesosRemoteManager
 
getHandler(RemoteIdentifier, Class<? extends T>) - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
Returns a proxy event handler for a remote identifier and a message type.
getHandler() - Method in class org.apache.reef.wake.remote.impl.RemoteSenderStage
Returns a new remote sender event handler.
getHandler(RemoteIdentifier, Class<? extends T>) - Method in interface org.apache.reef.wake.remote.RemoteManager
Returns an event handler that can be used to send messages of type T to the given destination.
getHeader() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Gets the value of the 'header' field.
getHeader() - Method in class org.apache.reef.webserver.AvroHttpRequest
Gets the value of the 'header' field.
getHeaderEntryList() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get http header as a list of HeaderEntry.
getHeaders() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get request headers.
getHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Gets the value of the 'host' field.
getHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Gets the value of the 'host' field.
getHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Gets the value of the 'host' field.
getHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Gets the value of the 'host' field.
getHostName() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEvent
 
getHostName() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl
 
getHTTPConfiguration() - Static method in class org.apache.reef.examples.hellohttp.HelloREEFHttp
 
getHTTPConfiguration() - Static method in class org.apache.reef.javabridge.generic.JobClient
 
getHttpMethod() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Gets the value of the 'httpMethod' field.
getHttpMethod() - Method in class org.apache.reef.webserver.AvroHttpRequest
Gets the value of the 'httpMethod' field.
getHttpServerEventHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getHttpServerPortNumber() - Method in class org.apache.reef.bridge.message.SetupBridge.Builder
Gets the value of the 'httpServerPortNumber' field.
getHttpServerPortNumber() - Method in class org.apache.reef.bridge.message.SetupBridge
Gets the value of the 'httpServerPortNumber' field.
getId() - Method in interface org.apache.reef.client.CompletedJob
 
getId() - Method in class org.apache.reef.client.JobMessage
Get the Identifier of the sending Job.
getId() - Method in interface org.apache.reef.client.RunningJob
 
getId() - Method in interface org.apache.reef.client.SubmittedJob
 
getId() - Method in class org.apache.reef.common.AbstractFailure
 
getId() - Method in interface org.apache.reef.driver.context.ContextBase
 
getId() - Method in interface org.apache.reef.driver.context.ContextMessage
 
getId() - Method in interface org.apache.reef.driver.task.CompletedTask
 
getId() - Method in interface org.apache.reef.driver.task.TaskMessage
 
getId() - Method in interface org.apache.reef.evaluator.context.events.ContextStart
 
getId() - Method in interface org.apache.reef.evaluator.context.events.ContextStop
 
getId() - Method in exception org.apache.reef.exception.EvaluatorException
Access the affected Evaluator.
getId() - Method in interface org.apache.reef.io.naming.Identifiable
Returns an identifier of this object.
getId() - Method in interface org.apache.reef.io.network.group.api.task.NodeStruct
 
getId() - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
getId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.PartitionSpec
 
getId() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.common.AvroFailure
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
getId() - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
 
getId() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getId() - Method in class org.apache.reef.javabridge.CompletedEvaluatorBridge
 
getId() - Method in class org.apache.reef.javabridge.ContextMessageBridge
 
getId() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
getId() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getId() - Method in class org.apache.reef.javabridge.RunningTaskBridge
 
getId() - Method in class org.apache.reef.javabridge.SuspendedTaskBridge
 
getId() - Method in class org.apache.reef.javabridge.TaskMessageBridge
 
getId() - Method in class org.apache.reef.runtime.common.client.RunningJobImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.catalog.NodeDescriptorImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.context.ContextMessageImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getId() - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
 
getId() - Method in class org.apache.reef.runtime.common.driver.task.CompletedTaskImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.task.SuspendedTaskImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.task.TaskMessageImpl
 
getId() - Method in class org.apache.reef.runtime.common.driver.task.TaskRepresenter
 
getId() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
 
getId() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getId() - Method in class org.apache.reef.runtime.local.process.RunnableProcess
 
getId() - Method in interface org.apache.reef.task.events.TaskStart
 
getId() - Method in interface org.apache.reef.task.events.TaskStop
 
getId() - Method in interface org.apache.reef.wake.Identifiable
Returns an identifier of this object.
getId() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Gets the value of the 'id' field.
getId() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
Gets the value of the 'id' field.
getIdentifier() - Method in class org.apache.reef.bridge.message.Header.Builder
Gets the value of the 'identifier' field.
getIdentifier() - Method in class org.apache.reef.bridge.message.Header
Gets the value of the 'identifier' field.
getIdentifier() - Method in interface org.apache.reef.io.naming.NameAssignment
Returns an identifier of this object.
getIdentifier() - Method in class org.apache.reef.io.network.naming.NameAssignmentTuple
Gets an identifier.
getIdentifier() - Method in class org.apache.reef.io.network.naming.serialization.NamingUnregisterRequest
Gets an identifier.
getIdentifier() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Gets the value of the 'identifier' field.
getIdentifier() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Gets the value of the 'identifier' field.
getIdentifier() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
required string identifier = 1;
getIdentifier() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
required string identifier = 1;
getIdentifier() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
required string identifier = 1;
getIdentifier() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required string identifier = 2;
getIdentifier() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
required string identifier = 2;
getIdentifier() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
required string identifier = 2;
getIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required string identifier = 1;
getIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
required string identifier = 1;
getIdentifier() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
required string identifier = 1;
getIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional string identifier = 5;
getIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
optional string identifier = 5;
getIdentifier() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
optional string identifier = 5;
getIdentifier() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getIdentifier() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getIdentifier() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceLaunchEvent
 
getIdentifier() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
getIdentifier() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceReleaseEvent
 
getIdentifier() - Method in class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl
 
getIdentifier() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEvent
 
getIdentifier() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl
 
getIdentifier() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceEvent
 
getIdentifier() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
getIdentifier() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEvent
 
getIdentifier() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
getIdentifier(Configuration) - Static method in exception org.apache.reef.runtime.common.evaluator.context.ContextClientCodeException
Extracts a context id from the given configuration.
getIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Gets the value of the 'identifier' field.
getIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Gets the value of the 'identifier' field.
getIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease.Builder
Gets the value of the 'identifier' field.
getIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Gets the value of the 'identifier' field.
getIdentifier() - Method in interface org.apache.reef.wake.remote.RemoteMessage
Returns a remote identifier of the sender.
getIdentifierBytes() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
required string identifier = 1;
getIdentifierBytes() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
required string identifier = 1;
getIdentifierBytes() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
required string identifier = 1;
getIdentifierBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required string identifier = 2;
getIdentifierBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
required string identifier = 2;
getIdentifierBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
required string identifier = 2;
getIdentifierBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required string identifier = 1;
getIdentifierBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
required string identifier = 1;
getIdentifierBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
required string identifier = 1;
getIdentifierBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional string identifier = 5;
getIdentifierBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
optional string identifier = 5;
getIdentifierBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
optional string identifier = 5;
getIdentifierFactory() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getIdentifiers() - Method in class org.apache.reef.io.network.naming.serialization.NamingLookupRequest
Gets identifiers.
getIdleStatus() - Method in class org.apache.reef.driver.restart.DriverRestartManager
getIdleStatus() - Method in class org.apache.reef.runtime.common.driver.idle.ClockIdlenessSource
 
getIdleStatus() - Method in interface org.apache.reef.runtime.common.driver.idle.DriverIdlenessSource
 
getIdleStatus() - Method in class org.apache.reef.runtime.common.driver.idle.EventHandlerIdlenessSource
 
getIdleStatus() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceManagerStatus
Driver is idle if, regardless of status, it has no evaluators allocated and no pending container requests.
getIds() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest.Builder
Gets the value of the 'ids' field.
getIds() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Gets the value of the 'ids' field.
getImplFullNames() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'implFullNames' field.
getImplFullNames() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'implFullNames' field.
getImplFullNames(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
getImplFullNames(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated string impl_full_names = 6;
getImplFullNames(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated string impl_full_names = 6;
getImplFullNamesBytes(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
getImplFullNamesBytes(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated string impl_full_names = 6;
getImplFullNamesBytes(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated string impl_full_names = 6;
getImplFullNamesCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
getImplFullNamesCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated string impl_full_names = 6;
getImplFullNamesCount() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated string impl_full_names = 6;
getImplFullNamesList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
getImplFullNamesList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated string impl_full_names = 6;
getImplFullNamesList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated string impl_full_names = 6;
getIndex() - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
getInetSocketAddress() - Method in interface org.apache.reef.driver.catalog.NodeDescriptor
Access the inet address of the Evaluator.
getInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Gets the value of the 'inetSocketAddress' field.
getInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Gets the value of the 'inetSocketAddress' field.
getInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Gets the value of the 'inetSocketAddress' field.
getInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Gets the value of the 'inetSocketAddress' field.
getInetSocketAddress() - Method in class org.apache.reef.runtime.common.driver.catalog.NodeDescriptorImpl
 
getInitialCount() - Method in class org.apache.reef.io.network.group.impl.utils.CountingSemaphore
 
getInjectableConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'injectableConstructors' field.
getInjectableConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'injectableConstructors' field.
getInjectableConstructors() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
getInjectableConstructors(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructors(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructors(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructors() - Method in interface org.apache.reef.tang.types.ClassNode
 
getInjectableConstructorsBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsCount() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsOrBuilder(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef InjectableConstructors = 4;
getInjectableConstructorsOrBuilderList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef InjectableConstructors = 4;
getInjectionPlan(Node) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
Return an injection plan for the given class / parameter name.
getInjectionPlan(String) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getInjectionPlan(Class<T>) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getInjectionPlan(String) - Method in interface org.apache.reef.tang.Injector
 
getInjectionPlan(Class<T>) - Method in interface org.apache.reef.tang.Injector
 
getInMeter() - Method in class org.apache.reef.wake.AbstractEStage
Gets the input meter of this stage.
getInMeter() - Method in class org.apache.reef.wake.rx.AbstractRxStage
Gets the input meter of this stage.
getInput() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregateExecutionRequest
 
getInput() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletExecutionRequest
Get input of the tasklet.
getInputs() - Method in exception org.apache.reef.vortex.api.VortexAggregateException
 
getInputSplit(NodeDescriptor, String) - Method in interface org.apache.reef.io.data.loading.api.EvaluatorToPartitionStrategy
Returns an input split for the given evaluator.
getInputSplit(NodeDescriptor, String) - Method in class org.apache.reef.io.data.loading.impl.AbstractEvaluatorToPartitionStrategy
Get an input split to be assigned to this evaluator.
getInputStream() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Gets the value of the 'inputStream' field.
getInputStream() - Method in class org.apache.reef.webserver.AvroHttpRequest
Gets the value of the 'inputStream' field.
getInputStream() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get input Stream.
getInstance(Class<U>) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getInstance(String) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getInstance() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
getInstance(Class<U>) - Method in interface org.apache.reef.tang.Injector
Gets an instance of iface, or the implementation that has been bound to it.
getInstance(String) - Method in interface org.apache.reef.tang.Injector
Gets an instance of iface, or the implementation that has been bound to it.
getInstance() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
getInstance() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Instance instance = 3;
getInstance() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Instance instance = 3;
getInstance(String) - Method in interface org.apache.reef.wake.remote.RemoteManagerFactory
 
getInstance(String, Codec<T>, EventHandler<Throwable>) - Method in interface org.apache.reef.wake.remote.RemoteManagerFactory
 
getInstance(String, int, Codec<T>, EventHandler<Throwable>) - Method in interface org.apache.reef.wake.remote.RemoteManagerFactory
 
getInstance(String, String, int, Codec<T>, EventHandler<Throwable>, boolean, int, int) - Method in interface org.apache.reef.wake.remote.RemoteManagerFactory
The old constructor of DefaultRemoteManagerImplementation.
getInstance(String, String, int, Codec<T>, EventHandler<Throwable>, boolean, int, int, LocalAddressProvider, TcpPortProvider) - Method in interface org.apache.reef.wake.remote.RemoteManagerFactory
The all-out constructor of DefaultRemoteManagerImplementation.
getInstanceAsString() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
getInstanceBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
getInstanceDefault() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'instanceDefault' field.
getInstanceDefault() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'instanceDefault' field.
getInstanceDefault(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
getInstanceDefault(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
repeated string instance_default = 7;
getInstanceDefault(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
repeated string instance_default = 7;
getInstanceDefaultBytes(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
getInstanceDefaultBytes(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
repeated string instance_default = 7;
getInstanceDefaultBytes(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
repeated string instance_default = 7;
getInstanceDefaultCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
getInstanceDefaultCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
repeated string instance_default = 7;
getInstanceDefaultCount() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
repeated string instance_default = 7;
getInstanceDefaultList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
getInstanceDefaultList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
repeated string instance_default = 7;
getInstanceDefaultList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
repeated string instance_default = 7;
getInstanceOrBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
getInstanceOrBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Instance instance = 3;
getInstanceOrBuilder() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Instance instance = 3;
getInterfaceTarget(Class<?>, Type) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
This method takes a class called clazz that *directly* implements a generic interface or generic class, iface.
getInternetAddress() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'internetAddress' field.
getInternetAddress() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'internetAddress' field.
getIsExternalConstructor() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'isExternalConstructor' field.
getIsExternalConstructor() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'isExternalConstructor' field.
getIsExternalConstructor() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_external_constructor = 2;
getIsExternalConstructor() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
required bool is_external_constructor = 2;
getIsExternalConstructor() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
required bool is_external_constructor = 2;
getIsInjectionCandidate() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'isInjectionCandidate' field.
getIsInjectionCandidate() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'isInjectionCandidate' field.
getIsInjectionCandidate() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_injection_candidate = 1;
getIsInjectionCandidate() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
required bool is_injection_candidate = 1;
getIsInjectionCandidate() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
required bool is_injection_candidate = 1;
getIsInjectionFuture() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Gets the value of the 'isInjectionFuture' field.
getIsInjectionFuture() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Gets the value of the 'isInjectionFuture' field.
getIsInjectionFuture() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required bool is_injection_future = 3;
getIsInjectionFuture() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
required bool is_injection_future = 3;
getIsInjectionFuture() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
required bool is_injection_future = 3;
getIsList() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'isList' field.
getIsList() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'isList' field.
getIsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_list = 4;
getIsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required bool is_list = 4;
getIsList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required bool is_list = 4;
getIsOptionSet() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Gets the value of the 'isOptionSet' field.
getIsOptionSet() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Gets the value of the 'isOptionSet' field.
getIsSet() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'isSet' field.
getIsSet() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'isSet' field.
getIsSet() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_set = 3;
getIsSet() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required bool is_set = 3;
getIsSet() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required bool is_set = 3;
getIsUnit() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'isUnit' field.
getIsUnit() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'isUnit' field.
getIsUnit() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_unit = 3;
getIsUnit() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
required bool is_unit = 3;
getIsUnit() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
required bool is_unit = 3;
getIters() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getJarFileSuffix() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getJobControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
getJobControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .JobControlProto jobControl = 2;
getJobControl() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .JobControlProto jobControl = 2;
getJobControlBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
getJobControlOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
getJobControlOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .JobControlProto jobControl = 2;
getJobControlOrBuilder() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .JobControlProto jobControl = 2;
getJobFolderPrefix() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
The prefix used whenever REEF is asked to create a job folder, on (H)DFS or locally.
getJobId() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Gets the value of the 'jobId' field.
getJobId() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Gets the value of the 'jobId' field.
getJobIdentifier() - Static method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Get the id of current job/application.
getJobStatus() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
getJobStatus() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .JobStatusProto jobStatus = 4;
getJobStatus() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .JobStatusProto jobStatus = 4;
getJobStatusBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
getJobStatusOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
getJobStatusOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .JobStatusProto jobStatus = 4;
getJobStatusOrBuilder() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .JobStatusProto jobStatus = 4;
getJobSubmissionDirectoryPath(String) - Method in interface org.apache.reef.runtime.yarn.driver.JobSubmissionDirectoryProvider
Returns path to job submission directory.
getJobSubmissionDirectoryPath(String) - Method in class org.apache.reef.runtime.yarn.driver.JobSubmissionDirectoryProviderImpl
 
getJobSubmissionDirectoryPrefix() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Gets the value of the 'jobSubmissionDirectoryPrefix' field.
getJobSubmissionDirectoryPrefix() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Gets the value of the 'jobSubmissionDirectoryPrefix' field.
getJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Gets the value of the 'jobSubmissionFolder' field.
getJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Gets the value of the 'jobSubmissionFolder' field.
getKey() - Method in class org.apache.reef.io.Tuple
 
getKey() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResourcesEntry
 
getKey() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
getKey() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Gets the value of the 'key' field.
getKey() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Gets the value of the 'key' field.
getKey() - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
getKey() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Gets the value of the 'key' field.
getKey() - Method in class org.apache.reef.webserver.HeaderEntry
Gets the value of the 'key' field.
getKillEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
getKillEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .KillEvaluatorProto kill_evaluator = 4;
getKillEvaluator() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .KillEvaluatorProto kill_evaluator = 4;
getKillEvaluatorBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
getKillEvaluatorOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
getKillEvaluatorOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .KillEvaluatorProto kill_evaluator = 4;
getKillEvaluatorOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .KillEvaluatorProto kill_evaluator = 4;
getKnownImplementations() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
getKnownImplementations() - Method in interface org.apache.reef.tang.types.ClassNode
 
getLabel() - Method in interface org.apache.reef.examples.group.bgd.data.Example
Access to the label.
getLabel() - Method in class org.apache.reef.examples.group.bgd.data.SparseExample
 
getLambda() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getLanguage() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Gets the value of the 'language' field.
getLanguage() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Gets the value of the 'language' field.
getLastStatus() - Method in interface org.apache.reef.runtime.common.driver.client.JobStatusHandler
Return the last known status of the REEF job.
getLastStatus() - Method in class org.apache.reef.runtime.common.driver.client.LoggingJobStatusHandler
Return the last known status of the REEF job.
getLastStatus() - Method in class org.apache.reef.runtime.common.REEFEnvironment
Get the last known status of REEF job.
getLauncher(Configuration) - Static method in class org.apache.reef.client.DriverLauncher
Instantiate a launcher for the given Configuration.
getLauncher(Configuration) - Static method in class org.apache.reef.tests.TestDriverLauncher
Instantiate a launcher for the given Configuration.
getLeft() - Method in class org.apache.reef.wake.impl.MergingEventHandler
 
getLegacyConstructor(ClassNode<T>) - Method in interface org.apache.reef.tang.Configuration
Return the LegacyConstructor that has been bound to this Class.
getLegacyConstructor(ClassNode<T>) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getLegacyConstructors() - Method in interface org.apache.reef.tang.Configuration
 
getLegacyConstructors() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getLevel() - Method in class org.apache.reef.util.logging.DFSHandler
 
getLink() - Method in class org.apache.reef.io.network.naming.serialization.NamingMessage
Gets a link.
getLink() - Method in class org.apache.reef.wake.remote.impl.TransportEvent
Returns the link associated with the event.
getList() - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
Get the list of tasks in the scheduler.
getListeningPort() - Method in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Gets a server listening port of this transport.
getListeningPort() - Method in interface org.apache.reef.wake.remote.transport.Transport
Gets a server listening port of this transport.
getLoad() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required double load = 2;
getLoad() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
required double load = 2;
getLoad() - Method in interface org.apache.reef.wake.test.proto.TestProtos.TestEventPBufOrBuilder
required double load = 2;
getLocalAddress() - Method in class org.apache.reef.wake.remote.address.HostnameBasedLocalAddressProvider
 
getLocalAddress() - Method in interface org.apache.reef.wake.remote.address.LocalAddressProvider
 
getLocalAddress() - Method in class org.apache.reef.wake.remote.address.LoopbackLocalAddressProvider
 
getLocalAddress() - Method in class org.apache.reef.wake.remote.impl.TransportEvent
Gets the local socket address.
getLocalAddress() - Method in interface org.apache.reef.wake.remote.transport.Link
Gets its local address.
getLocalAddress() - Method in class org.apache.reef.wake.remote.transport.netty.NettyLink
Gets a local address of the link.
getLocalAddress() - Method in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Gets a server local socket address of this transport.
getLocalAddress() - Method in interface org.apache.reef.wake.remote.transport.Transport
Gets a server local socket address of this transport.
getLocalEndPointId() - Method in interface org.apache.reef.io.network.ConnectionFactory
Each connection factory has own local end point id.
getLocalEndPointId() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getLocalFileSet() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getLocalFileSet() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getLocalFolder() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getLocalFolderName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getLocalFolderPath() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getLocalResourceForPath(Path, LocalResourceType) - Method in class org.apache.reef.runtime.yarn.client.uploader.JobFolder
Creates a LocalResource instance for the JAR file referenced by the given Path.
getLocalResources() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
getLocalRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the value of the 'localRuntimeAppParameters' field.
getLocalRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Gets the value of the 'localRuntimeAppParameters' field.
getLocalRuntimeAppParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the Builder instance for the 'localRuntimeAppParameters' field and creates one if it doesn't exist yet.
getLocation() - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
getLossFunction() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getLossFunction() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDLossType
 
getMasterTaskConfiguration() - Method in class org.apache.reef.examples.group.bgd.BGDDriver
 
getMaxAppAttempts() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getMaxApplicationSubmissions() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'maxApplicationSubmissions' field.
getMaxApplicationSubmissions() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'maxApplicationSubmissions' field.
getMaxApplicationSubmissions() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
Returns the number of time that the driver should be started by the resource manager if it fails unexpectedly.
getMaxApplicationSubmissions() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getMaxNumberOfConcurrentEvaluators() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Gets the value of the 'maxNumberOfConcurrentEvaluators' field.
getMaxNumberOfConcurrentEvaluators() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Gets the value of the 'maxNumberOfConcurrentEvaluators' field.
getMeanThp() - Method in class org.apache.reef.wake.metrics.Meter
Gets the mean throughput.
getMegaBytes() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Access the number of memory requested.
getMegaBytes() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Gets the value of the 'megaBytes' field.
getMegaBytes() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Gets the value of the 'megaBytes' field.
getMemory() - Method in interface org.apache.reef.driver.evaluator.EvaluatorDescriptor
 
getMemory() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Gets the value of the 'memory' field.
getMemory() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Gets the value of the 'memory' field.
getMemory() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Resource
 
getMemory() - Method in interface org.apache.reef.runtime.local.driver.Container
 
getMemory() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
getMemory() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'memory' field.
getMemory() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'memory' field.
getMemorySeconds() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getMemorySize() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getMemorySize() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getMemorySize() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEvent
 
getMemorySize() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl
 
getMessage() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Gets the value of the 'message' field.
getMessage() - Method in class org.apache.reef.bridge.message.BridgeInterop
Gets the value of the 'message' field.
getMessage() - Method in class org.apache.reef.common.AbstractFailure
 
getMessage() - Method in interface org.apache.reef.common.Failure
 
getMessage() - Method in interface org.apache.reef.evaluator.context.ContextMessageSource
 
getMessage() - Method in class org.apache.reef.examples.suspend.SuspendTestTask
Update driver on current state of the task.
getMessage() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Gets the value of the 'message' field.
getMessage() - Method in class org.apache.reef.io.watcher.common.AvroFailure
Gets the value of the 'message' field.
getMessage() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Gets the value of the 'message' field.
getMessage() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Gets the value of the 'message' field.
getMessage() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional bytes message = 3;
getMessage() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
optional bytes message = 3;
getMessage() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
optional bytes message = 3;
getMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required bytes message = 2;
getMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
required bytes message = 2;
getMessage() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProtoOrBuilder
required bytes message = 2;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required bytes message = 2;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
required bytes message = 2;
getMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProtoOrBuilder
required bytes message = 2;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes message = 3;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
optional bytes message = 3;
getMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
optional bytes message = 3;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string message = 2;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
required string message = 2;
getMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
required string message = 2;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required bytes message = 2;
getMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
required bytes message = 2;
getMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProtoOrBuilder
required bytes message = 2;
getMessage() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextMessagePOJO
 
getMessage() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskMessagePOJO
 
getMessage() - Method in class org.apache.reef.runtime.common.evaluator.context.defaults.DefaultContextMessageSource
 
getMessage() - Method in interface org.apache.reef.task.TaskMessageSource
 
getMessage() - Method in class org.apache.reef.tests.fail.driver.NoopTask
 
getMessage() - Method in class org.apache.reef.tests.messaging.task.TaskMessagingTask
 
getMessage() - Method in class org.apache.reef.tests.watcher.WatcherTestTask
 
getMessage() - Method in class org.apache.reef.vortex.evaluator.VortexWorker
 
getMessage() - Method in interface org.apache.reef.wake.remote.RemoteMessage
Returns an actual message.
getMessage() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required string message = 1;
getMessage() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
required string message = 1;
getMessage() - Method in interface org.apache.reef.wake.test.proto.TestProtos.TestEventPBufOrBuilder
required string message = 1;
getMessageBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string message = 2;
getMessageBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
required string message = 2;
getMessageBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
required string message = 2;
getMessageBytes() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required string message = 1;
getMessageBytes() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
required string message = 1;
getMessageBytes() - Method in interface org.apache.reef.wake.test.proto.TestProtos.TestEventPBufOrBuilder
required string message = 1;
getMessageIdentifier() - Method in class org.apache.reef.bridge.message.Acknowledgement.Builder
Gets the value of the 'messageIdentifier' field.
getMessageIdentifier() - Method in class org.apache.reef.bridge.message.Acknowledgement
Gets the value of the 'messageIdentifier' field.
getMessageSourceID() - Method in interface org.apache.reef.driver.context.ContextMessage
 
getMessageSourceID() - Method in interface org.apache.reef.driver.task.TaskMessage
 
getMessageSourceID() - Method in class org.apache.reef.evaluator.context.ContextMessage
 
getMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Gets the value of the 'messageSourceId' field.
getMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Gets the value of the 'messageSourceId' field.
getMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Gets the value of the 'messageSourceId' field.
getMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Gets the value of the 'messageSourceId' field.
getMessageSourceID() - Method in class org.apache.reef.javabridge.ContextMessageBridge
 
getMessageSourceId() - Method in class org.apache.reef.javabridge.TaskMessageBridge
 
getMessageSourceID() - Method in class org.apache.reef.runtime.common.driver.context.ContextMessageImpl
 
getMessageSourceID() - Method in class org.apache.reef.runtime.common.driver.task.TaskMessageImpl
 
getMessageSourceID() - Method in class org.apache.reef.task.TaskMessage
 
getMessageType() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Gets the value of the 'messageType' field.
getMessageType() - Method in class org.apache.reef.bridge.message.BridgeInterop
Gets the value of the 'messageType' field.
getMethod() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get http request method like "Get".
getMinParts() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getMsg() - Method in class org.apache.reef.io.network.group.impl.driver.IndexedMsg
 
getMsgs(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgs(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
repeated .GroupMessageBody msgs = 8;
getMsgs(int) - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
repeated .GroupMessageBody msgs = 8;
getMsgs(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgs(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
repeated .NSRecordPBuf msgs = 4;
getMsgs(int) - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
repeated .NSRecordPBuf msgs = 4;
getMsgsBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgsBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgsBuilderList() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgsBuilderList() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgsCount() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getMsgsCount() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgsCount() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
repeated .GroupMessageBody msgs = 8;
getMsgsCount() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
repeated .GroupMessageBody msgs = 8;
getMsgsCount() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgsCount() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
repeated .NSRecordPBuf msgs = 4;
getMsgsCount() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
repeated .NSRecordPBuf msgs = 4;
getMsgsList() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgsList() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
repeated .GroupMessageBody msgs = 8;
getMsgsList() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
repeated .GroupMessageBody msgs = 8;
getMsgsList() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgsList() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
repeated .NSRecordPBuf msgs = 4;
getMsgsList() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
repeated .NSRecordPBuf msgs = 4;
getMsgsOrBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgsOrBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
repeated .GroupMessageBody msgs = 8;
getMsgsOrBuilder(int) - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
repeated .GroupMessageBody msgs = 8;
getMsgsOrBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgsOrBuilder(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
repeated .NSRecordPBuf msgs = 4;
getMsgsOrBuilder(int) - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
repeated .NSRecordPBuf msgs = 4;
getMsgsOrBuilderList() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
getMsgsOrBuilderList() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
repeated .GroupMessageBody msgs = 8;
getMsgsOrBuilderList() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
repeated .GroupMessageBody msgs = 8;
getMsgsOrBuilderList() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
getMsgsOrBuilderList() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
repeated .NSRecordPBuf msgs = 4;
getMsgsOrBuilderList() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
repeated .NSRecordPBuf msgs = 4;
getMsgType() - Method in class org.apache.reef.io.network.group.impl.driver.MsgKey
 
getMultiRuntimeDefinition(URI, String, String) - Method in interface org.apache.reef.runtime.multi.client.MultiRuntimeDefinitionGenerator
Generates needed driver configuration modules.
getMyData() - Method in class org.apache.reef.io.network.group.impl.utils.ScatterData
Returns data that is assigned to this node.
getMyId() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getMyIdentifier() - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
getMyIdentifier() - Method in class org.apache.reef.runtime.mesos.util.MesosRemoteManager
 
getMyIdentifier() - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
Returns my identifier.
getMyIdentifier() - Method in interface org.apache.reef.wake.remote.RemoteManager
Access the Identifier of this.
getName() - Method in interface org.apache.reef.driver.catalog.ResourceCatalog.Descriptor
 
getName() - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
 
getName() - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getName() - Method in class org.apache.reef.io.storage.local.CodecFileAccumulable
 
getName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string name = 1;
getName() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
required string name = 1;
getName() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
required string name = 1;
getName() - Method in class org.apache.reef.runtime.common.driver.catalog.NodeDescriptorImpl
 
getName() - Method in class org.apache.reef.runtime.common.driver.catalog.RackDescriptorImpl
 
getName() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEvent
 
getName() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
getName() - Method in interface org.apache.reef.runtime.common.files.FileResource
 
getName() - Method in class org.apache.reef.runtime.common.files.FileResourceImpl
 
getName() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
getName() - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
getName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string name = 1;
getName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
required string name = 1;
getName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
required string name = 1;
getName() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
required string name = 1;
getName() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
required string name = 1;
getName() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
required string name = 1;
getName() - Method in interface org.apache.reef.tang.types.ConstructorArg
 
getName() - Method in interface org.apache.reef.tang.types.Node
 
getName() - Method in class org.apache.reef.wake.metrics.Meter
Gets the name of the meter.
getName() - Method in class org.apache.reef.wake.profiler.Vertex
 
getName() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Gets the value of the 'name' field.
getName() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
Gets the value of the 'name' field.
getNameAssignment() - Method in class org.apache.reef.io.network.naming.serialization.NamingRegisterRequest
Gets a name assignment.
getNameAssignments() - Method in class org.apache.reef.io.network.naming.serialization.NamingLookupResponse
Gets name assignments.
getNameBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
required string name = 1;
getNameBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
required string name = 1;
getNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
required string name = 1;
getNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
required string name = 1;
getNameBytes() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
required string name = 1;
getNameBytes() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
required string name = 1;
getNameClient() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getNamedInstance(Class<? extends Name<T>>) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getNamedInstance(Class<? extends Name<U>>) - Method in interface org.apache.reef.tang.Injector
Gets the value stored for the given named parameter.
getNamedParameter(NamedParameterNode<?>) - Method in interface org.apache.reef.tang.Configuration
Return the value of the given named parameter as an unparsed string.
getNamedParameter(NamedParameterNode<?>) - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getNamedParameter(Class<? extends Name<T>>) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
getNamedParameterName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Gets the value of the 'namedParameterName' field.
getNamedParameterName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Gets the value of the 'namedParameterName' field.
getNamedParameterName() - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
getNamedParameterName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
optional string named_parameter_name = 2;
getNamedParameterName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
optional string named_parameter_name = 2;
getNamedParameterName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
optional string named_parameter_name = 2;
getNamedParameterName() - Method in interface org.apache.reef.tang.types.ConstructorArg
 
getNamedParameterNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
optional string named_parameter_name = 2;
getNamedParameterNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
optional string named_parameter_name = 2;
getNamedParameterNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
optional string named_parameter_name = 2;
getNamedParameterNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the value of the 'namedParameterNode' field.
getNamedParameterNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Gets the value of the 'namedParameterNode' field.
getNamedParameterNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameterNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameterNode() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameterNodeBuilder() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the Builder instance for the 'namedParameterNode' field and creates one if it doesn't exist yet.
getNamedParameterNodeBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameterNodeOrBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameterNodeOrBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameterNodeOrBuilder() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .NamedParameterNode named_parameter_node = 4;
getNamedParameters() - Method in interface org.apache.reef.tang.Configuration
 
getNamedParameters() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
getNamedParameterTargetOrNull(Class<?>) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
 
getNames() - Method in class org.apache.reef.tang.util.Tint
 
getNameServerInfo() - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
 
getNamespace() - Method in interface org.apache.reef.tang.ClassHierarchy
Return a reference to the root of the ClassHierarchy.
getNamespace() - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
getNamespace() - Method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
 
getNamesUsedAndSet() - Method in class org.apache.reef.tang.util.Tint
 
getNewEvaluatorManagerForEvaluatorFailedDuringDriverRestart(ResourceStatusEvent) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManagerFactory
Instantiates a new EvaluatorManager for a failed evaluator during driver restart.
getNewEvaluatorManagerForNewEvaluator(ResourceAllocationEvent) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManagerFactory
Instantiates a new EvaluatorManager based on a resource allocation.
getNewEvaluatorManagerForRecoveredEvaluator(ResourceRecoverEvent) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManagerFactory
Instantiates a new EvaluatorManager based on a resource allocation from a recovered evaluator.
getNewInstance(Class<? extends Name<String>>, Class<? extends Topology>, int, int) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverFactory
Instantiates a new CommunicationGroupDriver instance.
getNewInstance(Class<? extends Name<String>>, Class<? extends Topology>) - Method in class org.apache.reef.io.network.group.impl.driver.TopologyFactory
Instantiates a new Topology instance.
getNewInstance(String) - Method in class org.apache.reef.io.network.util.StringIdentifierFactory
Creates a StringIdentifier object.
getNewInstance(String) - Method in interface org.apache.reef.wake.IdentifierFactory
Creates a RemoteIdentifier object.
getNewInstance(String) - Method in class org.apache.reef.wake.impl.DefaultIdentifierFactory
Creates a new remote identifier instance.
getNewInstance(String) - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteIdentifierFactoryImplementation
 
getNewInstance(String) - Method in interface org.apache.reef.wake.remote.RemoteIdentifierFactory
Creates a RemoteIdentifier object.
getNewLoggingScope(Level, String) - Static method in class org.apache.reef.util.logging.LoggingScopeFactory
Get a new instance of LoggingScope with specified log level.
getNewLoggingScope(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
Get a new instance of LoggingScope with injected LoggingScopeFactory instance.
getNewLoggingScope(String, Object[]) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
Get a new instance of LoggingScope with msg and params through new.
getNewlyRequestedEvaluatorNumber() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getNewName() - Method in interface org.apache.reef.io.checkpoint.CheckpointNamingService
Generate a new checkpoint Name.
getNewName() - Method in class org.apache.reef.io.checkpoint.RandomNameCNS
 
getNewName() - Method in class org.apache.reef.io.checkpoint.SimpleNamingService
Generate a new checkpoint name.
getNext() - Method in interface org.apache.reef.wake.examples.p2p.EventSource
 
getNextID() - Method in class org.apache.reef.runtime.local.driver.IDMaker
 
getNextSeq(SocketAddress) - Method in class org.apache.reef.wake.remote.impl.RemoteSeqNumGenerator
 
getNode(String) - Method in interface org.apache.reef.driver.catalog.ResourceCatalog
Get the node descriptor with the given identifier.
getNode(String) - Method in class org.apache.reef.runtime.common.driver.catalog.ResourceCatalogImpl
 
getNode(String) - Method in interface org.apache.reef.tang.ClassHierarchy
Lookup a node in this class hierarchy.
getNode() - Method in class org.apache.reef.tang.implementation.Constructor
 
getNode() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
getNode(Class<?>) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
getNode(String) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
getNode(String) - Method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
 
getNode(Class<?>) - Method in interface org.apache.reef.tang.JavaClassHierarchy
Look up a class object in this ClassHierarchy.
getNodeDescriptor() - Method in interface org.apache.reef.driver.evaluator.EvaluatorDescriptor
 
getNodeDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Gets the value of the 'nodeDescriptor' field.
getNodeDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Gets the value of the 'nodeDescriptor' field.
getNodeDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Gets the Builder instance for the 'nodeDescriptor' field and creates one if it doesn't exist yet.
getNodeId() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceEvent
 
getNodeId() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
getNodeID() - Method in interface org.apache.reef.runtime.local.driver.Container
 
getNodeID() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
getNodeId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'nodeId' field.
getNodeId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'nodeId' field.
getNodeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'nodeName' field.
getNodeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'nodeName' field.
getNodeNameList() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getNodeNameList() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getNodeNames() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Access the preferred node.
getNodeNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Gets the value of the 'nodeNames' field.
getNodeNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Gets the value of the 'nodeNames' field.
getNodes() - Method in interface org.apache.reef.driver.catalog.RackDescriptor
 
getNodes() - Method in interface org.apache.reef.driver.catalog.ResourceCatalog
The global list of resources.
getNodes() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Gets the value of the 'nodes' field.
getNodes() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Gets the value of the 'nodes' field.
getNodes() - Method in class org.apache.reef.runtime.common.driver.catalog.RackDescriptorImpl
 
getNodes() - Method in class org.apache.reef.runtime.common.driver.catalog.ResourceCatalogImpl
 
getNodeVersion(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Get the version of the Task 'taskId'.
getNodeVersion(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
getNodeVersion(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.Constructor
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.InjectionFuturePlan
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.ListInjectionPlan
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.SetInjectionPlan
 
getNumAlternatives() - Method in class org.apache.reef.tang.implementation.Subplan
 
getNumber() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Access the number of Evaluators requested.
getNumber() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Gets the value of the 'number' field.
getNumber() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Gets the value of the 'number' field.
getNumber() - Method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
getNumber() - Method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
getNumber() - Method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
getNumber() - Method in enum org.apache.reef.proto.ReefServiceProtos.State
 
getNumberOfChildren() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
getNumberOfChildren() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
getNumberOfCores() - Method in interface org.apache.reef.driver.evaluator.EvaluatorDescriptor
 
getNumberOfCores() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Access the number of core of Evaluators requested.
getNumberOfCores() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Gets the value of the 'numberOfCores' field.
getNumberOfCores() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Gets the value of the 'numberOfCores' field.
getNumberOfCores() - Method in interface org.apache.reef.runtime.local.driver.Container
 
getNumberOfCores() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
getNumberOfPartitions() - Method in interface org.apache.reef.io.data.loading.api.DataLoadingService
Access to the number of partitions suggested by this DataSource.
getNumberOfPartitions() - Method in class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
This method actually returns the number of splits in all partition of the data.
getNumberOfSplits() - Method in interface org.apache.reef.io.data.loading.api.EvaluatorToPartitionStrategy
Returns the total number of splits computed in this strategy.
getNumberOfSplits() - Method in class org.apache.reef.io.data.loading.impl.AbstractEvaluatorToPartitionStrategy
 
getNumBins() - Method in interface org.apache.reef.wake.metrics.Histogram
Returns the number of bins.
getNumBins() - Method in class org.apache.reef.wake.metrics.UniformHistogram
Returns the number of bins.
getObject() - Method in class org.apache.reef.wake.profiler.Vertex
 
getOffset() - Method in class org.apache.reef.bridge.message.Protocol.Builder
Gets the value of the 'offset' field.
getOffset() - Method in class org.apache.reef.bridge.message.Protocol
Gets the value of the 'offset' field.
getOperatorname() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getOperatorname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string operatorname = 5;
getOperatorname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional string operatorname = 5;
getOperatorname() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional string operatorname = 5;
getOperatornameBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string operatorname = 5;
getOperatornameBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional string operatorname = 5;
getOperatornameBytes() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional string operatorname = 5;
getOperName() - Method in class org.apache.reef.io.network.group.api.operators.AbstractGroupCommOperator
 
getOperName() - Method in interface org.apache.reef.io.network.group.api.operators.GroupCommOperator
 
getOperName() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.driver.IndexedMsg
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
getOperName() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getOtherConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Gets the value of the 'otherConstructors' field.
getOtherConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Gets the value of the 'otherConstructors' field.
getOtherConstructors(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructors(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructors(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsCount() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsCount() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsOrBuilder(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsOrBuilder(int) - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsOrBuilderList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
repeated .ConstructorDef OtherConstructors = 5;
getOtherConstructorsOrBuilderList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
repeated .ConstructorDef OtherConstructors = 5;
getOutEdges() - Method in class org.apache.reef.wake.profiler.Vertex
 
getOutMeter() - Method in class org.apache.reef.wake.AbstractEStage
Gets the output meter of this stage.
getOutMeter() - Method in class org.apache.reef.wake.rx.AbstractRxStage
Gets the output meter of this stage.
getOutstandingContainerRequests() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEvent
 
getOutstandingContainerRequests() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
getPackageNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the value of the 'packageNode' field.
getPackageNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Gets the value of the 'packageNode' field.
getPackageNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
getPackageNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .PackageNode package_node = 5;
getPackageNode() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .PackageNode package_node = 5;
getPackageNodeBuilder() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Gets the Builder instance for the 'packageNode' field and creates one if it doesn't exist yet.
getPackageNodeBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
getPackageNodeOrBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
getPackageNodeOrBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .PackageNode package_node = 5;
getPackageNodeOrBuilder() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .PackageNode package_node = 5;
getParameterParser() - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
getParent() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
getParent() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getParent() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
getParent() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getParent() - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
getParent() - Method in interface org.apache.reef.tang.types.Node
 
getParentContext() - Method in interface org.apache.reef.driver.context.ClosedContext
 
getParentContext() - Method in interface org.apache.reef.driver.context.FailedContext
 
getParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Gets the value of the 'parentContext' field.
getParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Gets the value of the 'parentContext' field.
getParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Gets the value of the 'parentContext' field.
getParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Gets the value of the 'parentContext' field.
getParentContext() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getParentContext() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
getParentContext() - Method in class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
getParentContext() - Method in class org.apache.reef.runtime.common.driver.context.FailedContextImpl
 
getParentContextBridge() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getParentContextBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Gets the Builder instance for the 'parentContext' field and creates one if it doesn't exist yet.
getParentContextBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Gets the Builder instance for the 'parentContext' field and creates one if it doesn't exist yet.
getParentContextId() - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
getParentContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string parent_context_id = 1;
getParentContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
required string parent_context_id = 1;
getParentContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
required string parent_context_id = 1;
getParentContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string parent_context_id = 1;
getParentContextIdBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
required string parent_context_id = 1;
getParentContextIdBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
required string parent_context_id = 1;
getParentId() - Method in interface org.apache.reef.driver.context.ContextBase
 
getParentId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Gets the value of the 'parentId' field.
getParentId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Gets the value of the 'parentId' field.
getParentId() - Method in class org.apache.reef.javabridge.ClosedContextBridge
 
getParentId() - Method in class org.apache.reef.javabridge.FailedContextBridge
 
getParentId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional string parent_id = 3;
getParentId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional string parent_id = 3;
getParentId() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional string parent_id = 3;
getParentId() - Method in class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
getParentId() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
getParentId() - Method in class org.apache.reef.runtime.common.driver.context.FailedContextImpl
 
getParentId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
getParentID() - Method in exception org.apache.reef.runtime.common.evaluator.context.ContextClientCodeException
 
getParentIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional string parent_id = 3;
getParentIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional string parent_id = 3;
getParentIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional string parent_id = 3;
getParentIdString() - Method in class org.apache.reef.javabridge.FailedContextBridge
Used by InterOp code.
getParserForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
getParserForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
getParserForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
getParserForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
getParserForType() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
getParserForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
getParserForType() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
getParserForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
getParserForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
getParserForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
getParserForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
getParserForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
getParserForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
getParserForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
getParserForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
getParserForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
getParserForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
getParserForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
getParserForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
getParserForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
getParserForType() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
getPath() - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
getPath() - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
getPath() - Method in interface org.apache.reef.runtime.common.files.FileResource
 
getPath() - Method in class org.apache.reef.runtime.common.files.FileResourceImpl
 
getPath() - Method in interface org.apache.reef.runtime.common.files.RuntimePathProvider
 
getPath() - Method in class org.apache.reef.runtime.common.files.UnixJVMPathProvider
 
getPath() - Method in class org.apache.reef.runtime.hdinsight.HDInsightJVMPathProvider
 
getPath() - Method in class org.apache.reef.runtime.yarn.client.uploader.JobFolder
 
getPathInfo() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Gets the value of the 'pathInfo' field.
getPathInfo() - Method in class org.apache.reef.webserver.AvroHttpRequest
Gets the value of the 'pathInfo' field.
getPathInfo() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get path infor, like /Reef/Evaluators/.
getPeriodMilliseconds() - Method in class org.apache.reef.vortex.api.VortexAggregatePolicy
 
getPID() - Static method in class org.apache.reef.util.OSUtils
 
getPlans() - Method in class org.apache.reef.tang.implementation.Subplan
 
getPlans(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlans(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
repeated .InjectionPlan plans = 2;
getPlans(int) - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
repeated .InjectionPlan plans = 2;
getPlansBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlansBuilderList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlansCount() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlansCount() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
repeated .InjectionPlan plans = 2;
getPlansCount() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
repeated .InjectionPlan plans = 2;
getPlansList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlansList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
repeated .InjectionPlan plans = 2;
getPlansList() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
repeated .InjectionPlan plans = 2;
getPlansOrBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlansOrBuilder(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
repeated .InjectionPlan plans = 2;
getPlansOrBuilder(int) - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
repeated .InjectionPlan plans = 2;
getPlansOrBuilderList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
getPlansOrBuilderList() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
repeated .InjectionPlan plans = 2;
getPlansOrBuilderList() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
repeated .InjectionPlan plans = 2;
getPolicy() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
 
getPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Gets the value of the 'port' field.
getPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Gets the value of the 'port' field.
getPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Gets the value of the 'port' field.
getPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Gets the value of the 'port' field.
getPort() - Method in interface org.apache.reef.io.network.naming.NameServer
get port number.
getPort() - Method in class org.apache.reef.io.network.naming.NameServerImpl
Gets port.
getPort() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEvent
 
getPort() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl
 
getPort() - Method in interface org.apache.reef.webserver.HttpServer
get port number of the server.
getPort() - Method in class org.apache.reef.webserver.HttpServerImpl
 
getPort() - Method in class org.apache.reef.webserver.NoOpHttpServerImpl
 
getPreserveEvaluators() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getPreserveEvaluators() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getPreviousEvaluators() - Method in interface org.apache.reef.driver.restart.DriverRuntimeRestartManager
Gets the sets of alive and failed evaluators based on the runtime implementation.
getPreviousEvaluators() - Method in class org.apache.reef.runtime.yarn.driver.YarnDriverRuntimeRestartManager
getPriority() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getPriority() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getPriority() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getPriority() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getPriority() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getProbOfSuccessfulIteration() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
getProcess() - Method in interface org.apache.reef.driver.evaluator.EvaluatorDescriptor
 
getProcess() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Gets the value of the 'process' field.
getProcess() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Gets the value of the 'process' field.
getProcess() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceLaunchEvent
 
getProcess() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
getProcessBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Gets the Builder instance for the 'process' field and creates one if it doesn't exist yet.
getProgress() - Method in class org.apache.reef.driver.DefaultProgressProvider
 
getProgress() - Method in interface org.apache.reef.driver.ProgressProvider
 
getProgress() - Method in class org.apache.reef.javabridge.generic.JobDriver.ProgressProvider
 
getProgress() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getProgressProvider() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getQueryMap() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get parsed queries.
getQueryRequestData() - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
getQueryResponseData() - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
getQueryResult() - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
getQueryString() - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
getQueryString() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Gets the value of the 'queryString' field.
getQueryString() - Method in class org.apache.reef.webserver.AvroHttpRequest
Gets the value of the 'queryString' field.
getQueryString() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get query string like "id=12345" .
getQueue() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getQueue() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getQueueLength() - Method in class org.apache.reef.wake.impl.ThreadPoolStage
Gets the queue length of this stage.
getQueueLength() - Method in class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Gets the queue length of this stage.
getRackDescriptor() - Method in interface org.apache.reef.driver.catalog.NodeDescriptor
 
getRackDescriptor() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Gets the value of the 'rackDescriptor' field.
getRackDescriptor() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Gets the value of the 'rackDescriptor' field.
getRackDescriptor() - Method in class org.apache.reef.runtime.common.driver.catalog.NodeDescriptorImpl
 
getRackDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Gets the Builder instance for the 'rackDescriptor' field and creates one if it doesn't exist yet.
getRackName() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEvent
 
getRackName() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl
 
getRackName() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceEvent
 
getRackName() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
getRackName() - Method in interface org.apache.reef.runtime.local.driver.Container
 
getRackName() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
getRackName(Container) - Method in class org.apache.reef.runtime.yarn.driver.DefaultRackNameFormatter
 
getRackName(Container) - Method in interface org.apache.reef.runtime.yarn.driver.RackNameFormatter
The rack name of the Container.
getRackNameList() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getRackNameList() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getRackNames() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Access the preferred rack name.
getRackNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Gets the value of the 'rackNames' field.
getRackNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Gets the value of the 'rackNames' field.
getRacks() - Method in interface org.apache.reef.driver.catalog.ResourceCatalog
The global list of racks.
getRacks() - Method in class org.apache.reef.runtime.common.driver.catalog.ResourceCatalogImpl
 
getRate(TimeUnit) - Method in class org.apache.reef.wake.metrics.EWMA
Gets the rate.
getRawClass(Type) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Coerce a Type into a Class.
getReason() - Method in class org.apache.reef.common.AbstractFailure
 
getReason() - Method in interface org.apache.reef.common.Failure
 
getReason() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Gets the value of the 'reason' field.
getReason() - Method in class org.apache.reef.io.watcher.common.AvroFailure
Gets the value of the 'reason' field.
getReason() - Method in class org.apache.reef.runtime.common.driver.idle.IdleMessage
 
getReceiverId() - Method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec
 
getReceiverId() - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec
 
getRecovery() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional bool recovery = 5;
getRecovery() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
optional bool recovery = 5;
getRecovery() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
optional bool recovery = 5;
getRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bool recovery = 6;
getRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional bool recovery = 6;
getRecovery() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional bool recovery = 6;
getRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bool recovery = 5;
getRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
optional bool recovery = 5;
getRecovery() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
optional bool recovery = 5;
getRedFuncClass() - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec
 
getReduceFunction() - Method in interface org.apache.reef.io.network.group.api.operators.AllReduce
Get the Reduce.ReduceFunction configured.
getReduceFunction() - Method in interface org.apache.reef.io.network.group.api.operators.Reduce.Receiver
The reduce function to be applied on the set of received values.
getReduceFunction() - Method in interface org.apache.reef.io.network.group.api.operators.Reduce.Sender
The Reduce.ReduceFunction to be applied on the set of received values.
getReduceFunction() - Method in interface org.apache.reef.io.network.group.api.operators.ReduceScatter
get Reduce.ReduceFunction configured.
getReduceFunction() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
getReduceFunction() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
getReduceReceiver(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
The reduce receiver configured on this communication group.
getReduceReceiver(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getReduceSender(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
The reduce sender configured on this communication group.
getReduceSender(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getREEFFolder() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getREEFFolderName() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
The name of the REEF folder inside of the working directory of an Evaluator or Driver.
getRelaxLocality() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getRelaxLocality() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getRemoteAddress() - Method in class org.apache.reef.wake.remote.impl.TransportEvent
Gets the remote socket address.
getRemoteAddress() - Method in interface org.apache.reef.wake.remote.transport.Link
Gets its remote address.
getRemoteAddress() - Method in class org.apache.reef.wake.remote.transport.netty.NettyLink
Gets a remote address of the link.
getRemoteId() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getRemoteId() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getRemoteId() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceLaunchEvent
 
getRemoteId() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
getRemoteId() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Gets the value of the 'remoteId' field.
getRemoteId() - Method in class org.apache.reef.webserver.AvroDriverInfo
Gets the value of the 'remoteId' field.
getRemoveContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
getRemoveContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .RemoveContextProto remove_context = 6;
getRemoveContext() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .RemoveContextProto remove_context = 6;
getRemoveContextBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
getRemoveContextOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
getRemoveContextOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .RemoveContextProto remove_context = 6;
getRemoveContextOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .RemoveContextProto remove_context = 6;
getReports() - Method in class org.apache.reef.vortex.protocol.workertomaster.WorkerToMasterReports
 
getRequest() - Method in class org.apache.reef.io.network.naming.serialization.NamingRegisterResponse
Gets a naming register request.
getRequestUri() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get URI, like /Reef/Evaluators/.
getRequestUrl() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Gets the value of the 'requestUrl' field.
getRequestUrl() - Method in class org.apache.reef.webserver.AvroHttpRequest
Gets the value of the 'requestUrl' field.
getRequestUrl() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get URL like //http://localhost:8080/Reef/Evaluators/.
getResource() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationID
 
getResource() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
getResource() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
getResourceCount() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getResourceCount() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getResourceMemory() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceEvent
 
getResourceMemory() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
getResourceRecoverEvent(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
 
getResourceRecoverEvent() - Method in class org.apache.reef.driver.restart.EvaluatorRestartInfo
 
getResubmissionAttempts() - Method in interface org.apache.reef.driver.restart.DriverRestarted
 
getResubmissionAttempts() - Method in class org.apache.reef.driver.restart.DriverRestartedImpl
 
getResubmissionAttempts() - Method in interface org.apache.reef.driver.restart.DriverRuntimeRestartManager
 
getResubmissionAttempts() - Method in class org.apache.reef.javabridge.DriverRestartedBridge
 
getResubmissionAttempts() - Method in class org.apache.reef.runtime.yarn.driver.YarnDriverRuntimeRestartManager
Determines the number of times the Driver has been submitted based on the container ID environment variable provided by YARN.
getResult() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bytes result = 4;
getResult() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
optional bytes result = 4;
getResult() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
optional bytes result = 4;
getResult() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
getResult() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationResultReport
 
getResult() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletResultReport
 
getRight() - Method in class org.apache.reef.wake.impl.MergingEventHandler
 
getRootId() - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Get the id of the root task.
getRootId() - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
getRootId() - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
getRunningContainers() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getRunningTaskHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getRuntimeError() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeError() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeError() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeErrorBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeErrorOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeErrorOrBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeErrorOrBuilder() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .RuntimeErrorProto runtimeError = 3;
getRuntimeName() - Method in interface org.apache.reef.driver.evaluator.EvaluatorDescriptor
 
getRuntimeName() - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Access the required runtime name.
getRuntimeName() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceLaunchEvent
 
getRuntimeName() - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
getRuntimeName() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceReleaseEvent
 
getRuntimeName() - Method in class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl
 
getRuntimeName() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getRuntimeName() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getRuntimeName() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceEvent
 
getRuntimeName() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
getRuntimeName() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEvent
 
getRuntimeName() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
getRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Gets the value of the 'runtimeName' field.
getRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Gets the value of the 'runtimeName' field.
getRuntimeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'runtimeName' field.
getRuntimeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'runtimeName' field.
getRuntimeNames() - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes.Builder
Gets the value of the 'runtimeNames' field.
getRuntimeNames() - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
Gets the value of the 'runtimeNames' field.
getRuntimes() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the value of the 'runtimes' field.
getRuntimes() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Gets the value of the 'runtimes' field.
getRuntimes() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Gets the value of the 'runtimes' field.
getRuntimes() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Gets the value of the 'runtimes' field.
getScatterReceiver(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
Return the scatter receiver configured on this communication group.
getScatterReceiver(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getScatterSender(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
Return the scatter sender configured on this communication group.
getScatterSender(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getSchema() - Method in class org.apache.reef.bridge.message.Acknowledgement
 
getSchema() - Method in class org.apache.reef.bridge.message.BridgeInterop
 
getSchema() - Method in class org.apache.reef.bridge.message.Header
 
getSchema() - Method in class org.apache.reef.bridge.message.Protocol
 
getSchema() - Method in class org.apache.reef.bridge.message.SetupBridge
 
getSchema() - Method in class org.apache.reef.bridge.message.SystemOnStart
 
getSchema() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
getSchema() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
getSchema() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
getSchema() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
getSchema() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
getSchema() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
getSchema() - Method in class org.apache.reef.io.watcher.common.AvroFailure
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
getSchema() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
getSchema() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
getSchema() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
getSchema() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
getSchema() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
getSchema() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
 
getSchema() - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
getSchema() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
getSchema() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
getSchema() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
getSchema() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
getSchema() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
getSchema() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
getSchema() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
getSchema() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
getSchema() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
getSchema() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
getSchema() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
getSchema() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
getSchema() - Method in class org.apache.reef.tang.implementation.avro.AvroNode
 
getSchema() - Method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
getSchema() - Method in class org.apache.reef.webserver.AvroDriverInfo
 
getSchema() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
 
getSchema() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
 
getSchema() - Method in class org.apache.reef.webserver.AvroEvaluatorList
 
getSchema() - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
getSchema() - Method in class org.apache.reef.webserver.AvroHttpRequest
 
getSchema() - Method in class org.apache.reef.webserver.AvroReefServiceInfo
 
getSchema() - Method in class org.apache.reef.webserver.HeaderEntry
 
getScratchSpace() - Method in class org.apache.reef.io.storage.local.LocalStorageService
 
getScratchSpace() - Method in class org.apache.reef.io.storage.ram.RamStorageService
 
getScratchSpace() - Method in interface org.apache.reef.io.storage.StorageService
 
getSecond() - Method in class org.apache.reef.io.network.util.Pair
 
getSecond() - Method in class org.apache.reef.wake.impl.MergingEventHandler.Pair
 
getSecrets() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
getSecurityTokenIdentifierFile() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getSecurityTokenKind() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'securityTokenKind' field.
getSecurityTokenKind() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'securityTokenKind' field.
getSecurityTokenPasswordFile() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getSecurityTokenService() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'securityTokenService' field.
getSecurityTokenService() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'securityTokenService' field.
getSelectedIndex() - Method in class org.apache.reef.tang.implementation.Subplan
 
getSelectedPlan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
optional sint32 selected_plan = 1;
getSelectedPlan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
optional sint32 selected_plan = 1;
getSelectedPlan() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
optional sint32 selected_plan = 1;
getSelfId() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getSelfId() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getSender() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getSender() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getSenderId() - Method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec
 
getSenderId() - Method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec
 
getSeq() - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Gets the sequence number.
getSeq() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required int64 seq = 2;
getSeq() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
required int64 seq = 2;
getSeq() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBufOrBuilder
required int64 seq = 2;
getSequence() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Gets the value of the 'sequence' field.
getSequence() - Method in class org.apache.reef.bridge.message.BridgeInterop
Gets the value of the 'sequence' field.
getSequenceNumber() - Method in interface org.apache.reef.driver.context.ContextMessage
 
getSequenceNumber() - Method in interface org.apache.reef.driver.task.TaskMessage
 
getSequenceNumber() - Method in interface org.apache.reef.io.Numberable
 
getSequenceNumber() - Method in class org.apache.reef.javabridge.ContextMessageBridge
 
getSequenceNumber() - Method in class org.apache.reef.runtime.common.driver.context.ContextMessageImpl
 
getSequenceNumber() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextMessagePOJO
 
getSequenceNumber() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskMessagePOJO
 
getSequenceNumber() - Method in class org.apache.reef.runtime.common.driver.task.TaskMessageImpl
 
getSerializedConfiguration() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Gets the value of the 'serializedConfiguration' field.
getSerializedConfiguration() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Gets the value of the 'serializedConfiguration' field.
getSerializedSize() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
getSerializedSize() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
getSerializedSize() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
getSerializedSize() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
getSerializedSize() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
getSerializedSize() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
getSerializedSize() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
getSerializedSize() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
getSerializedSize() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
getSerializedSize() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
getSerializedSize() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
getSerializedSize() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
getServiceConfiguration(AllocatedEvaluator) - Method in interface org.apache.reef.io.data.loading.api.DataLoadingService
 
getServiceConfiguration(AllocatedEvaluator) - Method in class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
 
getServiceConfiguration() - Method in interface org.apache.reef.io.data.output.OutputService
Provides a service configuration for the output service.
getServiceConfiguration() - Method in class org.apache.reef.io.data.output.TaskOutputService
Provides a service configuration for the output service.
getServiceConfiguration() - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
 
getServiceConfiguration() - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
getServiceConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
optional string service_configuration = 3;
getServiceConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
optional string service_configuration = 3;
getServiceConfiguration() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
optional string service_configuration = 3;
getServiceConfigurationBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
optional string service_configuration = 3;
getServiceConfigurationBytes() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
optional string service_configuration = 3;
getServiceConfigurationBytes() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
optional string service_configuration = 3;
getServiceData() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
getServiceInfo() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Gets the value of the 'serviceInfo' field.
getServiceInfo() - Method in class org.apache.reef.webserver.AvroReefServiceInfo
Gets the value of the 'serviceInfo' field.
getServiceName() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Gets the value of the 'serviceName' field.
getServiceName() - Method in class org.apache.reef.webserver.AvroReefServiceInfo
Gets the value of the 'serviceName' field.
getServices() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Gets the value of the 'services' field.
getServices() - Method in class org.apache.reef.webserver.AvroDriverInfo
Gets the value of the 'services' field.
getServicesInfo() - Method in class org.apache.reef.webserver.ReefEventStateManager
 
getSettersOf(Node) - Method in class org.apache.reef.tang.util.Tint
 
getSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Gets the value of the 'sharedAppSubmissionParameters' field.
getSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Gets the value of the 'sharedAppSubmissionParameters' field.
getSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the value of the 'sharedAppSubmissionParameters' field.
getSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Gets the value of the 'sharedAppSubmissionParameters' field.
getSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Gets the value of the 'sharedAppSubmissionParameters' field.
getSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Gets the value of the 'sharedAppSubmissionParameters' field.
getSharedAppSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Gets the Builder instance for the 'sharedAppSubmissionParameters' field and creates one if it doesn't exist yet.
getSharedAppSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the Builder instance for the 'sharedAppSubmissionParameters' field and creates one if it doesn't exist yet.
getSharedAppSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Gets the Builder instance for the 'sharedAppSubmissionParameters' field and creates one if it doesn't exist yet.
getSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Gets the value of the 'sharedJobSubmissionParameters' field.
getSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Gets the value of the 'sharedJobSubmissionParameters' field.
getSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Gets the value of the 'sharedJobSubmissionParameters' field.
getSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Gets the value of the 'sharedJobSubmissionParameters' field.
getSharedJobSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Gets the Builder instance for the 'sharedJobSubmissionParameters' field and creates one if it doesn't exist yet.
getSharedJobSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Gets the Builder instance for the 'sharedJobSubmissionParameters' field and creates one if it doesn't exist yet.
getShortName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'shortName' field.
getShortName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'shortName' field.
getShortName() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
getShortName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string short_name = 6;
getShortName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string short_name = 6;
getShortName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string short_name = 6;
getShortName() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
getShortNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string short_name = 6;
getShortNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string short_name = 6;
getShortNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string short_name = 6;
getSignal() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional .Signal signal = 2;
getSignal() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
optional .Signal signal = 2;
getSignal() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
optional .Signal signal = 2;
getSimpleArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Gets the value of the 'simpleArgClassName' field.
getSimpleArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Gets the value of the 'simpleArgClassName' field.
getSimpleArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string simple_arg_class_name = 1;
getSimpleArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required string simple_arg_class_name = 1;
getSimpleArgClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required string simple_arg_class_name = 1;
getSimpleArgClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string simple_arg_class_name = 1;
getSimpleArgClassNameBytes() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required string simple_arg_class_name = 1;
getSimpleArgClassNameBytes() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required string simple_arg_class_name = 1;
getSimpleArgName() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
getSimpleArgName() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
getSimpleName(Type) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Get the simple name of the class.
getSimpleOperName() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getSize() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
getSocketAddress() - Method in class org.apache.reef.wake.remote.impl.SocketRemoteIdentifier
Gets the socket address.
getSource() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required string source_id = 1;
getSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
required string source_id = 1;
getSourceId() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProtoOrBuilder
required string source_id = 1;
getSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required string source_id = 1;
getSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
required string source_id = 1;
getSourceId() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProtoOrBuilder
required string source_id = 1;
getSourceId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextMessagePOJO
 
getSourceId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskMessagePOJO
 
getSourceIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required string source_id = 1;
getSourceIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
required string source_id = 1;
getSourceIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProtoOrBuilder
required string source_id = 1;
getSourceIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required string source_id = 1;
getSourceIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
required string source_id = 1;
getSourceIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProtoOrBuilder
required string source_id = 1;
getSrc() - Method in class org.apache.reef.io.network.group.impl.driver.MsgKey
 
getSrcid() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getSrcId() - Method in class org.apache.reef.io.network.impl.NSMessage
Gets a source identifier.
getSrcId() - Method in interface org.apache.reef.io.network.Message
Gets a source identifier.
getSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string srcid = 2;
getSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required string srcid = 2;
getSrcid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required string srcid = 2;
getSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string srcid = 2;
getSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
required string srcid = 2;
getSrcid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
required string srcid = 2;
getSrcidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string srcid = 2;
getSrcidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required string srcid = 2;
getSrcidBytes() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required string srcid = 2;
getSrcidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string srcid = 2;
getSrcidBytes() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
required string srcid = 2;
getSrcidBytes() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
required string srcid = 2;
getSrcVersion() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getSrcVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 srcVersion = 7;
getSrcVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional int32 srcVersion = 7;
getSrcVersion() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional int32 srcVersion = 7;
getStackTrace() - Method in class org.apache.reef.javabridge.FailedEvaluatorBridge
 
getStartedTime() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getStartTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
getStartTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .StartTaskProto start_task = 7;
getStartTask() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .StartTaskProto start_task = 7;
getStartTaskBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
getStartTaskOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
getStartTaskOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .StartTaskProto start_task = 7;
getStartTaskOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .StartTaskProto start_task = 7;
getStartTime() - Method in interface org.apache.reef.driver.restart.DriverRestarted
 
getStartTime() - Method in class org.apache.reef.driver.restart.DriverRestartedImpl
 
getStartTime() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.reef.webserver.AvroDriverInfo
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.reef.webserver.AvroEvaluatorList
Gets the value of the 'startTime' field.
getStartTime() - Method in class org.apache.reef.webserver.ReefEventStateManager
get start time.
getState() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required .State state = 2;
getState() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
required .State state = 2;
getState() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
required .State state = 2;
getState() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required .State state = 2;
getState() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
required .State state = 2;
getState() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
required .State state = 2;
getState() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required .State state = 3;
getState() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required .State state = 3;
getState() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required .State state = 3;
getState() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.EvaluatorStatusPOJO
 
getState() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
getState() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEvent
 
getState() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
getState() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEvent
 
getState() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
getState() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getStatus() - Method in class org.apache.reef.client.DriverLauncher
 
getStatusProto() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
Called by heartbeat manager.
getStopEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
getStopEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .StopEvaluatorProto stop_evaluator = 5;
getStopEvaluator() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .StopEvaluatorProto stop_evaluator = 5;
getStopEvaluatorBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
getStopEvaluatorOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
getStopEvaluatorOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .StopEvaluatorProto stop_evaluator = 5;
getStopEvaluatorOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .StopEvaluatorProto stop_evaluator = 5;
getStopTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
getStopTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .StopTaskProto stop_task = 8;
getStopTask() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .StopTaskProto stop_task = 8;
getStopTaskBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
getStopTaskOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
getStopTaskOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .StopTaskProto stop_task = 8;
getStopTaskOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .StopTaskProto stop_task = 8;
getStopTime() - Method in class org.apache.reef.webserver.ReefEventStateManager
get stop time.
getStringApplicationId() - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
 
getSubplan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
getSubplan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Subplan subplan = 4;
getSubplan() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Subplan subplan = 4;
getSubplanBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
getSubplanOrBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
getSubplanOrBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Subplan subplan = 4;
getSubplanOrBuilder() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Subplan subplan = 4;
getSuspendedTaskHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getSuspendTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
getSuspendTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .SuspendTaskProto suspend_task = 9;
getSuspendTask() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .SuspendTaskProto suspend_task = 9;
getSuspendTaskBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
getSuspendTaskOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
getSuspendTaskOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .SuspendTaskProto suspend_task = 9;
getSuspendTaskOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .SuspendTaskProto suspend_task = 9;
getT() - Method in class org.apache.reef.examples.group.bgd.utils.StepSizes
 
getT1() - Method in class org.apache.reef.wake.remote.impl.Tuple2
 
getT2() - Method in class org.apache.reef.wake.remote.impl.Tuple2
 
getTang() - Static method in class org.apache.reef.tang.Tang.Factory
Return an instance of the default implementation of Tang.
getTargetEntity() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get target target entity like "Evaluators".
getTargetSpecification() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get target to match specification like "Reef".
getTaskConfiguration(Configuration) - Method in interface org.apache.reef.io.network.group.api.driver.CommunicationGroupDriver
Returns a configuration that includes the partial task configuration passed in as 'taskConf' and makes the current communication group and the operators configured on it available on the Task side.
getTaskConfiguration(Configuration) - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
 
getTaskConfiguration(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Get the topology portion of the Configuration.
getTaskConfiguration(Configuration) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
getTaskConfiguration(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
getTaskConfiguration(Configuration) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
getTaskConfiguration(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
getTaskId() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
getTaskId() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
getTaskId() - Method in class org.apache.reef.io.network.group.impl.driver.TopologySimpleNode
 
getTaskId() - Method in class org.apache.reef.javabridge.CompletedTaskBridge
 
getTaskId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string task_id = 1;
getTaskId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required string task_id = 1;
getTaskId() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required string task_id = 1;
getTaskId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
getTaskId(Configuration) - Static method in exception org.apache.reef.runtime.common.evaluator.task.TaskClientCodeException
Extracts a task id from the given configuration.
getTaskId() - Method in exception org.apache.reef.runtime.common.evaluator.task.TaskClientCodeException
 
getTaskId() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
 
getTaskId() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskStatus
 
getTaskIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string task_id = 1;
getTaskIdBytes() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required string task_id = 1;
getTaskIdBytes() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required string task_id = 1;
getTaskletId() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregateExecutionRequest
 
getTaskletId() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletCancellationRequest
 
getTaskletId() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletExecutionRequest
 
getTaskletId() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletCancelledReport
 
getTaskletId() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletFailureReport
 
getTaskletId() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletResultReport
 
getTaskletIds() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationFailureReport
 
getTaskletIds() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationResultReport
 
getTaskMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional bytes task_message = 1;
getTaskMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional bytes task_message = 1;
getTaskMessage() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional bytes task_message = 1;
getTaskMessage(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessage(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessage(int) - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageBuilderList() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageCount() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageCount() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageCount() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageHandler() - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
getTaskMessageList() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageList() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageList() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageList() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
getTaskMessageOrBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageOrBuilder(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageOrBuilder(int) - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageOrBuilderList() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageOrBuilderList() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskMessageOrBuilderList() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
getTaskRepresenter() - Method in interface org.apache.reef.driver.task.RunningTask
Gets the representer of task.
getTaskRepresenter() - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
getTaskStatus(int) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
Get the status of a task.
getTaskStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
getTaskStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
optional .TaskStatusProto task_status = 4;
getTaskStatus() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
optional .TaskStatusProto task_status = 4;
getTaskStatus() - Method in class org.apache.reef.runtime.common.evaluator.context.ContextManager
 
getTaskStatusBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
getTaskStatusOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
getTaskStatusOrBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
optional .TaskStatusProto task_status = 4;
getTaskStatusOrBuilder() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
optional .TaskStatusProto task_status = 4;
getTcpBeginPort() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Gets the value of the 'tcpBeginPort' field.
getTcpBeginPort() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Gets the value of the 'tcpBeginPort' field.
getTcpRangeCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Gets the value of the 'tcpRangeCount' field.
getTcpRangeCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Gets the value of the 'tcpRangeCount' field.
getTcpTryCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Gets the value of the 'tcpTryCount' field.
getTcpTryCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Gets the value of the 'tcpTryCount' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime.Builder
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime.Builder
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart.Builder
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required int64 timestamp = 1;
getTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
required int64 timestamp = 1;
getTimestamp() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
required int64 timestamp = 1;
getTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required int64 timestamp = 1;
getTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
required int64 timestamp = 1;
getTimestamp() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
required int64 timestamp = 1;
getTimestamp() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
getTimestamp() - Method in class org.apache.reef.wake.time.Time
Get timestamp in milliseconds since the beginning of the epoch (01/01/1970).
getTimeStamp() - Method in class org.apache.reef.wake.time.Time
Deprecated.
[REEF-1532] Prefer using getTimestamp() instead. Remove after release 0.16.
getToken() - Method in class org.apache.reef.wake.remote.impl.Subscription
Deprecated.
Gets the token of this subscription.
getTokens() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
getTokens() - Method in interface org.apache.reef.runtime.yarn.client.SecurityTokenProvider
Returns a ByteBuffer containing security tokens.
getTokens() - Method in class org.apache.reef.runtime.yarn.client.UserCredentialSecurityTokenProvider
 
getTopologyChanges() - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
 
getTopologyChanges() - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getTopologySimpleNodeRoot() - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
 
getTopologySimpleNodeRoot() - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
getTotal() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Gets the value of the 'total' field.
getTotal() - Method in class org.apache.reef.webserver.AvroEvaluatorList
Gets the value of the 'total' field.
getTotalPhysicalMemorySizeInMB() - Static method in class org.apache.reef.util.MemoryUtils
Returns the total amount of physical memory on the current machine in megabytes.
getTrackingUI() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getTrackingUrl() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getTrackingUrl() - Method in class org.apache.reef.runtime.yarn.driver.HttpTrackingURLProvider
get tracking URI.
getTrackingUrl() - Method in interface org.apache.reef.runtime.yarn.driver.TrackingURLProvider
 
getTransport() - Method in class org.apache.reef.io.network.impl.NetworkService
 
getTuples() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse.Builder
Gets the value of the 'tuples' field.
getTuples() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Gets the value of the 'tuples' field.
getType() - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
getType() - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
 
getType() - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
getType() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required .GroupCommMessage.Type type = 1;
getType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required .GroupCommMessage.Type type = 1;
getType() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required .GroupCommMessage.Type type = 1;
getType() - Method in class org.apache.reef.io.PartitionSpec
 
getType() - Method in interface org.apache.reef.runtime.common.files.FileResource
 
getType() - Method in class org.apache.reef.runtime.common.files.FileResourceImpl
 
getType() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
getType() - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
getType() - Method in interface org.apache.reef.tang.types.ConstructorArg
 
getType() - Method in interface org.apache.reef.vortex.protocol.mastertoworker.MasterToWorkerRequest
 
getType() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregateExecutionRequest
 
getType() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
 
getType() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletCancellationRequest
 
getType() - Method in class org.apache.reef.vortex.protocol.mastertoworker.TaskletExecutionRequest
 
getType() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationFailureReport
 
getType() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationResultReport
 
getType() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletCancelledReport
 
getType() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletFailureReport
 
getType() - Method in class org.apache.reef.vortex.protocol.workertomaster.TaskletResultReport
 
getType() - Method in interface org.apache.reef.vortex.protocol.workertomaster.WorkerToMasterReport
 
getType() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Gets the value of the 'type' field.
getType() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Gets the value of the 'type' field.
getUltimateCause(Throwable) - Static method in class org.apache.reef.util.Exceptions
Walks the .getCause() chain till it hits the leaf node.
getUniformCounts(int, int) - Static method in class org.apache.reef.io.network.group.impl.utils.ScatterHelper
Uniformly distribute a number of elements across a number of Tasks and return a list of counts.
getUnknownFields() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
getUnknownFields() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
getUnknownFields() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
getUnknownFields() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
getUnknownFields() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
getUnknownFields() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
getUnknownFields() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
getUnknownFields() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
getUnknownFields() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
getUnknownFields() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
getUnknownFields() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
getUnknownFields() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
getUriSpecification() - Method in class org.apache.reef.examples.scheduler.driver.http.SchedulerHttpHandler
 
getUriSpecification() - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
getUriSpecification() - Method in interface org.apache.reef.webserver.HttpHandler
Return specification of the handler.
getUriSpecification() - Method in class org.apache.reef.webserver.HttpServerReefEventHandler
 
getUser() - Method in class org.apache.reef.client.DriverLauncher
 
getUser() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getUserName() - Method in interface org.apache.reef.runtime.common.client.api.JobSubmissionEvent
 
getUserName() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
getUsesOf(Node) - Method in class org.apache.reef.tang.util.Tint
 
getValue() - Method in class org.apache.reef.io.Tuple
 
getValue() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResourcesEntry
 
getValue() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
getValue() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Gets the value of the 'value' field.
getValue() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Gets the value of the 'value' field.
getValue() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
required string value = 1;
getValue() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
required string value = 1;
getValue() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InstanceOrBuilder
required string value = 1;
getValue() - Method in class org.apache.reef.tests.statepassing.Counter
 
getValue() - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
getValue(int) - Method in interface org.apache.reef.wake.metrics.Histogram
Returns the value of the index.
getValue(int) - Method in class org.apache.reef.wake.metrics.UniformHistogram
Returns the value of the index.
getValue() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Gets the value of the 'value' field.
getValue() - Method in class org.apache.reef.webserver.HeaderEntry
Gets the value of the 'value' field.
getValueBytes() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
required string value = 1;
getValueBytes() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
required string value = 1;
getValueBytes() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InstanceOrBuilder
required string value = 1;
getValueDescriptor() - Method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
getValueDescriptor() - Method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
getValueDescriptor() - Method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
getValueDescriptor() - Method in enum org.apache.reef.proto.ReefServiceProtos.State
 
getValues() - Method in class org.apache.reef.examples.group.utils.math.DenseVector
Access the underlying storage.
getValuesForKey(K) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
getvCores() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Resource
 
getVCoreSeconds() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
getVersion() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
getVersion() - Method in class org.apache.reef.io.network.group.api.operators.AbstractGroupCommOperator
 
getVersion() - Method in interface org.apache.reef.io.network.group.api.operators.GroupCommOperator
 
getVersion() - Method in interface org.apache.reef.io.network.group.api.task.NodeStruct
 
getVersion() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
getVersion() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
getVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 version = 6;
getVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional int32 version = 6;
getVersion() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional int32 version = 6;
getVersion() - Method in class org.apache.reef.util.REEFVersion
 
getVersion() - Method in class org.apache.reef.webserver.ParsedHttpRequest
get version of the request for Rest API.
getVirtualCores() - Method in interface org.apache.reef.runtime.common.driver.api.ResourceRequestEvent
 
getVirtualCores() - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
getVirtualCores() - Method in interface org.apache.reef.runtime.common.driver.resourcemanager.ResourceEvent
 
getVirtualCores() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
getVisibility() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
getYarnBootstrapAppParamFile() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getYarnBootstrapAppParamFilePath() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getYarnBootstrapJobParamFile() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getYarnBootstrapJobParamFilePath() - Method in class org.apache.reef.runtime.common.files.REEFFileNames
 
getYarnConfiguration() - Static method in class org.apache.reef.javabridge.generic.JobClient
 
getYarnJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the value of the 'yarnJobSubmissionParameters' field.
getYarnJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Gets the value of the 'yarnJobSubmissionParameters' field.
getYarnJobSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Gets the Builder instance for the 'yarnJobSubmissionParameters' field and creates one if it doesn't exist yet.
getYarnRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the value of the 'yarnRuntimeAppParameters' field.
getYarnRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Gets the value of the 'yarnRuntimeAppParameters' field.
getYarnRuntimeAppParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Gets the Builder instance for the 'yarnRuntimeAppParameters' field and creates one if it doesn't exist yet.
GLOBAL_FILES - Static variable in class org.apache.reef.client.DriverConfiguration
Files to be made available on the Driver and all Evaluators.
GLOBAL_FILES - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Files to be made available on the Driver and all Evaluators.
GLOBAL_LIBRARIES - Static variable in class org.apache.reef.client.DriverConfiguration
Libraries to be made available on the Driver and all Evaluators.
GLOBAL_LIBRARIES - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Libraries to be made available on the Driver and all Evaluators.
GLOBAL_LIBRARIES_FILENAME - Static variable in class org.apache.reef.javabridge.NativeInterop
 
GraphvizConfigVisitor - Class in org.apache.reef.tang.util.walk.graphviz
Build a Graphviz representation of the configuration graph.
GraphvizConfigVisitor(Configuration, boolean, boolean) - Constructor for class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
Create a new TANG configuration visitor.
GraphvizInjectionPlanVisitor - Class in org.apache.reef.tang.util.walk.graphviz
Build a Graphviz representation of the injection plan graph.
GraphvizInjectionPlanVisitor(boolean) - Constructor for class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
Create a new visitor to build a graphviz string for the injection plan.
GroupChanges - Interface in org.apache.reef.io.network.group.api
Represents the changes in Topology that happened in a communication group.
GroupChangesCodec - Class in org.apache.reef.io.network.group.impl
 
GroupChangesCodec() - Constructor for class org.apache.reef.io.network.group.impl.GroupChangesCodec
 
GroupChangesImpl - Class in org.apache.reef.io.network.group.impl
 
GroupChangesImpl(boolean) - Constructor for class org.apache.reef.io.network.group.impl.GroupChangesImpl
 
GroupCommClient - Interface in org.apache.reef.io.network.group.api.task
The task side interface for the Group Communication Service.
GroupCommClientImpl - Class in org.apache.reef.io.network.group.impl.task
 
GroupCommDriver - Interface in org.apache.reef.io.network.group.api.driver
The driver side interface of Group Communication.
GroupCommDriverImpl - Class in org.apache.reef.io.network.group.impl.driver
Sets up various stages to handle REEF events and adds the per communication group stages to them whenever a new communication group is created.
GroupCommFailedEvalHandler - Class in org.apache.reef.io.network.group.impl.config.parameters
Name class of group comm failed evaluator handler.
GroupCommFailedTaskHandler - Class in org.apache.reef.io.network.group.impl.config.parameters
Name class of group comm failed task handler.
GroupCommMessageHandler - Class in org.apache.reef.io.network.group.impl.driver
The network handler for the group communication service on the driver side.
GroupCommMessageHandler() - Constructor for class org.apache.reef.io.network.group.impl.driver.GroupCommMessageHandler
 
GroupCommNetworkHandler - Interface in org.apache.reef.io.network.group.api.task
The global EventHandler that receives the GroupCommunicationMsg.
GroupCommNetworkHandlerImpl - Class in org.apache.reef.io.network.group.impl.task
 
GroupCommNetworkHandlerImpl() - Constructor for class org.apache.reef.io.network.group.impl.task.GroupCommNetworkHandlerImpl
 
GroupCommOperator - Interface in org.apache.reef.io.network.group.api.operators
 
GroupCommRunningTaskHandler - Class in org.apache.reef.io.network.group.impl.config.parameters
Name class of group comm running task handler.
GroupCommSenderStage - Class in org.apache.reef.io.network.group.impl.config.parameters
Name class of group comm sender stage.
GroupCommService - Class in org.apache.reef.io.network.group.impl.driver
The Group Communication Service.
GroupCommService(GroupCommServiceDriver) - Constructor for class org.apache.reef.io.network.group.impl.driver.GroupCommService
 
GroupCommService.FailedEvaluatorHandler - Class in org.apache.reef.io.network.group.impl.driver
 
GroupCommService.FailedEvaluatorHandler() - Constructor for class org.apache.reef.io.network.group.impl.driver.GroupCommService.FailedEvaluatorHandler
 
GroupCommService.FailedTaskHandler - Class in org.apache.reef.io.network.group.impl.driver
 
GroupCommService.FailedTaskHandler() - Constructor for class org.apache.reef.io.network.group.impl.driver.GroupCommService.FailedTaskHandler
 
GroupCommService.RunningTaskHandler - Class in org.apache.reef.io.network.group.impl.driver
 
GroupCommService.RunningTaskHandler() - Constructor for class org.apache.reef.io.network.group.impl.driver.GroupCommService.RunningTaskHandler
 
GroupCommServiceDriver - Interface in org.apache.reef.io.network.group.api.driver
 
GroupCommunicationMessage - Class in org.apache.reef.io.network.group.impl
Group Communication Message.
GroupCommunicationMessage(String, String, ReefNetworkGroupCommProtos.GroupCommMessage.Type, String, int, String, int, byte[][]) - Constructor for class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
GroupCommunicationMessageCodec - Class in org.apache.reef.io.network.group.impl
GroupCommunicationMessageCodec() - Constructor for class org.apache.reef.io.network.group.impl.GroupCommunicationMessageCodec
 
GROUPNAME_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 

H

HADOOP_COMMON_HOME - Static variable in class org.apache.reef.util.HadoopEnvironment
 
HADOOP_CONF_DIR - Static variable in class org.apache.reef.util.HadoopEnvironment
 
HADOOP_HDFS_HOME - Static variable in class org.apache.reef.util.HadoopEnvironment
 
HADOOP_HOME - Static variable in class org.apache.reef.util.HadoopEnvironment
 
HADOOP_MAPRED_HOME - Static variable in class org.apache.reef.util.HadoopEnvironment
 
HADOOP_YARN_HOME - Static variable in class org.apache.reef.util.HadoopEnvironment
 
HadoopEnvironment - Class in org.apache.reef.util
Constants for the various Hadoop environment variables.
handle(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
handle(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
Handle messages meant for this operator.
handle(NodeDescriptorEvent) - Method in class org.apache.reef.runtime.common.driver.catalog.ResourceCatalogImpl
 
handleContextControlProtocol(EvaluatorRuntimeProtocol.ContextControlProto) - Method in class org.apache.reef.runtime.common.evaluator.context.ContextManager
Processes the given ContextControlProto to launch / close / suspend Tasks and Contexts.
hasActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Checks whether the 'activeContext' field has been set.
hasActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Checks whether the 'activeContext' field has been set.
hasActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Checks whether the 'activeContext' field has been set.
hasActiveContext() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Checks whether the 'activeContext' field has been set.
hasActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Checks whether the 'activeContext' field has an active Builder instance
hasActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Checks whether the 'activeContext' field has an active Builder instance
hasActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Checks whether the 'activeContext' field has an active Builder instance
hasActiveContextBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Checks whether the 'activeContext' field has an active Builder instance
hasAddContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
hasAddContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .AddContextProto add_context = 5;
hasAddContext() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .AddContextProto add_context = 5;
hasAliasLanguage() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_language = 9;
hasAliasLanguage() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string alias_language = 9;
hasAliasLanguage() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string alias_language = 9;
hasAliasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_name = 8;
hasAliasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string alias_name = 8;
hasAliasName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string alias_name = 8;
hasAsError() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Checks whether the 'asError' field has been set.
hasBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Checks whether the 'base' field has been set.
hasBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Checks whether the 'base' field has been set.
hasBase() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Checks whether the 'base' field has been set.
hasBaseBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Checks whether the 'base' field has an active Builder instance
hasBaseBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Checks whether the 'base' field has an active Builder instance
hasBaseBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Checks whether the 'base' field has an active Builder instance
hasBindings() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Checks whether the 'Bindings' field has been set.
hasCause() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Checks whether the 'cause' field has been set.
hasChanges() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
hasChanges() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
 
hasChanges() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
hasChanges() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
hasChanges() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
hasChanges() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
hasChildren() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'children' field has been set.
hasClassName() - Method in class org.apache.reef.bridge.message.Header.Builder
Checks whether the 'className' field has been set.
hasClassName() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required string className = 1;
hasClassName() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
required string className = 1;
hasClassName() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBufOrBuilder
required string className = 1;
hasClassNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'classNode' field has been set.
hasClassNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
hasClassNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .ClassNode class_node = 3;
hasClassNode() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .ClassNode class_node = 3;
hasClassNodeBuilder() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'classNode' field has an active Builder instance
hasCommand() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Checks whether the 'command' field has been set.
hasCommandLines() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Checks whether the 'commandLines' field has been set.
hasConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string configuration = 2;
hasConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
required string configuration = 2;
hasConfiguration() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder
required string configuration = 2;
hasConstructor() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
hasConstructor() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Constructor constructor = 2;
hasConstructor() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Constructor constructor = 2;
hasConstructorArgs() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Checks whether the 'constructorArgs' field has been set.
hasContextConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string context_configuration = 2;
hasContextConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
required string context_configuration = 2;
hasContextConfiguration() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
required string context_configuration = 2;
hasContextControl() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
hasContextControl() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .ContextControlProto context_control = 3;
hasContextControl() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .ContextControlProto context_control = 3;
hasContextId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Checks whether the 'contextId' field has been set.
hasContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required string context_id = 1;
hasContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
required string context_id = 1;
hasContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProtoOrBuilder
required string context_id = 1;
hasContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
required string context_id = 1;
hasContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
required string context_id = 1;
hasContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProtoOrBuilder
required string context_id = 1;
hasContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string context_id = 1;
hasContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
required string context_id = 1;
hasContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProtoOrBuilder
required string context_id = 1;
hasContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required string context_id = 2;
hasContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
required string context_id = 2;
hasContextId() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
required string context_id = 2;
hasContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string context_id = 2;
hasContextId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required string context_id = 2;
hasContextId() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required string context_id = 2;
hasContextMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
hasContextMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .ContextMessageProto context_message = 2;
hasContextMessage() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .ContextMessageProto context_message = 2;
hasContextState() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required .ContextStatusProto.State context_state = 1;
hasContextState() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
required .ContextStatusProto.State context_state = 1;
hasContextState() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
required .ContextStatusProto.State context_state = 1;
hasCores() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Checks whether the 'cores' field has been set.
hasData() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
required bytes data = 1;
hasData() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
required bytes data = 1;
hasData() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBodyOrBuilder
required bytes data = 1;
hasData() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
required bytes data = 1;
hasData() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
required bytes data = 1;
hasData() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBufOrBuilder
required bytes data = 1;
hasData() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Checks whether the 'data' field has been set.
hasData() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Checks whether the 'data' field has been set.
hasData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required bytes data = 1;
hasData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
required bytes data = 1;
hasData() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBufOrBuilder
required bytes data = 1;
hasData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required bytes data = 2;
hasData() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
required bytes data = 2;
hasData() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBufOrBuilder
required bytes data = 2;
hasDateTime() - Method in class org.apache.reef.bridge.message.SystemOnStart.Builder
Checks whether the 'dateTime' field has been set.
hasDefaultImplementation() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'defaultImplementation' field has been set.
hasDefaultImplementation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
optional string default_implementation = 7;
hasDefaultImplementation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
optional string default_implementation = 7;
hasDefaultImplementation() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
optional string default_implementation = 7;
hasDefaultRuntimeName() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'defaultRuntimeName' field has been set.
hasDefaultRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Checks whether the 'defaultRuntimeName' field has been set.
hasDescription() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Checks whether the 'description' field has been set.
hasDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string destid = 3;
hasDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required string destid = 3;
hasDestid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required string destid = 3;
hasDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string destid = 3;
hasDestid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
required string destid = 3;
hasDestid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
required string destid = 3;
hasDfsJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Checks whether the 'dfsJobSubmissionFolder' field has been set.
hasDocumentation() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'documentation' field has been set.
hasDocumentation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string documentation = 5;
hasDocumentation() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string documentation = 5;
hasDocumentation() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string documentation = 5;
hasDoneEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
hasDoneEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .DoneEvaluatorProto done_evaluator = 6;
hasDoneEvaluator() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .DoneEvaluatorProto done_evaluator = 6;
hasDriverMemory() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'driverMemory' field has been set.
hasDriverRecoveryTimeout() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Checks whether the 'driverRecoveryTimeout' field has been set.
hasDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Checks whether the 'driverStderrFilePath' field has been set.
hasDriverStderrFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'driverStderrFilePath' field has been set.
hasDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Checks whether the 'driverStdoutFilePath' field has been set.
hasDriverStdoutFilePath() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'driverStdoutFilePath' field has been set.
hasEnded() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
 
hasError() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bytes error = 5;
hasError() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional bytes error = 5;
hasError() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional bytes error = 5;
hasError() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
optional bytes error = 3;
hasError() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
optional bytes error = 3;
hasError() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
optional bytes error = 3;
hasError() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
hasError() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.EvaluatorStatusPOJO
 
hasEvaluatorControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
hasEvaluatorControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .EvaluatorControlProto evaluatorControl = 5;
hasEvaluatorControl() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .EvaluatorControlProto evaluatorControl = 5;
hasEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Checks whether the 'evaluatorDescriptor' field has been set.
hasEvaluatorDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Checks whether the 'evaluatorDescriptor' field has been set.
hasEvaluatorDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Checks whether the 'evaluatorDescriptor' field has an active Builder instance
hasEvaluatorDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Checks whether the 'evaluatorDescriptor' field has an active Builder instance
hasEvaluatorException() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Checks whether the 'evaluatorException' field has been set.
hasEvaluatorHeartBeat() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
hasEvaluatorHeartBeat() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
hasEvaluatorHeartBeat() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
hasEvaluatorId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Checks whether the 'evaluatorId' field has been set.
hasEvaluatorId() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required string evaluator_id = 1;
hasEvaluatorId() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
required string evaluator_id = 1;
hasEvaluatorId() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
required string evaluator_id = 1;
hasEvaluatorId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'evaluatorId' field has been set.
hasEvaluatorLaunch() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Checks whether the 'evaluator_launch' field has been set.
hasEvaluatorLaunchBuilder() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Checks whether the 'evaluator_launch' field has an active Builder instance
hasEvaluatorRelease() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Checks whether the 'evaluator_release' field has been set.
hasEvaluatorReleaseBuilder() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Checks whether the 'evaluator_release' field has an active Builder instance
hasEvaluators() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Checks whether the 'evaluators' field has been set.
hasEvaluatorsInfo() - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo.Builder
Checks whether the 'evaluatorsInfo' field has been set.
hasEvaluatorStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
hasEvaluatorStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
required .EvaluatorStatusProto evaluator_status = 2;
hasEvaluatorStatus() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
required .EvaluatorStatusProto evaluator_status = 2;
hasEvaluatorType() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Checks whether the 'evaluatorType' field has been set.
hasException() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Checks whether the 'exception' field has been set.
hasException() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes exception = 4;
hasException() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
optional bytes exception = 4;
hasException() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
optional bytes exception = 4;
hasException() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional bytes exception = 3;
hasException() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
optional bytes exception = 3;
hasException() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
optional bytes exception = 3;
hasExceptions() - Method in class org.apache.reef.io.network.group.impl.driver.ExceptionHandler
 
hasFailedContextList() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Checks whether the 'failedContextList' field has been set.
hasFailedTask() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Checks whether the 'failedTask' field has been set.
hasFailedTaskBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Checks whether the 'failedTask' field has an active Builder instance
hasFailure() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Checks whether the 'failure' field has been set.
hasFailure() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Checks whether the 'failure' field has been set.
hasFailureBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Checks whether the 'failure' field has an active Builder instance
hasFailureBuilder() - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Checks whether the 'failure' field has an active Builder instance
hasFileSystemUrl() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Checks whether the 'fileSystemUrl' field has been set.
hasFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Checks whether the 'fullArgClassName' field has been set.
hasFullArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'fullArgClassName' field has been set.
hasFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required string full_arg_class_name = 1;
hasFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
required string full_arg_class_name = 1;
hasFullArgClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
required string full_arg_class_name = 1;
hasFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string full_arg_class_name = 2;
hasFullArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required string full_arg_class_name = 2;
hasFullArgClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required string full_arg_class_name = 2;
hasFullClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Checks whether the 'fullClassName' field has been set.
hasFullClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
required string full_class_name = 1;
hasFullClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
required string full_class_name = 1;
hasFullClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDefOrBuilder
required string full_class_name = 1;
hasFullName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'fullName' field has been set.
hasFullName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string full_name = 2;
hasFullName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
required string full_name = 2;
hasFullName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
required string full_name = 2;
hasGet() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Checks whether the 'get' field has been set.
hasGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Checks whether the 'get' field has been set.
hasGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Checks whether the 'get' field has been set.
hasGet() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Checks whether the 'get' field has been set.
hasGroupname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string groupname = 4;
hasGroupname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional string groupname = 4;
hasGroupname() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional string groupname = 4;
hashCode() - Method in class org.apache.reef.client.LauncherStatus
 
hashCode() - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
hashCode() - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition
 
hashCode() - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
hashCode() - Method in class org.apache.reef.io.network.group.impl.driver.IndexedMsg
 
hashCode() - Method in class org.apache.reef.io.network.group.impl.driver.MsgKey
 
hashCode() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
hashCode() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
hashCode() - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
hashCode() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
hashCode() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
hashCode() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
hashCode() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
hashCode() - Method in class org.apache.reef.io.network.util.StringIdentifier
Returns a hash code for the object.
hashCode() - Method in class org.apache.reef.io.Tuple
 
hashCode() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
hashCode() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
hashCode() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
hashCode() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
hashCode() - Method in class org.apache.reef.runtime.common.driver.catalog.RackDescriptorImpl
 
hashCode() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
hashCode() - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
hashCode() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
hashCode() - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
hashCode() - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
hashCode() - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
hashCode() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
hashCode() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
hashCode() - Method in class org.apache.reef.util.Optional
 
hashCode() - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
hashCode() - Method in class org.apache.reef.wake.examples.join.TupleEvent
 
hashCode() - Method in interface org.apache.reef.wake.Identifier
Returns a hash code for the object.
hashCode() - Method in class org.apache.reef.wake.remote.impl.SocketRemoteIdentifier
Returns a hash code for the object.
hashCode() - Method in class org.apache.reef.wake.remote.impl.Tuple2
 
hashCode() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
hashCode() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
hashCode() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
hashCode() - Method in class org.apache.reef.wake.time.Time
 
hasHeader() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Checks whether the 'header' field has been set.
hasHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Checks whether the 'host' field has been set.
hasHost() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Checks whether the 'host' field has been set.
hasHttpMethod() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Checks whether the 'httpMethod' field has been set.
hasHttpServerPortNumber() - Method in class org.apache.reef.bridge.message.SetupBridge.Builder
Checks whether the 'httpServerPortNumber' field has been set.
hasId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Checks whether the 'id' field has been set.
hasId() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Checks whether the 'id' field has been set.
hasIdentifier() - Method in class org.apache.reef.bridge.message.Header.Builder
Checks whether the 'identifier' field has been set.
hasIdentifier() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Checks whether the 'identifier' field has been set.
hasIdentifier() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
required string identifier = 1;
hasIdentifier() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
required string identifier = 1;
hasIdentifier() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
required string identifier = 1;
hasIdentifier() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required string identifier = 2;
hasIdentifier() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
required string identifier = 2;
hasIdentifier() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
required string identifier = 2;
hasIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required string identifier = 1;
hasIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
required string identifier = 1;
hasIdentifier() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
required string identifier = 1;
hasIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional string identifier = 5;
hasIdentifier() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
optional string identifier = 5;
hasIdentifier() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
optional string identifier = 5;
hasIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Checks whether the 'identifier' field has been set.
hasIdentifier() - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease.Builder
Checks whether the 'identifier' field has been set.
hasIds() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest.Builder
Checks whether the 'ids' field has been set.
hasImplFullNames() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'implFullNames' field has been set.
hasInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Checks whether the 'inetSocketAddress' field has been set.
hasInetSocketAddress() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Checks whether the 'inetSocketAddress' field has been set.
hasInjectableConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'injectableConstructors' field has been set.
hasInputStream() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Checks whether the 'inputStream' field has been set.
hasInstance() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
hasInstance() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Instance instance = 3;
hasInstance() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Instance instance = 3;
hasInstanceDefault() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'instanceDefault' field has been set.
hasInternetAddress() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'internetAddress' field has been set.
hasIsExternalConstructor() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'isExternalConstructor' field has been set.
hasIsExternalConstructor() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_external_constructor = 2;
hasIsExternalConstructor() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
required bool is_external_constructor = 2;
hasIsExternalConstructor() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
required bool is_external_constructor = 2;
hasIsInjectionCandidate() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'isInjectionCandidate' field has been set.
hasIsInjectionCandidate() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_injection_candidate = 1;
hasIsInjectionCandidate() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
required bool is_injection_candidate = 1;
hasIsInjectionCandidate() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
required bool is_injection_candidate = 1;
hasIsInjectionFuture() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Checks whether the 'isInjectionFuture' field has been set.
hasIsInjectionFuture() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required bool is_injection_future = 3;
hasIsInjectionFuture() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
required bool is_injection_future = 3;
hasIsInjectionFuture() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
required bool is_injection_future = 3;
hasIsList() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'isList' field has been set.
hasIsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_list = 4;
hasIsList() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required bool is_list = 4;
hasIsList() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required bool is_list = 4;
hasIsOptionSet() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Checks whether the 'isOptionSet' field has been set.
hasIsSet() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'isSet' field has been set.
hasIsSet() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_set = 3;
hasIsSet() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required bool is_set = 3;
hasIsSet() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required bool is_set = 3;
hasIsUnit() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'isUnit' field has been set.
hasIsUnit() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_unit = 3;
hasIsUnit() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
required bool is_unit = 3;
hasIsUnit() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ClassNodeOrBuilder
required bool is_unit = 3;
hasJobControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
hasJobControl() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .JobControlProto jobControl = 2;
hasJobControl() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .JobControlProto jobControl = 2;
hasJobId() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Checks whether the 'jobId' field has been set.
hasJobStatus() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
hasJobStatus() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .JobStatusProto jobStatus = 4;
hasJobStatus() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .JobStatusProto jobStatus = 4;
hasJobSubmissionDirectoryPrefix() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Checks whether the 'jobSubmissionDirectoryPrefix' field has been set.
hasJobSubmissionFolder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Checks whether the 'jobSubmissionFolder' field has been set.
hasKey() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Checks whether the 'key' field has been set.
hasKey() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Checks whether the 'key' field has been set.
hasKillEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
hasKillEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .KillEvaluatorProto kill_evaluator = 4;
hasKillEvaluator() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .KillEvaluatorProto kill_evaluator = 4;
hasLanguage() - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Checks whether the 'language' field has been set.
hasLoad() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required double load = 2;
hasLoad() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
required double load = 2;
hasLoad() - Method in interface org.apache.reef.wake.test.proto.TestProtos.TestEventPBufOrBuilder
required double load = 2;
hasLocalRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'localRuntimeAppParameters' field has been set.
hasLocalRuntimeAppParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'localRuntimeAppParameters' field has an active Builder instance
hasMaxApplicationSubmissions() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'maxApplicationSubmissions' field has been set.
hasMaxNumberOfConcurrentEvaluators() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Checks whether the 'maxNumberOfConcurrentEvaluators' field has been set.
hasMegaBytes() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Checks whether the 'megaBytes' field has been set.
hasMemory() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Checks whether the 'memory' field has been set.
hasMemory() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'memory' field has been set.
hasMessage() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Checks whether the 'message' field has been set.
hasMessage() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Checks whether the 'message' field has been set.
hasMessage() - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Checks whether the 'message' field has been set.
hasMessage() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional bytes message = 3;
hasMessage() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
optional bytes message = 3;
hasMessage() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
optional bytes message = 3;
hasMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required bytes message = 2;
hasMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
required bytes message = 2;
hasMessage() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProtoOrBuilder
required bytes message = 2;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required bytes message = 2;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
required bytes message = 2;
hasMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProtoOrBuilder
required bytes message = 2;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes message = 3;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
optional bytes message = 3;
hasMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
optional bytes message = 3;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string message = 2;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
required string message = 2;
hasMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
required string message = 2;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required bytes message = 2;
hasMessage() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
required bytes message = 2;
hasMessage() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProtoOrBuilder
required bytes message = 2;
hasMessage() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required string message = 1;
hasMessage() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
required string message = 1;
hasMessage() - Method in interface org.apache.reef.wake.test.proto.TestProtos.TestEventPBufOrBuilder
required string message = 1;
hasMessageIdentifier() - Method in class org.apache.reef.bridge.message.Acknowledgement.Builder
Checks whether the 'messageIdentifier' field has been set.
hasMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Checks whether the 'messageSourceId' field has been set.
hasMessageSourceId() - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Checks whether the 'messageSourceId' field has been set.
hasMessageType() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Checks whether the 'messageType' field has been set.
hasName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Checks whether the 'name' field has been set.
hasName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Checks whether the 'name' field has been set.
hasName() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Checks whether the 'name' field has been set.
hasName() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string name = 1;
hasName() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
required string name = 1;
hasName() - Method in interface org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProtoOrBuilder
required string name = 1;
hasName() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'name' field has been set.
hasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string name = 1;
hasName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
required string name = 1;
hasName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
required string name = 1;
hasName() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
required string name = 1;
hasName() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
required string name = 1;
hasName() - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Checks whether the 'name' field has been set.
hasNamedParameterName() - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Checks whether the 'namedParameterName' field has been set.
hasNamedParameterName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
optional string named_parameter_name = 2;
hasNamedParameterName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
optional string named_parameter_name = 2;
hasNamedParameterName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArgOrBuilder
optional string named_parameter_name = 2;
hasNamedParameterNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'namedParameterNode' field has been set.
hasNamedParameterNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
hasNamedParameterNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .NamedParameterNode named_parameter_node = 4;
hasNamedParameterNode() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .NamedParameterNode named_parameter_node = 4;
hasNamedParameterNodeBuilder() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'namedParameterNode' field has an active Builder instance
hasNext() - Method in class org.apache.reef.io.storage.MergingIterator
 
hasNext() - Method in class org.apache.reef.vortex.api.AggregateResultSynchronous
 
hasNodeDescriptor() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Checks whether the 'nodeDescriptor' field has been set.
hasNodeDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Checks whether the 'nodeDescriptor' field has an active Builder instance
hasNodeId() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'nodeId' field has been set.
hasNodeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'nodeName' field has been set.
hasNodeNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Checks whether the 'nodeNames' field has been set.
hasNodes() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Checks whether the 'nodes' field has been set.
hasNotRestarted() - Method in enum org.apache.reef.driver.restart.DriverRestartState
hasNumber() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Checks whether the 'number' field has been set.
hasNumberOfCores() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Checks whether the 'numberOfCores' field has been set.
hasOffset() - Method in class org.apache.reef.bridge.message.Protocol.Builder
Checks whether the 'offset' field has been set.
hasOperatorname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string operatorname = 5;
hasOperatorname() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional string operatorname = 5;
hasOperatorname() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional string operatorname = 5;
hasOtherConstructors() - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Checks whether the 'otherConstructors' field has been set.
hasPackageNode() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'packageNode' field has been set.
hasPackageNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
hasPackageNode() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
optional .PackageNode package_node = 5;
hasPackageNode() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NodeOrBuilder
optional .PackageNode package_node = 5;
hasPackageNodeBuilder() - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Checks whether the 'packageNode' field has an active Builder instance
hasParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Checks whether the 'parentContext' field has been set.
hasParentContext() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Checks whether the 'parentContext' field has been set.
hasParentContextBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Checks whether the 'parentContext' field has an active Builder instance
hasParentContextBuilder() - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Checks whether the 'parentContext' field has an active Builder instance
hasParentContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string parent_context_id = 1;
hasParentContextId() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
required string parent_context_id = 1;
hasParentContextId() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
required string parent_context_id = 1;
hasParentId() - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Checks whether the 'parentId' field has been set.
hasParentId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional string parent_id = 3;
hasParentId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional string parent_id = 3;
hasParentId() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional string parent_id = 3;
hasParentId() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.ContextStatusPOJO
 
hasPathInfo() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Checks whether the 'pathInfo' field has been set.
hasPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Checks whether the 'port' field has been set.
hasPort() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Checks whether the 'port' field has been set.
hasProcess() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Checks whether the 'process' field has been set.
hasProcessBuilder() - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Checks whether the 'process' field has an active Builder instance
hasQueryString() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Checks whether the 'queryString' field has been set.
hasRackDescriptor() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Checks whether the 'rackDescriptor' field has been set.
hasRackDescriptorBuilder() - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Checks whether the 'rackDescriptor' field has an active Builder instance
hasRackNames() - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Checks whether the 'rackNames' field has been set.
hasReason() - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Checks whether the 'reason' field has been set.
hasRecovery() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional bool recovery = 5;
hasRecovery() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
optional bool recovery = 5;
hasRecovery() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
optional bool recovery = 5;
hasRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bool recovery = 6;
hasRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
optional bool recovery = 6;
hasRecovery() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProtoOrBuilder
optional bool recovery = 6;
hasRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bool recovery = 5;
hasRecovery() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
optional bool recovery = 5;
hasRecovery() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
optional bool recovery = 5;
hasRemoteId() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Checks whether the 'remoteId' field has been set.
hasRemoveContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
hasRemoveContext() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .RemoveContextProto remove_context = 6;
hasRemoveContext() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .RemoveContextProto remove_context = 6;
hasReported() - Method in enum org.apache.reef.driver.restart.EvaluatorRestartState
 
hasRequestUrl() - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Checks whether the 'requestUrl' field has been set.
hasRestarted() - Method in enum org.apache.reef.driver.restart.DriverRestartState
 
hasResult() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bytes result = 4;
hasResult() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
optional bytes result = 4;
hasResult() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
optional bytes result = 4;
hasResult() - Method in class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
hasRuntimeError() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
hasRuntimeError() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
optional .RuntimeErrorProto runtimeError = 3;
hasRuntimeError() - Method in interface org.apache.reef.proto.REEFProtocol.REEFMessageOrBuilder
optional .RuntimeErrorProto runtimeError = 3;
hasRuntimeName() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Checks whether the 'runtimeName' field has been set.
hasRuntimeName() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'runtimeName' field has been set.
hasRuntimeNames() - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes.Builder
Checks whether the 'runtimeNames' field has been set.
hasRuntimes() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'runtimes' field has been set.
hasRuntimes() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Checks whether the 'runtimes' field has been set.
hasSecurityTokenKind() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'securityTokenKind' field has been set.
hasSecurityTokenService() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'securityTokenService' field has been set.
hasSelectedPlan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
optional sint32 selected_plan = 1;
hasSelectedPlan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
optional sint32 selected_plan = 1;
hasSelectedPlan() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.SubplanOrBuilder
optional sint32 selected_plan = 1;
hasSeq() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required int64 seq = 2;
hasSeq() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
required int64 seq = 2;
hasSeq() - Method in interface org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBufOrBuilder
required int64 seq = 2;
hasSequence() - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Checks whether the 'sequence' field has been set.
hasSerializedConfiguration() - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Checks whether the 'serializedConfiguration' field has been set.
hasServiceConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
optional string service_configuration = 3;
hasServiceConfiguration() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
optional string service_configuration = 3;
hasServiceConfiguration() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProtoOrBuilder
optional string service_configuration = 3;
hasServiceInfo() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Checks whether the 'serviceInfo' field has been set.
hasServiceName() - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Checks whether the 'serviceName' field has been set.
hasServices() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Checks whether the 'services' field has been set.
hasSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Checks whether the 'sharedAppSubmissionParameters' field has been set.
hasSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'sharedAppSubmissionParameters' field has been set.
hasSharedAppSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Checks whether the 'sharedAppSubmissionParameters' field has been set.
hasSharedAppSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Checks whether the 'sharedAppSubmissionParameters' field has an active Builder instance
hasSharedAppSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'sharedAppSubmissionParameters' field has an active Builder instance
hasSharedAppSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Checks whether the 'sharedAppSubmissionParameters' field has an active Builder instance
hasSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Checks whether the 'sharedJobSubmissionParameters' field has been set.
hasSharedJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Checks whether the 'sharedJobSubmissionParameters' field has been set.
hasSharedJobSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Checks whether the 'sharedJobSubmissionParameters' field has an active Builder instance
hasSharedJobSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Checks whether the 'sharedJobSubmissionParameters' field has an active Builder instance
hasShortName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'shortName' field has been set.
hasShortName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string short_name = 6;
hasShortName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
optional string short_name = 6;
hasShortName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
optional string short_name = 6;
hasSignal() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional .Signal signal = 2;
hasSignal() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
optional .Signal signal = 2;
hasSignal() - Method in interface org.apache.reef.proto.ClientRuntimeProtocol.JobControlProtoOrBuilder
optional .Signal signal = 2;
hasSimpleArgClassName() - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Checks whether the 'simpleArgClassName' field has been set.
hasSimpleArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string simple_arg_class_name = 1;
hasSimpleArgClassName() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
required string simple_arg_class_name = 1;
hasSimpleArgClassName() - Method in interface org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNodeOrBuilder
required string simple_arg_class_name = 1;
hasSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required string source_id = 1;
hasSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
required string source_id = 1;
hasSourceId() - Method in interface org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProtoOrBuilder
required string source_id = 1;
hasSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required string source_id = 1;
hasSourceId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
required string source_id = 1;
hasSourceId() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProtoOrBuilder
required string source_id = 1;
hasSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string srcid = 2;
hasSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required string srcid = 2;
hasSrcid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required string srcid = 2;
hasSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string srcid = 2;
hasSrcid() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
required string srcid = 2;
hasSrcid() - Method in interface org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBufOrBuilder
required string srcid = 2;
hasSrcVersion() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
hasSrcVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 srcVersion = 7;
hasSrcVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional int32 srcVersion = 7;
hasSrcVersion() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional int32 srcVersion = 7;
hasStartTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
hasStartTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .StartTaskProto start_task = 7;
hasStartTask() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .StartTaskProto start_task = 7;
hasStartTime() - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Checks whether the 'startTime' field has been set.
hasStartTime() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Checks whether the 'startTime' field has been set.
hasState() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required .State state = 2;
hasState() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
required .State state = 2;
hasState() - Method in interface org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProtoOrBuilder
required .State state = 2;
hasState() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required .State state = 2;
hasState() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
required .State state = 2;
hasState() - Method in interface org.apache.reef.proto.ReefServiceProtos.JobStatusProtoOrBuilder
required .State state = 2;
hasState() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required .State state = 3;
hasState() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required .State state = 3;
hasState() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required .State state = 3;
hasStopEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
hasStopEvaluator() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
optional .StopEvaluatorProto stop_evaluator = 5;
hasStopEvaluator() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
optional .StopEvaluatorProto stop_evaluator = 5;
hasStopTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
hasStopTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .StopTaskProto stop_task = 8;
hasStopTask() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .StopTaskProto stop_task = 8;
hasSubplan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
hasSubplan() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
optional .Subplan subplan = 4;
hasSubplan() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlanOrBuilder
optional .Subplan subplan = 4;
hasSuspendTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
hasSuspendTask() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional .SuspendTaskProto suspend_task = 9;
hasSuspendTask() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional .SuspendTaskProto suspend_task = 9;
hasTaskId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string task_id = 1;
hasTaskId() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
required string task_id = 1;
hasTaskId() - Method in interface org.apache.reef.proto.ReefServiceProtos.TaskStatusProtoOrBuilder
required string task_id = 1;
hasTaskMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional bytes task_message = 1;
hasTaskMessage() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
optional bytes task_message = 1;
hasTaskMessage() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProtoOrBuilder
optional bytes task_message = 1;
hasTaskStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
hasTaskStatus() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
optional .TaskStatusProto task_status = 4;
hasTaskStatus() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
optional .TaskStatusProto task_status = 4;
hasTcpBeginPort() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Checks whether the 'tcpBeginPort' field has been set.
hasTcpRangeCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Checks whether the 'tcpRangeCount' field has been set.
hasTcpTryCount() - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Checks whether the 'tcpTryCount' field has been set.
hasTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime.Builder
Checks whether the 'timestamp' field has been set.
hasTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime.Builder
Checks whether the 'timestamp' field has been set.
hasTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart.Builder
Checks whether the 'timestamp' field has been set.
hasTimestamp() - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Checks whether the 'timestamp' field has been set.
hasTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required int64 timestamp = 1;
hasTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
required int64 timestamp = 1;
hasTimestamp() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProtoOrBuilder
required int64 timestamp = 1;
hasTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required int64 timestamp = 1;
hasTimestamp() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
required int64 timestamp = 1;
hasTimestamp() - Method in interface org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProtoOrBuilder
required int64 timestamp = 1;
hasTotal() - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Checks whether the 'total' field has been set.
hasTuples() - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse.Builder
Checks whether the 'tuples' field has been set.
hasType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required .GroupCommMessage.Type type = 1;
hasType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
required .GroupCommMessage.Type type = 1;
hasType() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
required .GroupCommMessage.Type type = 1;
hasType() - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Checks whether the 'type' field has been set.
hasValue() - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Checks whether the 'value' field has been set.
hasValue() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
required string value = 1;
hasValue() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
required string value = 1;
hasValue() - Method in interface org.apache.reef.tang.proto.InjectionPlanProto.InstanceOrBuilder
required string value = 1;
hasValue() - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Checks whether the 'value' field has been set.
hasVersion() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
hasVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 version = 6;
hasVersion() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
optional int32 version = 6;
hasVersion() - Method in interface org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder
optional int32 version = 6;
hasYarnJobSubmissionParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'yarnJobSubmissionParameters' field has been set.
hasYarnJobSubmissionParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Checks whether the 'yarnJobSubmissionParameters' field has an active Builder instance
hasYarnRuntimeAppParameters() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'yarnRuntimeAppParameters' field has been set.
hasYarnRuntimeAppParametersBuilder() - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Checks whether the 'yarnRuntimeAppParameters' field has an active Builder instance
HDFSConfigurationConstructor - Class in org.apache.reef.runtime.mesos.util
Configuration wrapper which allows it to be injected.
HDICLI - Class in org.apache.reef.runtime.hdinsight.cli
Main class for the HDInsight REST commandline.
HDINSIGHT_CONFIGURATION_FILE_ENVIRONMENT_VARIABLE - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The environment variable that holds the path to the default configuration file.
HDInsightClasspathProvider - Class in org.apache.reef.runtime.hdinsight
Access to the classpath according to the REEF file system standard.
HDInsightDriverConfiguration - Class in org.apache.reef.runtime.hdinsight.client
ConfigurationModule to create a Driver configuration.
HDInsightDriverConfiguration() - Constructor for class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
HDInsightInstance - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents an HDInsight instance.
HDInsightInstanceURL - Class in org.apache.reef.runtime.hdinsight.parameters
The password to be used for connecting to hdinsight.
HDInsightInstanceURL() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.HDInsightInstanceURL
 
HDInsightJobSubmissionHandler - Class in org.apache.reef.runtime.hdinsight.client
Handles job submission to a HDInsight instance.
HDInsightJVMPathProvider - Class in org.apache.reef.runtime.hdinsight
Supplies the java binary's path for HDInsight.
HDInsightJVMPathProvider() - Constructor for class org.apache.reef.runtime.hdinsight.HDInsightJVMPathProvider
 
HDInsightPassword - Class in org.apache.reef.runtime.hdinsight.parameters
The password to be used for connecting to hdinsight.
HDInsightPassword() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.HDInsightPassword
 
HDInsightRuntimeConfiguration - Class in org.apache.reef.runtime.hdinsight.client
Configuration module to setup REEF to submit jobs to HDInsight.
HDInsightRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
 
HDInsightRuntimeConfigurationStatic - Class in org.apache.reef.runtime.hdinsight.client
The static part of the HDInsightRuntimeConfiguration.
HDInsightRuntimeConfigurationStatic() - Constructor for class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfigurationStatic
 
HDInsightUsername - Class in org.apache.reef.runtime.hdinsight.parameters
The username to be used for connecting to hdinsight.
HDInsightUsername() - Constructor for class org.apache.reef.runtime.hdinsight.parameters.HDInsightUsername
 
Header - Class in org.apache.reef.bridge.message
 
Header() - Constructor for class org.apache.reef.bridge.message.Header
Default constructor.
Header(Long, CharSequence) - Constructor for class org.apache.reef.bridge.message.Header
All-args constructor.
header - Variable in class org.apache.reef.webserver.AvroHttpRequest
Deprecated.
Header.Builder - Class in org.apache.reef.bridge.message
RecordBuilder for Header instances.
HeaderEntry - Class in org.apache.reef.webserver
 
HeaderEntry() - Constructor for class org.apache.reef.webserver.HeaderEntry
Default constructor.
HeaderEntry(CharSequence, CharSequence) - Constructor for class org.apache.reef.webserver.HeaderEntry
All-args constructor.
HeaderEntry.Builder - Class in org.apache.reef.webserver
RecordBuilder for HeaderEntry instances.
HEARTBEAT_PERIOD - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
HeartBeatManager - Class in org.apache.reef.runtime.common.evaluator
Heartbeat manager.
HeartbeatPeriod - Class in org.apache.reef.runtime.common.evaluator.parameters
The evaluator heartbeat period in ms.
HeartBeatTriggerManager - Class in org.apache.reef.task
Helper class for immediately sending heartbeat messages.
HelloCLR - Class in org.apache.reef.examples.helloCLR
The Client for Hello REEF example.
HelloDriver - Class in org.apache.reef.examples.hello
The Driver code for the Hello REEF Application.
HelloDriver - Class in org.apache.reef.examples.helloCLR
The Driver code for the Hello REEF Application.
HelloDriver(EvaluatorRequestor, CLRProcessFactory) - Constructor for class org.apache.reef.examples.helloCLR.HelloDriver
Job driver constructor - instantiated via TANG.
HelloDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.examples.hello
Handles AllocatedEvaluator: Submit the HelloTask.
HelloDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.examples.hello.HelloDriver.EvaluatorAllocatedHandler
 
HelloDriver.StartHandler - Class in org.apache.reef.examples.hello
Handles the StartTime event: Request as single Evaluator.
HelloDriver.StartHandler() - Constructor for class org.apache.reef.examples.hello.HelloDriver.StartHandler
 
HelloDriverRestart - Class in org.apache.reef.examples.hello
The Restart code for the Hello REEF Application.
HelloDriverRestart.DriverRestartHandler - Class in org.apache.reef.examples.hello
Handles Restarts.
HelloDriverRestart.DriverRestartHandler() - Constructor for class org.apache.reef.examples.hello.HelloDriverRestart.DriverRestartHandler
 
HelloHDInsight - Class in org.apache.reef.examples.hello
HelloREEF running on HDInsight.
HelloJVMOptionsDriver - Class in org.apache.reef.examples.hello
The Driver code for the Hello JVM Options Application.
HelloJVMOptionsDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.examples.hello
Handles AllocatedEvaluator: Submit the HelloTask with additional JVM Options.
HelloJVMOptionsDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.examples.hello.HelloJVMOptionsDriver.EvaluatorAllocatedHandler
 
HelloJVMOptionsDriver.StartHandler - Class in org.apache.reef.examples.hello
Handles the StartTime event: Request as single Evaluator.
HelloJVMOptionsDriver.StartHandler() - Constructor for class org.apache.reef.examples.hello.HelloJVMOptionsDriver.StartHandler
 
HelloJVMOptionsREEF - Class in org.apache.reef.examples.hello
The Client for Hello JVM Options example.
HelloMultiRuntimeDriver - Class in org.apache.reef.examples.hellomultiruntime
The Driver code for the Hello REEF Application with Multi Runtime.
HelloMultiRuntimeDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.examples.hellomultiruntime
Handles AllocatedEvaluator: Submit the HelloTask.
HelloMultiRuntimeDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.examples.hellomultiruntime.HelloMultiRuntimeDriver.EvaluatorAllocatedHandler
 
HelloMultiRuntimeDriver.StartHandler - Class in org.apache.reef.examples.hellomultiruntime
Handles the StartTime event: Request as single Evaluator.
HelloMultiRuntimeDriver.StartHandler() - Constructor for class org.apache.reef.examples.hellomultiruntime.HelloMultiRuntimeDriver.StartHandler
 
HelloREEF - Class in org.apache.reef.examples.hello
The Client for Hello REEF example.
HelloREEFEnvironment - Class in org.apache.reef.examples.hello
The Client for Hello REEF example running driver and client in the same process.
HelloREEFHttp - Class in org.apache.reef.examples.hellohttp
Distributed shell example based on REEF HTTP Server component.
HelloREEFHttpYarn - Class in org.apache.reef.examples.hellohttp
HelloREEFHttp for running on Yarn.
HelloREEFMesos - Class in org.apache.reef.examples.hello
The Client for running HelloREEF on Mesos.
HelloREEFMultiYarn - Class in org.apache.reef.examples.hellomultiruntime
The Client for running HelloREEFMulti on YARN.
HelloREEFNoClient - Class in org.apache.reef.examples.hello
A main() for running hello REEF without a persistent client connection.
HelloREEFStandalone - Class in org.apache.reef.examples.hello
The Client for Hello REEF example on standalone environment.
HelloREEFYarn - Class in org.apache.reef.examples.hello
The Client for running HelloREEF on YARN.
HelloREEFYarnRestart - Class in org.apache.reef.examples.hello
The Client for running HelloREEF with DriverRestartHandler on YARN.
HelloReefYarnTcp - Class in org.apache.reef.examples.hello
The Client for running HelloREEF with tcp port configuration on YARN.
HelloREEFYarnUnmanagedAM - Class in org.apache.reef.examples.hello
The Client for running HelloREEF on YARN in unmanaged AM mode.
HelloTask - Class in org.apache.reef.examples.hello
A 'hello REEF' Task.
Histogram - Interface in org.apache.reef.wake.metrics
Histogram.
host - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Deprecated.
host - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Deprecated.
HostnameBasedLocalAddressProvider - Class in org.apache.reef.wake.remote.address
A LocalAddressProvider that uses Inet4Address.getLocalHost().getHostAddress().
HOURS - Static variable in class org.apache.reef.examples.group.utils.timer.Timer
 
HTTP_HANDLERS - Static variable in class org.apache.reef.webserver.HttpHandlerConfiguration
Specify optional parameter for HttpEventHandlers.
HTTP_REQUEST - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
HTTP_SERVER - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
HTTP_SERVER_CONFIGURATION - Static variable in class org.apache.reef.bridge.client.Constants
The HTTP Server configuration assumed by the bridge.
HttpEventHandlers - Class in org.apache.reef.webserver
HttpEventHandlers.
HttpEventHandlers() - Constructor for class org.apache.reef.webserver.HttpEventHandlers
 
HttpHandler - Interface in org.apache.reef.webserver
HttpHandler interface.
HttpHandlerConfiguration - Class in org.apache.reef.webserver
Configuration Module Builder for Http Handler.
HttpHandlerConfiguration() - Constructor for class org.apache.reef.webserver.HttpHandlerConfiguration
 
httpMethod - Variable in class org.apache.reef.webserver.AvroHttpRequest
Deprecated.
httpRequest(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in handling a http request.
HttpRuntimeConfiguration - Class in org.apache.reef.webserver
Configuration Module Builder for HttpRuntime.
HttpRuntimeConfiguration() - Constructor for class org.apache.reef.webserver.HttpRuntimeConfiguration
 
httpServer() - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time used to create HttpServer.
HttpServer - Interface in org.apache.reef.webserver
HttpServer interface.
HttpServerEventBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for http server events.
HttpServerEventBridge(String) - Constructor for class org.apache.reef.javabridge.HttpServerEventBridge
 
HttpServerEventBridge(byte[]) - Constructor for class org.apache.reef.javabridge.HttpServerEventBridge
 
HttpServerImpl - Class in org.apache.reef.webserver
HttpServer.
httpServerPortNumber - Variable in class org.apache.reef.bridge.message.SetupBridge
Deprecated.
HttpServerReefEventHandler - Class in org.apache.reef.webserver
Http handler for REEF events.
HttpServerReefEventHandler(ReefEventStateManager, Set<EventHandler<Void>>, String, LoggingScopeFactory, REEFFileNames, InjectionFuture<ProgressProvider>) - Constructor for class org.apache.reef.webserver.HttpServerReefEventHandler
 
HttpShellJobDriver - Class in org.apache.reef.examples.hellohttp
The Driver code for the Hello REEF Http Distributed Shell Application.
HttpShellJobDriver(EvaluatorRequestor, HttpServerShellCmdHandler.ClientCallBackHandler) - Constructor for class org.apache.reef.examples.hellohttp.HttpShellJobDriver
Job Driver Constructor.
HttpTrackingURLProvider - Class in org.apache.reef.runtime.yarn.driver
Http TrackingURLProvider.
HttpTrackingURLProvider(HttpServer) - Constructor for class org.apache.reef.runtime.yarn.driver.HttpTrackingURLProvider
Constructor of HttpTrackingURLProvider.

I

id - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Deprecated.
id - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Deprecated.
id - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Deprecated.
id - Variable in class org.apache.reef.io.watcher.common.AvroFailure
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Deprecated.
id - Variable in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Deprecated.
ID - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
id - Variable in class org.apache.reef.webserver.AvroEvaluatorEntry
Deprecated.
Idempotent - Annotation Type in org.apache.reef.annotations.semantics
Methods annotated with this are idempotent: Calling them multiple times has the same effect as calling them once.
Identifiable - Interface in org.apache.reef.io.naming
This interface imposes that each object of the class that implements it has an identifier.
Identifiable - Interface in org.apache.reef.wake
This interface imposes that each object of the class that implements it has an identifier.
identifier - Variable in class org.apache.reef.bridge.message.Header
Deprecated.
IDENTIFIER - Static variable in class org.apache.reef.driver.context.ContextConfiguration
The identifier of the Context.
IDENTIFIER - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Identifier for the task.
identifier - Variable in class org.apache.reef.javabridge.avro.AvroFailedTask
Deprecated.
identifier - Variable in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Deprecated.
identifier - Variable in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Deprecated.
Identifier - Interface in org.apache.reef.wake
An identifier class for REEF.
IDENTIFIER_FACTORY - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
Identifier factory for NameClient.
IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
IdentifierFactory - Interface in org.apache.reef.wake
The factory interface for Wake.
IdentityFunction - Class in org.apache.reef.vortex.examples.sumones
Identity function.
IdentityFunction() - Constructor for class org.apache.reef.vortex.examples.sumones.IdentityFunction
 
IdleClock - Class in org.apache.reef.wake.time.runtime.event
An event when there is no scheduled event.
IdleClock(long) - Constructor for class org.apache.reef.wake.time.runtime.event.IdleClock
 
IdleMessage - Class in org.apache.reef.runtime.common.driver.idle
A message to be used to indicate that the driver is potentially idle.
IdleMessage(String, String, boolean) - Constructor for class org.apache.reef.runtime.common.driver.idle.IdleMessage
 
IDMaker - Class in org.apache.reef.runtime.local.driver
Generates unique IDs.
IDMaker(String) - Constructor for class org.apache.reef.runtime.local.driver.IDMaker
The ids generated by getNextID are of the form "prefixNUMBER", where number is counted up.
ids - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Deprecated.
ImmutableVector - Interface in org.apache.reef.examples.group.utils.math
Represents an immutable vector.
Impl<T> - Interface in org.apache.reef.tang.formats
 
IMPL_FULL_NAMES_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
implFullNames - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
IMPORT - Static variable in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
increment() - Method in class org.apache.reef.io.network.group.impl.utils.CountingSemaphore
 
increment() - Method in class org.apache.reef.tests.statepassing.Counter
 
IndependentIterationsThreadPoolStage<T> - Class in org.apache.reef.wake.impl
This stage uses a thread pool to schedule events in parallel.
IndependentIterationsThreadPoolStage(EventHandler<T>, int, int) - Constructor for class org.apache.reef.wake.impl.IndependentIterationsThreadPoolStage
Create a thread pool with fixed threads.
IndexedMsg - Class in org.apache.reef.io.network.group.impl.driver
Helper class to wrap msg and the operator name in the msg.
IndexedMsg(GroupCommunicationMessage) - Constructor for class org.apache.reef.io.network.group.impl.driver.IndexedMsg
 
inetSocketAddress - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Deprecated.
inetSocketAddress - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Deprecated.
INFINITE - Static variable in class org.apache.reef.driver.parameters.DriverRestartEvaluatorRecoverySeconds
The driver waits forever until all expected evaluators report back or fail.
informAboutEvaluatorFailures(Set<String>) - Method in interface org.apache.reef.driver.restart.DriverRuntimeRestartManager
Informs the necessary components about failed evaluators.
informAboutEvaluatorFailures(Set<String>) - Method in class org.apache.reef.runtime.yarn.driver.YarnDriverRuntimeRestartManager
Calls the appropriate handler via REEFEventHandlers, which is a runtime specific implementation of the YARN runtime.
INIT - Static variable in class org.apache.reef.client.LauncherStatus
 
INIT - Static variable in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
INIT_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.State
INIT = 0;
initialize() - Method in class org.apache.reef.io.network.group.api.operators.AbstractGroupCommOperator
 
initialize() - Method in interface org.apache.reef.io.network.group.api.operators.GroupCommOperator
 
initialize() - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupServiceClient
Should not be used by user code.
initialize() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
initialize() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
initialize() - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
initialize() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
initialize() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
This method needs to be called before a Task can be run().
InitialTaskConfiguration - Class in org.apache.reef.runtime.common.evaluator.parameters
An initial task to launch on startup.
inject(ConstructorDef<T>, Constructor<T>, Object[]) - Method in interface org.apache.reef.tang.Aspect
Inject an object of type T.
inject(ConstructorDef<T>, Constructor<T>, Object[]) - Method in class org.apache.reef.wake.profiler.WakeProfiler
 
injectableConstructors - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
INJECTABLECONSTRUCTORS_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
InjectionException - Exception in org.apache.reef.tang.exceptions
Thrown when an injection fails.
InjectionException(String, Throwable) - Constructor for exception org.apache.reef.tang.exceptions.InjectionException
 
InjectionException(String) - Constructor for exception org.apache.reef.tang.exceptions.InjectionException
 
InjectionFuture<T> - Class in org.apache.reef.tang
A future-based mechanism for cyclic object injections.
InjectionFuture() - Constructor for class org.apache.reef.tang.InjectionFuture
 
InjectionFuture(Injector, Class<? extends T>) - Constructor for class org.apache.reef.tang.InjectionFuture
 
InjectionFuture(T) - Constructor for class org.apache.reef.tang.InjectionFuture
 
injectionFutureInstantiated(InjectionFuture<T>, T) - Method in interface org.apache.reef.tang.Aspect
TANG calls this the first time get() is called on an injection future.
injectionFutureInstantiated(InjectionFuture<T>, T) - Method in class org.apache.reef.wake.profiler.WakeProfiler
 
InjectionFuturePlan<T> - Class in org.apache.reef.tang.implementation
 
InjectionFuturePlan(Node) - Constructor for class org.apache.reef.tang.implementation.InjectionFuturePlan
 
InjectionPlan<T> - Class in org.apache.reef.tang.implementation
 
InjectionPlan(Node) - Constructor for class org.apache.reef.tang.implementation.InjectionPlan
 
InjectionPlanProto - Class in org.apache.reef.tang.proto
 
InjectionPlanProto.Constructor - Class in org.apache.reef.tang.proto
Protobuf type Constructor
InjectionPlanProto.Constructor.Builder - Class in org.apache.reef.tang.proto
Protobuf type Constructor
InjectionPlanProto.ConstructorOrBuilder - Interface in org.apache.reef.tang.proto
 
InjectionPlanProto.InjectionPlan - Class in org.apache.reef.tang.proto
Protobuf type InjectionPlan
InjectionPlanProto.InjectionPlan.Builder - Class in org.apache.reef.tang.proto
Protobuf type InjectionPlan
InjectionPlanProto.InjectionPlanOrBuilder - Interface in org.apache.reef.tang.proto
 
InjectionPlanProto.Instance - Class in org.apache.reef.tang.proto
Protobuf type Instance
InjectionPlanProto.Instance.Builder - Class in org.apache.reef.tang.proto
Protobuf type Instance
InjectionPlanProto.InstanceOrBuilder - Interface in org.apache.reef.tang.proto
 
InjectionPlanProto.Subplan - Class in org.apache.reef.tang.proto
Protobuf type Subplan
InjectionPlanProto.Subplan.Builder - Class in org.apache.reef.tang.proto
Protobuf type Subplan
InjectionPlanProto.SubplanOrBuilder - Interface in org.apache.reef.tang.proto
 
Injector - Interface in org.apache.reef.tang
 
InjectorImpl - Class in org.apache.reef.tang.implementation.java
 
InjectorImpl(Configuration) - Constructor for class org.apache.reef.tang.implementation.java.InjectorImpl
 
InMemoryInputFormatDataSet<K extends org.apache.hadoop.io.WritableComparable<K>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.reef.io.data.loading.impl
 
InMemoryInputFormatDataSet(InputFormatDataSet<K, V>) - Constructor for class org.apache.reef.io.data.loading.impl.InMemoryInputFormatDataSet
 
InputDir - Class in org.apache.reef.examples.group.bgd.parameters
The input folder of the learner.
InputDir() - Constructor for class org.apache.reef.examples.group.bgd.parameters.InputDir
 
InputFormatDataSet<K extends org.apache.hadoop.io.WritableComparable<K>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.reef.io.data.loading.impl
An implementation of DataSet that reads records using a RecordReader encoded inside an InputSplit.
InputFormatDataSet(InputSplit, JobConf) - Constructor for class org.apache.reef.io.data.loading.impl.InputFormatDataSet
 
InputFormatExternalConstructor - Class in org.apache.reef.io.data.loading.impl
A Tang External Constructor to inject the required.
InputFormatExternalConstructor(JobConf) - Constructor for class org.apache.reef.io.data.loading.impl.InputFormatExternalConstructor
 
InputFormatLoadingService<K,V> - Class in org.apache.reef.io.data.loading.impl
An implementation of DataLoadingService that uses the Hadoop InputFormat to find partitions of data and request resources.
InputFormatLoadingService(EvaluatorToPartitionStrategy<InputSplit>, boolean, String) - Constructor for class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
 
InputSplitExternalConstructor - Class in org.apache.reef.io.data.loading.impl
A Tang external constructor to inject an InputSplit.
InputSplitExternalConstructor(JobConf, String) - Constructor for class org.apache.reef.io.data.loading.impl.InputSplitExternalConstructor
 
InputSplitExternalConstructor.SerializedInputSplit - Class in org.apache.reef.io.data.loading.impl
 
InputSplitExternalConstructor.SerializedInputSplit() - Constructor for class org.apache.reef.io.data.loading.impl.InputSplitExternalConstructor.SerializedInputSplit
 
inputStream - Variable in class org.apache.reef.webserver.AvroHttpRequest
Deprecated.
instance() - Static method in class org.apache.reef.wake.impl.StageManager
 
INSTANCE_DEFAULT_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
INSTANCE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
instanceDefault - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
INT_SIZE - Static variable in class org.apache.reef.wake.remote.transport.netty.ChunkedReadWriteHandler
 
INT_SIZE - Static variable in class org.apache.reef.wake.remote.transport.netty.NettyLink
 
IntegerCodec - Class in org.apache.reef.io.storage.util
 
IntegerCodec() - Constructor for class org.apache.reef.io.storage.util.IntegerCodec
 
IntegerDeserializer - Class in org.apache.reef.io.storage.util
 
IntegerDeserializer() - Constructor for class org.apache.reef.io.storage.util.IntegerDeserializer
 
IntegerSerializer - Class in org.apache.reef.io.storage.util
 
IntegerSerializer() - Constructor for class org.apache.reef.io.storage.util.IntegerSerializer
 
internalGetValueMap() - Static method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
internalGetValueMap() - Static method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
internalGetValueMap() - Static method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
internalGetValueMap() - Static method in enum org.apache.reef.proto.ReefServiceProtos.State
 
internetAddress - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
Interop - Annotation Type in org.apache.reef.annotations.audience
Indicates that a class, function, or instance variable is used at the Interop layer, and should not be modified or removed without testing, knowing its consequences, and making corresponding changes in C# and C++ code.
InteropLogger - Class in org.apache.reef.javabridge
Logger called from CLR code.
InteropLogger() - Constructor for class org.apache.reef.javabridge.InteropLogger
 
INTERVAL - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
invalidate(Identifier) - Method in class org.apache.reef.io.network.naming.NameCache
Invalidates the entry for an identifier.
invalidate(K) - Method in interface org.apache.reef.util.cache.Cache
Invalidates a key from the cache.
invalidate(K) - Method in class org.apache.reef.util.cache.CacheImpl
 
IS_EXTERNAL_CONSTRUCTOR_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
IS_INJECTION_CANDIDATE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
IS_INJECTION_FUTURE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
IS_LIST_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
IS_LOCAL - Static variable in class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration
Use local file system if true; otherwise, use HDFS.
IS_SET_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
IS_UNIT_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
isActive(String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
 
isActive(String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.Constructor
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.InjectionFuturePlan
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.ListInjectionPlan
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.SetInjectionPlan
 
isAmbiguous() - Method in class org.apache.reef.tang.implementation.Subplan
Even if there is only one sub-plan, it was registered as a default plan, and is therefore ambiguous.
isAtOrAfterVersion(String) - Static method in class org.apache.reef.runtime.yarn.util.YarnTypes
 
isAvailable() - Method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Check if container is available - that is, in one of the states INIT, RUNNING, or SUSPEND.
isCancelled() - Method in class org.apache.reef.tang.InjectionFuture
 
isCancelled() - Method in class org.apache.reef.vortex.api.VortexFuture
 
isClosable() - Method in class org.apache.reef.runtime.common.driver.task.TaskRepresenter
 
isClosed() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Return true if the state is DONE, FAILED, or KILLED, and there are no messages queued or in processing.
isClosed() - Method in class org.apache.reef.runtime.common.utils.DispatchingEStage
Check if the stage can still accept messages.
isClosed() - Method in class org.apache.reef.wake.AbstractEStage
Check if the stage can still accept messages.
isClosed() - Method in interface org.apache.reef.wake.time.Clock
Clock is closed after a call to stop() or close().
isClosed() - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
The clock is closed after a call to stop() or close().
isClosedOrClosing() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Return true if the state is DONE, FAILED, KILLED, or CLOSING.
isClosing() - Method in enum org.apache.reef.runtime.common.driver.DriverStatus
Check if the driver is in process of shutting down (either gracefully or due to an error).
isClosing() - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Check if the driver is in process of shutting down (either gracefully or due to an error).
isClosing() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Return true if the state is CLOSING.
isCoercable(Class<?>, Class<?>) - Static method in class org.apache.reef.tang.util.ReflectionUtilities
Check to see if one class can be coerced into another.
isCompleted() - Method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Check if the container is stopped.
isComputeContext(ActiveContext) - Method in interface org.apache.reef.io.data.loading.api.DataLoadingService
 
isComputeContext(ActiveContext) - Method in class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
 
isConfigured(ActiveContext) - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
Tests whether the activeContext is a context configured.
isConfigured(ActiveContext) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
isDataLoadedContext(ActiveContext) - Method in interface org.apache.reef.io.data.loading.api.DataLoadingService
Distinguishes data loaded contexts from compute contexts.
isDataLoadedContext(ActiveContext) - Method in class org.apache.reef.io.data.loading.impl.InputFormatLoadingService
 
isDone() - Method in class org.apache.reef.client.LauncherStatus
Has the job completed?
isDone() - Method in class org.apache.reef.tang.InjectionFuture
 
isDone() - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
 
isDone() - Method in class org.apache.reef.vortex.api.VortexFuture
 
isEmpty() - Method in class org.apache.reef.io.data.loading.api.DistributedDataSet
Returns true if it does not contain any partition.
isEmpty() - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
isEmpty() - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
isEmpty() - Method in class org.apache.reef.runtime.common.utils.DispatchingEStage
Return true if there are no messages queued or in processing, false otherwise.
isEmpty() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
isEmpty() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
isEmpty() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
isEmpty(Collection<T>) - Static method in class org.apache.reef.util.CollectionUtils
Checks if the collection is null or empty.
isExternalConstructor - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
isExternalConstructor() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
isExternalConstructor() - Method in interface org.apache.reef.tang.types.ClassNode
 
isFailedOrExpired() - Method in enum org.apache.reef.driver.restart.EvaluatorRestartState
 
isFailedOrNotExpected() - Method in enum org.apache.reef.driver.restart.EvaluatorRestartState
 
isFeasible() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
isIdle() - Method in class org.apache.reef.runtime.common.driver.idle.IdleMessage
 
isIdle() - Method in interface org.apache.reef.wake.time.Clock
Clock is idle if it has no future Alarms set.
isIdle() - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
Check if there are no client alarms scheduled.
isImplementation(ClassNode<?>, ClassNode<?>) - Method in interface org.apache.reef.tang.ClassHierarchy
Return whether the impl is a subclass of inter.
isImplementation(ClassNode<?>, ClassNode<?>) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
isImplementation(ClassNode<?>, ClassNode<?>) - Method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
 
isImplementationOf(ClassNode<?>) - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
isImplementationOf(ClassNode<?>) - Method in interface org.apache.reef.tang.types.ClassNode
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
isInitialized() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
isInitialized() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
isInitialized() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
isInitialized() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
isInitialized() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
isInitialized() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
isInitialized() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
isInitialized() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
isInitialized() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
isInitialized() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
isInitialized() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
isInitialized() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
isInjectable() - Method in class org.apache.reef.tang.implementation.Constructor
 
isInjectable() - Method in class org.apache.reef.tang.implementation.InjectionFuturePlan
 
isInjectable() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
isInjectable(String) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
isInjectable(Class<?>) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
isInjectable() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
isInjectable() - Method in class org.apache.reef.tang.implementation.ListInjectionPlan
 
isInjectable() - Method in class org.apache.reef.tang.implementation.SetInjectionPlan
 
isInjectable() - Method in class org.apache.reef.tang.implementation.Subplan
 
isInjectable(String) - Method in interface org.apache.reef.tang.Injector
Returns true if this Injector is able to instantiate the object named by name.
isInjectable(Class<?>) - Method in interface org.apache.reef.tang.Injector
 
isInjectionCandidate - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
isInjectionCandidate() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
isInjectionCandidate() - Method in interface org.apache.reef.tang.types.ClassNode
 
isInjectionFuture - Variable in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Deprecated.
isInjectionFuture() - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
isInjectionFuture() - Method in interface org.apache.reef.tang.types.ConstructorArg
 
isKeepContainers() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
isLegalTransition(EvaluatorRestartState, EvaluatorRestartState) - Static method in enum org.apache.reef.driver.restart.EvaluatorRestartState
Deprecated.
TODO[JIRA REEF-1560] Use non-static method instead. Remove after version 0.16
isLegalTransition(EvaluatorRestartState) - Method in enum org.apache.reef.driver.restart.EvaluatorRestartState
Check if the transition of EvaluatorRestartState from current state to the given one is legal.
isLegalTransition(DriverStatus) - Method in enum org.apache.reef.runtime.common.driver.DriverStatus
Check whether a driver state transition from current state to a given one is legal.
isLegalTransition(State) - Method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Checks if the ResourceManager can switch from the current state to the target state.
isLinux() - Static method in class org.apache.reef.util.OSUtils
Determines whether the current JVM is running on the Linux OS.
isList - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
isList() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
isList() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
isLoggable(LogRecord) - Method in class org.apache.reef.util.logging.DFSHandler
 
isMac() - Static method in class org.apache.reef.util.OSUtils
Determines whether the current JVM is running on the Mac OS.
isMoreSpecificThan(ConstructorDef<?>) - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
isMoreSpecificThan(ConstructorDef<?>) - Method in interface org.apache.reef.tang.types.ConstructorDef
 
isNeighborActive(String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
isNeighborActive(String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
isNotEmpty(Collection<T>) - Static method in class org.apache.reef.util.CollectionUtils
Checks if the collection is not null and not empty.
isNotRunning() - Method in class org.apache.reef.runtime.common.driver.task.TaskRepresenter
 
isOptionSet() - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
isOptionSet() - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
Check whether custom options have been set for the process.
isOptionSet() - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
isOptionSet - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Deprecated.
isParameterSet(String) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
isParameterSet(Class<? extends Name<?>>) - Method in class org.apache.reef.tang.implementation.java.InjectorImpl
 
isParameterSet(String) - Method in interface org.apache.reef.tang.Injector
 
isParameterSet(Class<? extends Name<?>>) - Method in interface org.apache.reef.tang.Injector
 
isPresent() - Method in class org.apache.reef.util.Optional
 
isProfilingEnabled(Injector) - Static method in class org.apache.reef.wake.profiler.ProfilerState
Checks if profiling is enabled.
isRampup() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
isReady(long) - Method in class org.apache.reef.wake.time.runtime.LogicalTimer
Deprecated.
[REEF-1532] Prefer passing Time object instead of the numeric timestamp. Remove after release 0.16.
isReady(Time) - Method in class org.apache.reef.wake.time.runtime.LogicalTimer
Check if the event with a given timestamp has occurred, according to the timer.
isReady(long) - Method in class org.apache.reef.wake.time.runtime.RealTimer
Deprecated.
[REEF-1532] Prefer passing Time object instead of the numeric timestamp. Remove after release 0.16.
isReady(Time) - Method in class org.apache.reef.wake.time.runtime.RealTimer
Check if the event with a given timestamp has occurred.
isReady(long) - Method in interface org.apache.reef.wake.time.runtime.Timer
Deprecated.
[REEF-1532] Prefer passing Time object instead of the numeric timestamp. Remove after release 0.16.
isReady(Time) - Method in interface org.apache.reef.wake.time.runtime.Timer
Check if the event with a given timestamp has occurred, according to the timer.
isReregistered() - Method in enum org.apache.reef.driver.restart.EvaluatorRestartState
 
isRestartable() - Method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Check if the container is can be restarted.
isRestarting() - Method in class org.apache.reef.driver.restart.DriverRestartManager
 
isRestarting() - Method in enum org.apache.reef.driver.restart.DriverRestartState
 
isRootContext() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
isRootPresent() - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Check whether the root node has been added or not.
isRootPresent() - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
isRootPresent() - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
isRunning() - Method in class org.apache.reef.client.LauncherStatus
Is the job still running?
isRunning() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
isRunning() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
isRunning() - Method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Check if container is in RUNNING state.
isRunning() - Method in interface org.apache.reef.runtime.local.driver.Container
 
isRunning() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
isSet() - Method in class org.apache.reef.runtime.common.client.defaults.DefaultUserCredentials
Check if the user credentials had been set.
isSet() - Method in interface org.apache.reef.runtime.common.UserCredentials
Check if the user credentials had been set.
isSet() - Method in class org.apache.reef.runtime.yarn.client.unmanaged.YarnProxyUser
Check if the proxy user is set.
isSet - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
isSet() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
isSet() - Method in interface org.apache.reef.tang.types.NamedParameterNode
 
isSet() - Method in class org.apache.reef.util.SetOnce
 
isShuttingDownOrFailing() - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Deprecated.
TODO[JIRA REEF-1560] Use isClosing() method instead. Remove after version 0.16
isSuccess() - Method in class org.apache.reef.client.LauncherStatus
Has the job completed successfully?
IsTaskSuspended - Class in org.apache.reef.tests.watcher
Boolean value, true = task is suspended.
IsTaskSuspended() - Constructor for class org.apache.reef.tests.watcher.IsTaskSuspended
 
isTimedOut() - Method in interface org.apache.reef.driver.restart.DriverRestartCompleted
 
isTimedOut() - Method in class org.apache.reef.javabridge.generic.DriverRestartCompletedBridge
 
isUnit - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
isUnit() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
isUnit() - Method in interface org.apache.reef.tang.types.ClassNode
 
isUnix() - Static method in class org.apache.reef.util.OSUtils
Determines whether the current JVM is running on the Unix-based OS.
isUnmanagedAM() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
isWindows() - Static method in class org.apache.reef.util.OSUtils
Determines whether the current JVM is running on the Windows OS.
Iterations - Class in org.apache.reef.examples.group.bgd.parameters
Maximum Number of Iterations.
Iterations() - Constructor for class org.apache.reef.examples.group.bgd.parameters.Iterations
 
iterator() - Method in class org.apache.reef.io.data.loading.api.DistributedDataSet
 
iterator() - Method in class org.apache.reef.io.data.loading.impl.InMemoryInputFormatDataSet
 
iterator() - Method in class org.apache.reef.io.data.loading.impl.InputFormatDataSet
 
iterator() - Method in interface org.apache.reef.io.Spool
Returns an Iterable over the spool file.
iterator() - Method in class org.apache.reef.io.storage.FramingInputStream
 
iterator() - Method in class org.apache.reef.io.storage.local.CodecFileIterable
 
iterator() - Method in class org.apache.reef.io.storage.local.SerializerFileSpool
 
iterator() - Method in class org.apache.reef.io.storage.ram.RamSpool
 
iterator() - Method in class org.apache.reef.io.storage.ram.SortingRamSpool
 
iterator() - Method in class org.apache.reef.io.storage.util.GetAllIterable
 
iterator() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
iterator() - Method in class org.apache.reef.wake.remote.ports.RangeTcpPortProvider
Returns an iterator over a set of tcp ports.
iterator() - Method in interface org.apache.reef.wake.remote.ports.TcpPortProvider
Returns an iterator over a set of tcp ports.

J

JARFileMaker - Class in org.apache.reef.util
Helper class to create JAR files.
JARFileMaker(File) - Constructor for class org.apache.reef.util.JARFileMaker
 
JARFileMaker(File, Manifest) - Constructor for class org.apache.reef.util.JARFileMaker
 
JAVA - Static variable in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
JavaClassHierarchy - Interface in org.apache.reef.tang
 
JavaConfigurationBuilder - Interface in org.apache.reef.tang
Convenience methods that extend the ConfigurationBuilder but assume that the underlying ClassHierarchy delegates to the default Java classloader.
JavaConfigurationBuilderImpl - Class in org.apache.reef.tang.implementation.java
 
JavaConfigurationBuilderImpl(URL[], Configuration[], Class<? extends ExternalConstructor<?>>[]) - Constructor for class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
JavaConfigurationBuilderImpl(URL[]) - Constructor for class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
JavaConfigurationBuilderImpl(Configuration[]) - Constructor for class org.apache.reef.tang.implementation.java.JavaConfigurationBuilderImpl
 
JavaInstance<T> - Class in org.apache.reef.tang.implementation.java
 
JavaInstance(Node, T) - Constructor for class org.apache.reef.tang.implementation.java.JavaInstance
 
JavaLaunchCommandBuilder - Class in org.apache.reef.runtime.common.launch
Build the launch command for Java REEF processes.
JavaLaunchCommandBuilder() - Constructor for class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
Constructor that populates default options, using the default Launcher class REEFLauncher.
JavaLaunchCommandBuilder(List<String>) - Constructor for class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
Constructor that uses the default Launcher class, REEFLauncher.
JavaLaunchCommandBuilder(Class, List<String>) - Constructor for class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
Constructor that populates prefix and uses a custom Launcher class.
JavaNodeFactory - Class in org.apache.reef.tang.implementation.java
 
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The identifier of the Job submitted.
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
 
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.multi.driver.MultiRuntimeDriverConfiguration
The identifier of the Job submitted.
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
The identifier of the Job submitted.
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
JOB_IDENTIFIER - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
JOB_STATUS_HANDLER - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
Interface to use for communications back to the client.
JOB_SUBMISSION_DIRECTORY - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
JOB_SUBMISSION_DIRECTORY - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
JOB_SUBMISSION_DIRECTORY - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
JOB_SUBMISSION_DIRECTORY_PREFIX - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
The client remote identifier.
JOB_SUBMISSION_DIRECTORY_PREFIX - Static variable in class org.apache.reef.runtime.yarn.client.YarnDriverConfiguration
The job submission directory.
JOB_TIMEOUT - Static variable in class org.apache.reef.examples.hellohttp.HelloREEFHttp
Number of milliseconds to wait for the job to complete.
JobClient - Class in org.apache.reef.javabridge.generic
Clr Bridge Client.
JobCompletedHandler - Class in org.apache.reef.client.parameters
Event handler for CompletedJob.
JobConfExternalConstructor - Class in org.apache.reef.io.data.loading.impl
 
JobConfExternalConstructor(String, String) - Constructor for class org.apache.reef.io.data.loading.impl.JobConfExternalConstructor
 
JobConfExternalConstructor.InputFormatClass - Class in org.apache.reef.io.data.loading.impl
 
JobConfExternalConstructor.InputFormatClass() - Constructor for class org.apache.reef.io.data.loading.impl.JobConfExternalConstructor.InputFormatClass
 
JobConfExternalConstructor.InputPath - Class in org.apache.reef.io.data.loading.impl
 
JobConfExternalConstructor.InputPath() - Constructor for class org.apache.reef.io.data.loading.impl.JobConfExternalConstructor.InputPath
 
JOBCONTROL_FIELD_NUMBER - Static variable in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
JobDriver - Class in org.apache.reef.examples.pool
Allocate N evaluators, submit M tasks to them, and measure the time.
JobDriver - Class in org.apache.reef.javabridge.generic
Generic job driver for CLRBridge.
JobDriver.ActiveContextHandler - Class in org.apache.reef.javabridge.generic
Receive notification that a new Context is available.
JobDriver.ActiveContextHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.ActiveContextHandler
 
JobDriver.AllocatedEvaluatorHandler - Class in org.apache.reef.javabridge.generic
Handles AllocatedEvaluator: Submit an empty context.
JobDriver.AllocatedEvaluatorHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.AllocatedEvaluatorHandler
 
JobDriver.ClosedContextHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Context had completed.
JobDriver.ClosedContextHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.ClosedContextHandler
 
JobDriver.CompletedEvaluatorHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Evaluator has been shut down.
JobDriver.CompletedEvaluatorHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.CompletedEvaluatorHandler
 
JobDriver.CompletedTaskHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Task has completed successfully.
JobDriver.CompletedTaskHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.CompletedTaskHandler
 
JobDriver.ContextMessageHandler - Class in org.apache.reef.javabridge.generic
Receive notification that a ContextMessage has been received.
JobDriver.ContextMessageHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.ContextMessageHandler
 
JobDriver.DriverRestartActiveContextHandler - Class in org.apache.reef.javabridge.generic
Receive notification that an context is active on Evaluator when the driver restarted.
JobDriver.DriverRestartActiveContextHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.DriverRestartActiveContextHandler
 
JobDriver.DriverRestartCompletedHandler - Class in org.apache.reef.javabridge.generic
Receive notification that driver restart has completed.
JobDriver.DriverRestartCompletedHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.DriverRestartCompletedHandler
 
JobDriver.DriverRestartFailedEvaluatorHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the entire Evaluator had failed on Driver Restart.
JobDriver.DriverRestartFailedEvaluatorHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.DriverRestartFailedEvaluatorHandler
 
JobDriver.DriverRestartRunningTaskHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Task is running when driver restarted.
JobDriver.DriverRestartRunningTaskHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.DriverRestartRunningTaskHandler
 
JobDriver.FailedContextHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Context had failed.
JobDriver.FailedContextHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.FailedContextHandler
 
JobDriver.FailedEvaluatorHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the entire Evaluator had failed.
JobDriver.FailedEvaluatorHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.FailedEvaluatorHandler
 
JobDriver.FailedTaskHandler - Class in org.apache.reef.javabridge.generic
Handle failed task.
JobDriver.FailedTaskHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.FailedTaskHandler
 
JobDriver.ProgressProvider - Class in org.apache.reef.javabridge.generic
Gets the progress of the application from .NET side.
JobDriver.ProgressProvider() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.ProgressProvider
 
JobDriver.RestartHandler - Class in org.apache.reef.javabridge.generic
Job driver is restarted after previous crash.
JobDriver.RestartHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.RestartHandler
 
JobDriver.RunningTaskHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Task is running.
JobDriver.RunningTaskHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.RunningTaskHandler
 
JobDriver.StartHandler - Class in org.apache.reef.javabridge.generic
Job Driver is ready and the clock is set up: request the evaluators.
JobDriver.StartHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.StartHandler
 
JobDriver.SuspendedTaskHandler - Class in org.apache.reef.javabridge.generic
Receive notification that the Task has been suspended.
JobDriver.SuspendedTaskHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.SuspendedTaskHandler
 
JobDriver.TaskMessageHandler - Class in org.apache.reef.javabridge.generic
Handler for message received from the Task.
JobDriver.TaskMessageHandler() - Constructor for class org.apache.reef.javabridge.generic.JobDriver.TaskMessageHandler
 
JobFailedHandler - Class in org.apache.reef.client.parameters
Client EventHandler triggered on remote job failure.
JobFolder - Class in org.apache.reef.runtime.yarn.client.uploader
Helper class that represents a folder on the destination filesystem.
JobGlobalFiles - Class in org.apache.reef.driver.parameters
Files to be made accessible on the Driver and all Evaluators.
JobGlobalLibraries - Class in org.apache.reef.driver.parameters
Libraries to be made accessible on the Driver and all Evaluators.
jobId - Variable in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Deprecated.
JobIdentifier - Class in org.apache.reef.runtime.common.driver.parameters
The job identifier.
JobIdentifier() - Constructor for class org.apache.reef.runtime.common.driver.parameters.JobIdentifier
 
JobJarMaker - Class in org.apache.reef.runtime.common.files
Utility that takes a JobSubmissionProto and turns it into a Job Submission Jar.
JobMessage - Class in org.apache.reef.client
A message received by the client from the driver.
JobMessage(String, byte[]) - Constructor for class org.apache.reef.client.JobMessage
 
JobMessageHandler - Class in org.apache.reef.client.parameters
Client EventHandler that gets messages from the Driver.
JobMessageObserver - Interface in org.apache.reef.driver.client
The driver uses this interface to communicate with the job client.
JobMessageObserverImpl - Class in org.apache.reef.runtime.common.driver.client
An implementation of JobMessageObserver.
JobMessageObserverImpl(ClientConnection) - Constructor for class org.apache.reef.runtime.common.driver.client.JobMessageObserverImpl
 
JobPriority - Class in org.apache.reef.runtime.yarn.client.parameters
The priority of the submitted job.
JobPriority() - Constructor for class org.apache.reef.runtime.yarn.client.parameters.JobPriority
 
JobQueue - Class in org.apache.reef.runtime.yarn.client.parameters
The queue to submit a job to.
JobQueue() - Constructor for class org.apache.reef.runtime.yarn.client.parameters.JobQueue
 
JobResourceUploader - Class in org.apache.reef.bridge.client
Helper class that uploads job resource to HDFS.
JobRunningHandler - Class in org.apache.reef.client.parameters
Client EventHandler triggered when the REEF job is running.
JOBSTATUS_FIELD_NUMBER - Static variable in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
JobStatusHandler - Interface in org.apache.reef.runtime.common.driver.client
Generic interface for job status messages' handler.
JobSubmissionDirectory - Class in org.apache.reef.runtime.yarn.driver.parameters
The job submission directory.
JobSubmissionDirectory() - Constructor for class org.apache.reef.runtime.yarn.driver.parameters.JobSubmissionDirectory
 
jobSubmissionDirectoryPrefix - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Deprecated.
JobSubmissionDirectoryPrefix - Class in org.apache.reef.runtime.mesos.driver.parameters
The job submission directory.
JobSubmissionDirectoryPrefix() - Constructor for class org.apache.reef.runtime.mesos.driver.parameters.JobSubmissionDirectoryPrefix
 
JobSubmissionDirectoryPrefix - Class in org.apache.reef.runtime.yarn.driver.parameters
The job submission directory.
JobSubmissionDirectoryPrefix() - Constructor for class org.apache.reef.runtime.yarn.driver.parameters.JobSubmissionDirectoryPrefix
 
JobSubmissionDirectoryProvider - Interface in org.apache.reef.runtime.yarn.driver
Provides path to job submission directory.
JobSubmissionDirectoryProviderImpl - Class in org.apache.reef.runtime.yarn.driver
Default implementation of JobSubmissionDirectoryProvider.
JobSubmissionEvent - Interface in org.apache.reef.runtime.common.client.api
Event sent to Driver Runtime.
JobSubmissionEventImpl - Class in org.apache.reef.runtime.common.client.api
Default POJO implementation of JobSubmissionEvent.
JobSubmissionEventImpl.Builder - Class in org.apache.reef.runtime.common.client.api
Builder used to create JobSubmissionEvent instances.
JobSubmissionEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
jobSubmissionFolder - Variable in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Deprecated.
JobSubmissionHandler - Interface in org.apache.reef.runtime.common.client.api
A Handler for JobSubmissionEvent.
JobSubmittedHandler - Class in org.apache.reef.client.parameters
Handler for the SubmittedJob event.
JobUploader - Class in org.apache.reef.runtime.yarn.client.uploader
Helper class to upload the driver files to HDFS.
JSON_CHARSET - Static variable in class org.apache.reef.webserver.AvroHttpSerializer
 
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
 
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
 
JVM_HEAP_SLACK - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
The fraction of the container memory NOT to use for the Java Heap.
JVMHeapSlack - Class in org.apache.reef.runtime.common.parameters
The fraction of the container memory NOT to use for the Java Heap.
JVMHeapSlack() - Constructor for class org.apache.reef.runtime.common.parameters.JVMHeapSlack
 
JVMProcess - Class in org.apache.reef.driver.evaluator
Defines the setup of a JVM process.
JVMProcessFactory - Class in org.apache.reef.driver.evaluator
Factory to setup new JVM processes.

K

KEEP_CONTAINERS_ACROSS_APPLICATION_ATTEMPTS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
KEY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
key - Variable in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Deprecated.
key - Variable in class org.apache.reef.webserver.HeaderEntry
Deprecated.
keySet() - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
keySet() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
keySet() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
keySet() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
kill(long) - Static method in class org.apache.reef.util.OSUtils
Kill the process.
KILL_EVALUATOR_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
killApplication(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.HDInsightInstance
Issues a YARN kill command to the application.
KILLED_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.State
KILLED = 5;
killTask(ExecutorDriver, Protos.TaskID) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
KryoUtils - Class in org.apache.reef.vortex.common
The one and only serializer for the Vortex protocol.

L

Lambda - Class in org.apache.reef.examples.group.bgd.parameters
The regularization constant.
Lambda() - Constructor for class org.apache.reef.examples.group.bgd.parameters.Lambda
 
language - Variable in class org.apache.reef.tang.formats.avro.AvroConfiguration
Deprecated.
Launch - Class in org.apache.reef.examples.pool
Pool of Evaluators example - main class.
Launch - Class in org.apache.reef.examples.reefonreef
The Client for running REEF-on-REEF application on YARN.
Launch - Class in org.apache.reef.examples.suspend
Suspend/Resume example - main class.
Launch - Class in org.apache.reef.javabridge.generic
Clr Bridge example - main class.
launch(File) - Method in class org.apache.reef.runtime.local.client.PreparedDriverFolderLauncher
Launches the driver prepared in driverFolder.
launch(File, String, String) - Method in class org.apache.reef.runtime.local.client.PreparedDriverFolderLauncher
 
Launch.Delay - Class in org.apache.reef.examples.pool
Command line parameter: number of experiments to run.
Launch.Delay() - Constructor for class org.apache.reef.examples.pool.Launch.Delay
 
Launch.Delay - Class in org.apache.reef.examples.suspend
Command line parameter: delay in seconds for each cycle.
Launch.Delay() - Constructor for class org.apache.reef.examples.suspend.Launch.Delay
 
Launch.DriverIdentifier - Class in org.apache.reef.javabridge.generic
Command line parameter, driver identifier.
Launch.DriverIdentifier() - Constructor for class org.apache.reef.javabridge.generic.Launch.DriverIdentifier
 
Launch.DriverJobSubmissionDirectory - Class in org.apache.reef.javabridge.generic
Command line parameter, job submission directory, if set, user should guarantee its uniqueness.
Launch.DriverJobSubmissionDirectory() - Constructor for class org.apache.reef.javabridge.generic.Launch.DriverJobSubmissionDirectory
 
Launch.DriverMemoryInMb - Class in org.apache.reef.javabridge.generic
Command line parameter, driver memory, in MB.
Launch.DriverMemoryInMb() - Constructor for class org.apache.reef.javabridge.generic.Launch.DriverMemoryInMb
 
Launch.JobId - Class in org.apache.reef.examples.pool
Command line parameter = Numeric ID for the job.
Launch.JobId() - Constructor for class org.apache.reef.examples.pool.Launch.JobId
 
Launch.Local - Class in org.apache.reef.examples.pool
Command line parameter = true to run locally, or false to run on YARN.
Launch.Local() - Constructor for class org.apache.reef.examples.pool.Launch.Local
 
Launch.Local - Class in org.apache.reef.examples.suspend
Command line parameter = true to run locally, or false to run on YARN.
Launch.Local() - Constructor for class org.apache.reef.examples.suspend.Launch.Local
 
Launch.Local - Class in org.apache.reef.javabridge.generic
Command line parameter = true to run locally, or false to run on YARN.
Launch.Local() - Constructor for class org.apache.reef.javabridge.generic.Launch.Local
 
Launch.NumCycles - Class in org.apache.reef.examples.suspend
Command line parameter: number of iterations to run.
Launch.NumCycles() - Constructor for class org.apache.reef.examples.suspend.Launch.NumCycles
 
Launch.NumEvaluators - Class in org.apache.reef.examples.pool
Command line parameter: number of Evaluators to request.
Launch.NumEvaluators() - Constructor for class org.apache.reef.examples.pool.Launch.NumEvaluators
 
Launch.NumRuns - Class in org.apache.reef.javabridge.generic
Command line parameter: number of experiments to run.
Launch.NumRuns() - Constructor for class org.apache.reef.javabridge.generic.Launch.NumRuns
 
Launch.NumTasks - Class in org.apache.reef.examples.pool
Command line parameter: number of Tasks to run.
Launch.NumTasks() - Constructor for class org.apache.reef.examples.pool.Launch.NumTasks
 
Launch.Piggyback - Class in org.apache.reef.examples.pool
Command line parameter = true to submit task and context in one request.
Launch.Piggyback() - Constructor for class org.apache.reef.examples.pool.Launch.Piggyback
 
Launch.Submit - Class in org.apache.reef.javabridge.generic
Command line parameter = true to submit the job with driver config, or false to write config to current directory.
Launch.Submit() - Constructor for class org.apache.reef.javabridge.generic.Launch.Submit
 
Launch.WaitTimeForDriver - Class in org.apache.reef.javabridge.generic
Command line parameter, number of seconds to wait till driver finishes , = -1 : waits forever = 0: exit immediately without wait for driver.
Launch.WaitTimeForDriver() - Constructor for class org.apache.reef.javabridge.generic.Launch.WaitTimeForDriver
 
LaunchCommandBuilder - Interface in org.apache.reef.runtime.common.launch
Used to build the launch command for REEF processes.
LauncherStatus - Class in org.apache.reef.client
The status of a reef job spawned using the DriverLauncher class.
LaunchID - Class in org.apache.reef.runtime.common.launch.parameters
The launch identifier.
launchLocal(VortexJobConf) - Static method in class org.apache.reef.vortex.driver.VortexLauncher
Launch a Vortex job using the local runtime.
launchTask(ExecutorDriver, Protos.TaskInfo) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
We assume a long-running Mesos Task that manages a REEF Evaluator process, leveraging Mesos Executor's interface.
LineCounter - Class in org.apache.reef.examples.data.loading
Driver side for the line counting demo that uses the data loading service.
LineCounter(DataLoadingService) - Constructor for class org.apache.reef.examples.data.loading.LineCounter
 
LineCounter.ContextActiveHandler - Class in org.apache.reef.examples.data.loading
Handler for ActiveContext.
LineCounter.ContextActiveHandler() - Constructor for class org.apache.reef.examples.data.loading.LineCounter.ContextActiveHandler
 
LineCounter.TaskCompletedHandler - Class in org.apache.reef.examples.data.loading
Completed task handler.
LineCounter.TaskCompletedHandler() - Constructor for class org.apache.reef.examples.data.loading.LineCounter.TaskCompletedHandler
 
LineCountingTask - Class in org.apache.reef.examples.data.loading
The task that iterates over the data set to count the number of records.
LineCountingTask(DataSet<LongWritable, Text>) - Constructor for class org.apache.reef.examples.data.loading.LineCountingTask
 
LineSearchEvaluationsReducer - Class in org.apache.reef.examples.group.bgd.operatornames
Name of the reducer used to aggregate line search results.
LineSearchEvaluationsReducer() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.LineSearchEvaluationsReducer
 
LineSearchReduceFunction - Class in org.apache.reef.examples.group.bgd
Reduce function implementing line search.
LineSearchReduceFunction() - Constructor for class org.apache.reef.examples.group.bgd.LineSearchReduceFunction
 
Link<T> - Interface in org.apache.reef.wake.remote.transport
Link between two end physical endpoints.
LinkListener<T> - Interface in org.apache.reef.wake.remote.transport
Link listener.
ListApplicationResponse - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
The data structure used to deserialize the REST response from a call to the Resource Manager to list applications.
ListApplicationResponse() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.ListApplicationResponse
 
listApplications() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.HDInsightInstance
 
ListCodec<T> - Class in org.apache.reef.io.network.util
 
ListCodec(Codec<T>) - Constructor for class org.apache.reef.io.network.util.ListCodec
 
ListInjectionPlan<T> - Class in org.apache.reef.tang.implementation
 
ListInjectionPlan(Node, List<InjectionPlan<T>>) - Constructor for class org.apache.reef.tang.implementation.ListInjectionPlan
 
listToString(List<ComparableIdentifier>) - Static method in class org.apache.reef.io.network.util.Utils
 
LOAD_FIELD_NUMBER - Static variable in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
LOAD_LIB - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
loadClassHierarchy(String) - Static method in class org.apache.reef.javabridge.Utilities
 
loadClrAssembly(String) - Static method in class org.apache.reef.javabridge.NativeInterop
 
loadIntoMemory(boolean) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
loadLib() - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to load global files and libraries.
LOCAL_FILES - Static variable in class org.apache.reef.client.DriverConfiguration
Files to be made available on the Driver only.
LOCAL_FILES - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Files to be made available on the Driver only.
LOCAL_JOB_SUBMIT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
LOCAL_LIBRARIES - Static variable in class org.apache.reef.client.DriverConfiguration
Libraries to be made available on the Driver only.
LOCAL_LIBRARIES - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Libraries to be made available on the Driver only.
LOCAL_RESOURCES - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
localAddress() - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Gets the local socket address.
LocalAddressProvider - Interface in org.apache.reef.wake.remote.address
Injectable class that provides the local address of the node to bind to.
LocalClasspathProvider - Class in org.apache.reef.runtime.local
RuntimeClasspathProvider for the local runtime.
LocalClient - Class in org.apache.reef.bridge.client
Submits a folder containing a Driver to the local runtime.
LocalDriverConfiguration - Class in org.apache.reef.runtime.local.driver
ConfigurationModule for the Driver executed in the local resourcemanager.
LocalDriverConfiguration() - Constructor for class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
 
localJobSubmission() - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time for a job submission.
LocalJobSubmissionHandler - Class in org.apache.reef.runtime.local.client
Handles Job Submissions for the Local and the Standalone Runtime.
LocalNameResolverConfiguration - Class in org.apache.reef.io.network.naming
Configuration Module Builder for LocalNameResolver.
LocalNameResolverConfiguration() - Constructor for class org.apache.reef.io.network.naming.LocalNameResolverConfiguration
 
LocalNameResolverImpl - Class in org.apache.reef.io.network.naming
NameResolver looking up local name server.
LocalResource - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents a the details of a local resource used in an HDInsight job submission.
LocalResource() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
LocalResourceReleaseHandler - Class in org.apache.reef.runtime.local.driver
Takes Resource Release requests and patches them through to the resource manager.
LocalResourcesEntry - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents a resource to be localized.
LocalResourcesEntry(String, LocalResource) - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResourcesEntry
 
localRuntimeAppParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Deprecated.
LocalRuntimeConfiguration - Class in org.apache.reef.runtime.local.client
A ConfigurationModule to configure the local resourcemanager.
LocalRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
 
LocalScratchSpace - Class in org.apache.reef.io.storage.local
 
LocalScratchSpace(String, String) - Constructor for class org.apache.reef.io.storage.local.LocalScratchSpace
 
LocalScratchSpace(String, String, long) - Constructor for class org.apache.reef.io.storage.local.LocalScratchSpace
 
LocalStorageService - Class in org.apache.reef.io.storage.local
 
LocalStorageService(String, String) - Constructor for class org.apache.reef.io.storage.local.LocalStorageService
 
log(int, String) - Method in class org.apache.reef.javabridge.InteropLogger
 
LogEventStream - Class in org.apache.reef.io.watcher
Write events to driver.err using Logger.
LoggingEventHandler<T> - Class in org.apache.reef.examples.utils.wake
An EventHandler that logs its events before handing it to a downstream EventHandler.
LoggingEventHandler(EventHandler<T>, String) - Constructor for class org.apache.reef.examples.utils.wake.LoggingEventHandler
 
LoggingEventHandler(EventHandler<T>) - Constructor for class org.apache.reef.examples.utils.wake.LoggingEventHandler
 
LoggingEventHandler<T> - Class in org.apache.reef.wake.impl
A logging event handler.
LoggingEventHandler() - Constructor for class org.apache.reef.wake.impl.LoggingEventHandler
 
LoggingJobStatusHandler - Class in org.apache.reef.runtime.common.driver.client
A handler for job status messages that just logs them.
LoggingLinkListener<T> - Class in org.apache.reef.wake.remote.transport.netty
Link listener that logs whether the message is sent successfully.
LoggingLinkListener() - Constructor for class org.apache.reef.wake.remote.transport.netty.LoggingLinkListener
 
LoggingRunnableProcessObserver - Class in org.apache.reef.runtime.local.process
A RunnableProcessObserver that logs the events/.
LoggingRunnableProcessObserver() - Constructor for class org.apache.reef.runtime.local.process.LoggingRunnableProcessObserver
 
LoggingScope - Interface in org.apache.reef.util.logging
Log time elapsed for a scope.
LoggingScopeFactory - Class in org.apache.reef.util.logging
Create Logging scope objects.
LoggingScopeImpl - Class in org.apache.reef.util.logging
Log time and duration for a scope.
LoggingSetup - Class in org.apache.reef.util.logging
Configure Commons Logging.
LoggingUtils - Class in org.apache.reef.wake.impl
Utility for logging.
LoggingVoidEventHandler - Class in org.apache.reef.wake.impl
A logging void event handler.
LoggingVoidEventHandler() - Constructor for class org.apache.reef.wake.impl.LoggingVoidEventHandler
 
LogicalTimer - Class in org.apache.reef.wake.time.runtime
Logical timer that is only bound to the timestamps of the events tracked against it.
LogisticLossFunction - Class in org.apache.reef.examples.group.bgd.loss
Logistic LossFunction.
LogisticLossFunction() - Constructor for class org.apache.reef.examples.group.bgd.loss.LogisticLossFunction
Trivial constructor.
LogLevelName - Class in org.apache.reef.util.logging
Name of a log Level as a string such as "INFO", "FINE".
LogLevelName() - Constructor for class org.apache.reef.util.logging.LogLevelName
 
LogParser - Class in org.apache.reef.util.logging
Parse logs for reporting.
logThreads(Logger, Level, String) - Static method in class org.apache.reef.util.ThreadLogger
Same as logThreads(logger, level, prefix, "\n\t", "\n\t\t").
logThreads(Logger, Level, String, String, String) - Static method in class org.apache.reef.util.ThreadLogger
Logs the currently active threads and their stack trace to the given Logger and Level.
logVersion() - Method in class org.apache.reef.util.REEFVersion
Logs the version of REEF into the log Level INFO.
logVersion(Level) - Method in class org.apache.reef.util.REEFVersion
Logs the version of REEF into the given logLevel.
lookup(Identifier) - Method in interface org.apache.reef.io.naming.NamingLookup
Lookup an Address for a given Identifier.
lookup(Identifier) - Method in class org.apache.reef.io.network.naming.LocalNameResolverImpl
 
lookup(Identifier) - Method in class org.apache.reef.io.network.naming.NameClient
Finds an address for an identifier.
lookup(Identifier) - Method in class org.apache.reef.io.network.naming.NameLookupClient
Finds an address for an identifier.
lookup(Identifier) - Method in interface org.apache.reef.io.network.naming.NameServer
Finds an address for an identifier locally.
lookup(Iterable<Identifier>) - Method in interface org.apache.reef.io.network.naming.NameServer
Finds addresses for identifiers locally.
lookup(Identifier) - Method in class org.apache.reef.io.network.naming.NameServerImpl
Finds an address for an identifier locally.
lookup(Iterable<Identifier>) - Method in class org.apache.reef.io.network.naming.NameServerImpl
Finds addresses for identifiers locally.
LoopbackLocalAddressProvider - Class in org.apache.reef.wake.remote.address
A LocalAddressProvider that always uses the Loopback Address.
LossAndGradientReduceFunction - Class in org.apache.reef.examples.group.bgd
Loss and gradient reduce function.
LossAndGradientReduceFunction() - Constructor for class org.apache.reef.examples.group.bgd.LossAndGradientReduceFunction
 
LossAndGradientReducer - Class in org.apache.reef.examples.group.bgd.operatornames
Name used for the Reduce operator for loss and gradient aggregation.
LossAndGradientReducer() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.LossAndGradientReducer
 
LossFunction - Interface in org.apache.reef.examples.group.bgd.loss
Interface for Loss Functions.
lossFunctionString() - Method in class org.apache.reef.examples.group.bgd.parameters.BGDLossType
 
LossFunctionType - Class in org.apache.reef.examples.group.bgd.parameters
 
LossFunctionType() - Constructor for class org.apache.reef.examples.group.bgd.parameters.LossFunctionType
 

M

M15_ALPHA - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
M1_ALPHA - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
M5_ALPHA - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
main(String[]) - Static method in class org.apache.reef.bridge.client.JobResourceUploader
This class is invoked from Org.Apache.REEF.Client.Yarn.LegacyJobResourceUploader in .NET code.
main(String[]) - Static method in class org.apache.reef.bridge.client.LocalClient
 
main(String[]) - Static method in class org.apache.reef.bridge.client.MultiRuntimeYarnBootstrapREEFLauncher
 
main(String[]) - Static method in class org.apache.reef.bridge.client.YarnBootstrapREEFLauncher
 
main(String[]) - Static method in class org.apache.reef.bridge.client.YarnJobSubmissionClient
.NET client calls into this main method for job submission.
main(String[]) - Static method in class org.apache.reef.examples.data.loading.DataLoadingREEF
 
main(String[]) - Static method in class org.apache.reef.examples.data.output.OutputServiceREEF
 
main(String[]) - Static method in class org.apache.reef.examples.distributedshell.ShellClient
Start the distributed shell job.
main(String[]) - Static method in class org.apache.reef.examples.group.bgd.BGDLocal
 
main(String[]) - Static method in class org.apache.reef.examples.group.bgd.BGDYarn
 
main(String[]) - Static method in class org.apache.reef.examples.group.bgd.data.parser.SVMLightParser
 
main(String[]) - Static method in class org.apache.reef.examples.group.bgd.utils.StepSizes
 
main(String[]) - Static method in class org.apache.reef.examples.group.bgd.utils.SubConfiguration
 
main(String[]) - Static method in class org.apache.reef.examples.group.broadcast.BroadcastREEF
 
main(String[]) - Static method in class org.apache.reef.examples.group.utils.math.Window
 
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloHDInsight
 
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloJVMOptionsREEF
Start HelloJVMOptions REEF job.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEF
Start Hello REEF job with local runtime.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFEnvironment
Start Hello REEF job with Driver and Client sharing the same process.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFMesos
MASTER_IP is set to "localhost:5050".
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFNoClient
 
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFStandalone
Start Hello REEF job.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFYarn
Start Hello REEF job.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFYarnRestart
Start HelloREEFYarnRestart job.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloReefYarnTcp
Start Hello REEF job.
main(String[]) - Static method in class org.apache.reef.examples.hello.HelloREEFYarnUnmanagedAM
Start Hello REEF job with Unmanaged Driver running locally in the same process.
main(String[]) - Static method in class org.apache.reef.examples.helloCLR.HelloCLR
Start Hello REEF job.
main(String[]) - Static method in class org.apache.reef.examples.hellohttp.HelloREEFHttp
Main program.
main(String[]) - Static method in class org.apache.reef.examples.hellohttp.HelloREEFHttpYarn
Start Hello REEF job.
main(String[]) - Static method in class org.apache.reef.examples.hellomultiruntime.HelloREEFMultiYarn
Start Hello REEF job.
main(String[]) - Static method in class org.apache.reef.examples.pool.Launch
Main method that launches the REEF job.
main(String[]) - Static method in class org.apache.reef.examples.reefonreef.Launch
Start REEF-on-REEF job on YARN.
main(String[]) - Static method in class org.apache.reef.examples.scheduler.client.SchedulerREEF
Main program.
main(String[]) - Static method in class org.apache.reef.examples.scheduler.client.SchedulerREEFYarn
Launch the scheduler with YARN client configuration.
main(String[]) - Static method in class org.apache.reef.examples.suspend.Control
 
main(String[]) - Static method in class org.apache.reef.examples.suspend.Launch
Main method that runs the example.
main(String[]) - Static method in class org.apache.reef.io.network.group.impl.GroupChangesCodec
 
main(String[]) - Static method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
main(String[]) - Static method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
main(String[]) - Static method in class org.apache.reef.io.network.util.ListCodec
 
main(String[]) - Static method in class org.apache.reef.javabridge.generic.Launch
Main method that starts the CLR Bridge from Java.
main(String[]) - Static method in class org.apache.reef.runtime.common.REEFLauncher
Launches a REEF client process (Driver or Evaluator).
main(String[]) - Static method in class org.apache.reef.runtime.hdinsight.cli.HDICLI
 
main(String[]) - Static method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
The starting point of the executor.
main(String[]) - Static method in class org.apache.reef.tang.examples.PrintTypeHierarchy
 
main(String[]) - Static method in class org.apache.reef.tang.examples.Timer
 
main(String[]) - Static method in class org.apache.reef.tang.examples.timer.TimerMock
 
main(String[]) - Static method in class org.apache.reef.tang.examples.TimerV1
 
main(String[]) - Static method in class org.apache.reef.tang.util.Tint
 
main(String[]) - Static method in class org.apache.reef.tang.util.ValidateConfiguration
 
main(String[]) - Static method in class org.apache.reef.tests.evaluator.failure.FailureREEF
 
main(String[]) - Static method in class org.apache.reef.util.MemoryUtils
 
main(String[]) - Static method in class org.apache.reef.util.ThreadLogger
An example how to use the above methods.
mark(long) - Method in class org.apache.reef.wake.metrics.Meter
Marks the number of events.
MASTER_IP - Static variable in class org.apache.reef.runtime.mesos.client.MesosClientConfiguration
The ip address of Mesos Master.
MasterIp - Class in org.apache.reef.runtime.mesos.client.parameters
The ip address of Mesos Master.
MasterIp() - Constructor for class org.apache.reef.runtime.mesos.client.parameters.MasterIp
 
MasterTask - Class in org.apache.reef.examples.group.bgd
Master task for BGD example.
MasterTask(GroupCommClient, int, double, int, boolean, StepSizes) - Constructor for class org.apache.reef.examples.group.bgd.MasterTask
 
MasterTask - Class in org.apache.reef.examples.group.broadcast
Slave task for broadcast example.
MasterTask(GroupCommClient, int) - Constructor for class org.apache.reef.examples.group.broadcast.MasterTask
 
MasterTask - Class in org.apache.reef.tests.group
Master task used for testing multiple communication groups.
MasterToWorkerRequest - Interface in org.apache.reef.vortex.protocol.mastertoworker
Master-to-Worker protocol.
MasterToWorkerRequest.Type - Enum in org.apache.reef.vortex.protocol.mastertoworker
Type of Request.
MAX_APP_ATTEMPTS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
MAX_APPLICATION_SUBMISSIONS - Static variable in class org.apache.reef.client.DriverConfiguration
The number of submissions that the resource manager will attempt to submit the application.
MAX_FRAME_LENGTH - Static variable in class org.apache.reef.wake.WakeParameters
 
MAX_NUMBER_OF_EVALUATORS - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
The number of threads or processes available to the resourcemanager.
MAX_NUMBER_OF_EVALUATORS - Static variable in class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
The number of threads or processes available to the resourcemanager.
MAX_NUMBER_OF_EVALUATORS - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The maximum number of evaluators.
MAX_NUMBER_OF_EVALUATORS - Static variable in class org.apache.reef.tests.evaluator.failure.FailureREEF
The upper limit on the number of Evaluators that the local resourcemanager will hand out concurrently.
MaxApplicationSubmissions - Class in org.apache.reef.driver.parameters
Whether the resource manager should preserve evaluators on job driver failure.
maxApplicationSubmissions - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
MAXIMUM_RESOURCE_CAPABILITY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
maxNumberOfConcurrentEvaluators - Variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Deprecated.
MaxNumberOfEvaluators - Class in org.apache.reef.runtime.local.client.parameters
The maximum number of evaluators to allow to run at once.
MaxNumberOfEvaluators() - Constructor for class org.apache.reef.runtime.local.client.parameters.MaxNumberOfEvaluators
 
megaBytes - Variable in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Deprecated.
MEMENTO - Static variable in class org.apache.reef.driver.task.TaskConfiguration
The Base64 encoded memento to be passed to Task.call().
memory - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Deprecated.
MEMORY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
memory - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
MEMORY_SECONDS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
MemoryUtils - Class in org.apache.reef.util
Utility class to report current and peak memory usage.
memPoolNames() - Static method in class org.apache.reef.util.MemoryUtils
 
merge(ClassHierarchy) - Method in interface org.apache.reef.tang.ClassHierarchy
Merge the contents of this ClassHierarchy and the provided one into a new class hierarchy.
merge(Configuration...) - Static method in class org.apache.reef.tang.Configurations
Merge a set of Configurations.
merge(Iterable<Configuration>) - Static method in class org.apache.reef.tang.Configurations
Merge a set of Configurations.
merge(ConfigurationModule) - Method in class org.apache.reef.tang.formats.ConfigurationModuleBuilder
TODO: It would be nice if this incorporated d by reference so that static analysis / documentation tools could document the dependency between c and d.
merge(ClassHierarchy) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
 
merge(ClassHierarchy) - Method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
 
mergeAddContext(EvaluatorRuntimeProtocol.AddContextProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
mergeClassNode(ClassHierarchyProto.ClassNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
mergeConstructor(InjectionPlanProto.Constructor) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
mergeContextControl(EvaluatorRuntimeProtocol.ContextControlProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
mergeContextMessage(EvaluatorRuntimeProtocol.ContextMessageProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
mergeDoneEvaluator(EvaluatorRuntimeProtocol.DoneEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
mergeEvaluatorControl(EvaluatorRuntimeProtocol.EvaluatorControlProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
mergeEvaluatorHeartBeat(EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
mergeEvaluatorStatus(ReefServiceProtos.EvaluatorStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
mergeFrom(Message) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
mergeFrom(ReefNetworkGroupCommProtos.GroupCommMessage) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
mergeFrom(ReefNetworkGroupCommProtos.GroupMessageBody) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
mergeFrom(ReefNetworkServiceProtos.NSMessagePBuf) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
mergeFrom(ReefNetworkServiceProtos.NSRecordPBuf) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
mergeFrom(ClientRuntimeProtocol.JobControlProto) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.AddContextProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.ContextControlProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.ContextMessageProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.DoneEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.EvaluatorControlProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.KillEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.RemoveContextProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.StartTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.StopEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.StopTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
mergeFrom(EvaluatorRuntimeProtocol.SuspendTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
mergeFrom(REEFProtocol.REEFMessage) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
mergeFrom(ReefServiceProtos.ContextStatusProto) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
mergeFrom(ReefServiceProtos.ContextStatusProto.ContextMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
mergeFrom(ReefServiceProtos.EvaluatorStatusProto) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
mergeFrom(ReefServiceProtos.JobStatusProto) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
mergeFrom(ReefServiceProtos.RuntimeErrorProto) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
mergeFrom(ReefServiceProtos.TaskStatusProto) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
mergeFrom(ReefServiceProtos.TaskStatusProto.TaskMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
 
mergeFrom(ResourceRequestEvent) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
Create a builder from an existing ResourceRequestEvent.
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
mergeFrom(ClassHierarchyProto.ClassNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
mergeFrom(ClassHierarchyProto.ConstructorArg) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
mergeFrom(ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
mergeFrom(ClassHierarchyProto.NamedParameterNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
mergeFrom(ClassHierarchyProto.Node) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
mergeFrom(ClassHierarchyProto.PackageNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
mergeFrom(InjectionPlanProto.Constructor) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
mergeFrom(InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
mergeFrom(InjectionPlanProto.Instance) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
mergeFrom(InjectionPlanProto.Subplan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
mergeFrom(WakeRemoteProtos.WakeMessagePBuf) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
mergeFrom(WakeRemoteProtos.WakeTuplePBuf) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
 
mergeFrom(Message) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
mergeFrom(TestProtos.TestEventPBuf) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
 
mergeIn(ParameterParser) - Method in class org.apache.reef.tang.formats.ParameterParser
 
mergeInstance(InjectionPlanProto.Instance) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
mergeJobControl(ClientRuntimeProtocol.JobControlProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
mergeJobStatus(ReefServiceProtos.JobStatusProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
mergeKillEvaluator(EvaluatorRuntimeProtocol.KillEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
mergeNamedParameterNode(ClassHierarchyProto.NamedParameterNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
mergePackageNode(ClassHierarchyProto.PackageNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
mergeRemoveContext(EvaluatorRuntimeProtocol.RemoveContextProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
mergeRuntimeError(ReefServiceProtos.RuntimeErrorProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
mergeStages(ArrayList<String>, ArrayList<String>) - Static method in class org.apache.reef.util.logging.LogParser
 
mergeStartTask(EvaluatorRuntimeProtocol.StartTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
mergeStopEvaluator(EvaluatorRuntimeProtocol.StopEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
mergeStopTask(EvaluatorRuntimeProtocol.StopTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
mergeSubplan(InjectionPlanProto.Subplan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
mergeSuspendTask(EvaluatorRuntimeProtocol.SuspendTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
mergeTaskStatus(ReefServiceProtos.TaskStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
MergingEventHandler<L,R> - Class in org.apache.reef.wake.impl
An EventHandler combines two events of different types into a single Pair of events.
MergingEventHandler(EventHandler<MergingEventHandler.Pair<L, R>>) - Constructor for class org.apache.reef.wake.impl.MergingEventHandler
 
MergingEventHandler.Pair<S1,S2> - Class in org.apache.reef.wake.impl
A pair having two independent typed items.
MergingIterator<T> - Class in org.apache.reef.io.storage
 
MergingIterator(Comparator<T>, Iterator<T>[]) - Constructor for class org.apache.reef.io.storage.MergingIterator
 
MESOS_MASTER_IP - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
The ip address of Mesos Master.
MESOS_SLAVE_PORT - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
The port number of Mesos Slave.
MesosClasspathProvider - Class in org.apache.reef.runtime.mesos
Access to the classpath according to the REEF file system standard.
MesosClientConfiguration - Class in org.apache.reef.runtime.mesos.client
A ConfigurationModule for the Mesos resource manager.
MesosClientConfiguration() - Constructor for class org.apache.reef.runtime.mesos.client.MesosClientConfiguration
 
MesosDriverConfiguration - Class in org.apache.reef.runtime.mesos.driver
Binds Driver's runtime event handlers.
MesosDriverConfiguration() - Constructor for class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
 
MesosErrorHandler - Class in org.apache.reef.runtime.mesos.util
ErrorHandler for MesosRemoteManager.
MesosExecutorId - Class in org.apache.reef.runtime.mesos.evaluator.parameters
Mesos Executor's id.
MesosExecutorId() - Constructor for class org.apache.reef.runtime.mesos.evaluator.parameters.MesosExecutorId
 
MesosMasterIp - Class in org.apache.reef.runtime.mesos.driver.parameters
The ip address of Mesos Master.
MesosMasterIp() - Constructor for class org.apache.reef.runtime.mesos.driver.parameters.MesosMasterIp
 
MesosRemoteManager - Class in org.apache.reef.runtime.mesos.util
Since the existing RemoteManager cannot use an additional codec, we need this additional RemoteManager to use MesosMessageCodec.
MesosRemoteManagerCodec - Class in org.apache.reef.runtime.mesos.util
EvaluatorControl codec.
MesosRemoteManagerCodec() - Constructor for class org.apache.reef.runtime.mesos.util.MesosRemoteManagerCodec
 
MesosSchedulerDriverExecutor - Class in org.apache.reef.runtime.mesos.driver
Handler for Mesos SchedulerDriver.
MesosSchedulerDriverExecutor() - Constructor for class org.apache.reef.runtime.mesos.driver.MesosSchedulerDriverExecutor
 
MesosSlavePort - Class in org.apache.reef.runtime.mesos.driver.parameters
The port number of Mesos Slave.
MesosSlavePort() - Constructor for class org.apache.reef.runtime.mesos.driver.parameters.MesosSlavePort
 
message - Variable in class org.apache.reef.bridge.message.BridgeInterop
Deprecated.
Message - Interface in org.apache.reef.io
A message from a REEF component.
Message<T> - Interface in org.apache.reef.io.network
Network message.
message - Variable in class org.apache.reef.io.watcher.common.AvroFailure
Deprecated.
message - Variable in class org.apache.reef.javabridge.avro.AvroFailedTask
Deprecated.
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
messageIdentifier - Variable in class org.apache.reef.bridge.message.Acknowledgement
Deprecated.
messageSourceId - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Deprecated.
messageSourceId - Variable in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Deprecated.
messageType - Variable in class org.apache.reef.bridge.message.BridgeInterop
Deprecated.
MessageType - Enum in org.apache.reef.bridge.message
 
MessagingTransportFactory - Class in org.apache.reef.wake.remote.transport.netty
Factory that creates a messaging transport.
Meter - Class in org.apache.reef.wake.metrics
Meter that monitors mean throughput and ewma (1m, 5m, 15m) throughput.
Meter(String) - Constructor for class org.apache.reef.wake.metrics.Meter
Constructs a meter.
min() - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
Computes the min of all entries in the Vector.
MIN_VERSION_KEEP_CONTAINERS_AVAILABLE - Static variable in class org.apache.reef.runtime.yarn.util.YarnTypes
 
MinEtaBroadcaster - Class in org.apache.reef.examples.group.bgd.operatornames
The name of the MinEta broadcast operator.
MinEtaBroadcaster() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.MinEtaBroadcaster
 
MinParts - Class in org.apache.reef.examples.group.bgd.parameters
Maximum Number of Iterations.
MinParts() - Constructor for class org.apache.reef.examples.group.bgd.parameters.MinParts
 
MINUTES - Static variable in class org.apache.reef.examples.group.utils.timer.Timer
 
MissingStartHandlerHandler - Class in org.apache.reef.wake.impl
The EventHandler used as the default for the Clock.StartHandler event.
MOCK_SLEEP_TIME - Static variable in class org.apache.reef.tang.examples.timer.TimerMock.TimerMockConf
 
ModelAndDescentDirectionBroadcaster - Class in org.apache.reef.examples.group.bgd.operatornames
Name of the broadcast operator used to send a model and descent direction during line search.
ModelAndDescentDirectionBroadcaster() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.ModelAndDescentDirectionBroadcaster
 
ModelBroadcaster - Class in org.apache.reef.examples.group.bgd.operatornames
The name of the broadcast operator used for model broadcasts.
ModelBroadcaster() - Constructor for class org.apache.reef.examples.group.bgd.operatornames.ModelBroadcaster
 
ModelBroadcaster - Class in org.apache.reef.examples.group.broadcast.parameters
Model broadcaster.
ModelBroadcaster() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.ModelBroadcaster
 
ModelDimensions - Class in org.apache.reef.examples.group.bgd.parameters
The dimensionality of the model learned.
ModelDimensions() - Constructor for class org.apache.reef.examples.group.bgd.parameters.ModelDimensions
 
ModelReceiveAckReduceFunction - Class in org.apache.reef.examples.group.broadcast
Reduce function for model receive acknowledgement.
ModelReceiveAckReduceFunction() - Constructor for class org.apache.reef.examples.group.broadcast.ModelReceiveAckReduceFunction
 
ModelReceiveAckReducer - Class in org.apache.reef.examples.group.broadcast.parameters
Reduce operator name for model receive acknowledgement.
ModelReceiveAckReducer() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.ModelReceiveAckReducer
 
MonotonicHashMap<T,U> - Class in org.apache.reef.tang.util
 
MonotonicHashMap() - Constructor for class org.apache.reef.tang.util.MonotonicHashMap
 
MonotonicHashSet<T> - Class in org.apache.reef.tang.util
 
MonotonicHashSet() - Constructor for class org.apache.reef.tang.util.MonotonicHashSet
 
MonotonicHashSet(Collection<T>) - Constructor for class org.apache.reef.tang.util.MonotonicHashSet
 
MonotonicHashSet(T...) - Constructor for class org.apache.reef.tang.util.MonotonicHashSet
 
MonotonicMultiHashMap<K,V> - Class in org.apache.reef.tang.util
 
MonotonicMultiHashMap() - Constructor for class org.apache.reef.tang.util.MonotonicMultiHashMap
 
MonotonicMultiMap<K,V> - Class in org.apache.reef.tang.util
 
MonotonicMultiMap() - Constructor for class org.apache.reef.tang.util.MonotonicMultiMap
 
MonotonicSet<T> - Class in org.apache.reef.tang.util
 
MonotonicSet() - Constructor for class org.apache.reef.tang.util.MonotonicSet
 
MonotonicSet(TreeSet<T>) - Constructor for class org.apache.reef.tang.util.MonotonicSet
 
MonotonicSet(Comparator<T>) - Constructor for class org.apache.reef.tang.util.MonotonicSet
 
MonotonicTreeMap<T,U> - Class in org.apache.reef.tang.util
 
MonotonicTreeMap() - Constructor for class org.apache.reef.tang.util.MonotonicTreeMap
 
MsgKey - Class in org.apache.reef.io.network.group.impl.driver
The key object used in map to aggregate msgs from.
MsgKey(String, String, ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Constructor for class org.apache.reef.io.network.group.impl.driver.MsgKey
 
MsgKey(GroupCommunicationMessage) - Constructor for class org.apache.reef.io.network.group.impl.driver.MsgKey
 
MSGS_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
MSGS_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
multAdd(double, ImmutableVector) - Method in class org.apache.reef.examples.group.utils.math.AbstractVector
 
multAdd(double, ImmutableVector) - Method in interface org.apache.reef.examples.group.utils.math.Vector
this += factor * that.
MultiCodec<T> - Class in org.apache.reef.wake.remote.impl
Codec using the WakeTuple protocol buffer.
MultiCodec(Map<Class<? extends T>, Codec<? extends T>>) - Constructor for class org.apache.reef.wake.remote.impl.MultiCodec
Constructs a codec that encodes/decodes an object to/from bytes based on the class name.
MultiDataCenterEvaluatorToPartitionStrategy - Class in org.apache.reef.io.data.loading.impl
This is an online version which satisfies requests based on the locations the users ask the data to be loaded, for multiple data center network topologies.
MultiDecoder<T> - Class in org.apache.reef.wake.remote.impl
Decoder using the WakeTuple protocol buffer.
MultiDecoder(Map<Class<? extends T>, Decoder<? extends T>>) - Constructor for class org.apache.reef.wake.remote.impl.MultiDecoder
Constructs a decoder that decodes bytes based on the class name.
MultiEncoder<T> - Class in org.apache.reef.wake.remote.impl
Encoder using the WakeTuple protocol buffer.
MultiEncoder(Map<Class<? extends T>, Encoder<? extends T>>) - Constructor for class org.apache.reef.wake.remote.impl.MultiEncoder
Constructs an encoder that encodes an object to bytes based on the class name.
MultiEventHandler<T> - Class in org.apache.reef.wake.impl
Event handler that dispatches an event to a specific handler based on an event class type.
MultiEventHandler(Map<Class<? extends T>, EventHandler<? extends T>>) - Constructor for class org.apache.reef.wake.impl.MultiEventHandler
Constructs a multi-event handler.
MultipleCommGroupsDriver - Class in org.apache.reef.tests.group
Driver used for testing multiple communication groups.
MultiRuntimeConfigurationBuilder - Class in org.apache.reef.runtime.multi.client
A builder for Multi Runtime Configuration.
MultiRuntimeConfigurationBuilder() - Constructor for class org.apache.reef.runtime.multi.client.MultiRuntimeConfigurationBuilder
 
MultiRuntimeDefinitionBuilder - Class in org.apache.reef.runtime.multi.client
Builder for multi runtime definition.
MultiRuntimeDefinitionBuilder() - Constructor for class org.apache.reef.runtime.multi.client.MultiRuntimeDefinitionBuilder
 
MultiRuntimeDefinitionGenerator - Interface in org.apache.reef.runtime.multi.client
Defines a contract for a multi runtime definition generator.
MultiRuntimeDefinitionSerializer - Class in org.apache.reef.runtime.multi.utils
Serializer for MultiRuntimeDefinition.
MultiRuntimeDefinitionSerializer() - Constructor for class org.apache.reef.runtime.multi.utils.MultiRuntimeDefinitionSerializer
 
MultiRuntimeDriverConfiguration - Class in org.apache.reef.runtime.multi.driver
ConfigurationModule for the multi-runtime Driver.
MultiRuntimeDriverConfiguration() - Constructor for class org.apache.reef.runtime.multi.driver.MultiRuntimeDriverConfiguration
 
MultiRuntimeYarnBootstrapREEFLauncher - Class in org.apache.reef.bridge.client
This is a bootstrap launcher for YARN for submission of multiruntime jobs from C#.

N

name - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Deprecated.
name - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Deprecated.
name - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Deprecated.
NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Name<T> - Interface in org.apache.reef.tang.annotations
 
name - Variable in class org.apache.reef.tang.implementation.avro.AvroNode
Deprecated.
name - Variable in class org.apache.reef.webserver.AvroEvaluatorEntry
Deprecated.
NAME_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
NAME_SERVER_CONFIGURATION - Static variable in class org.apache.reef.bridge.client.Constants
The name server configuration assumed by the bridge.
NAME_SERVER_HOSTNAME - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
DNS hostname running the name service.
NAME_SERVER_HOSTNAME - Static variable in class org.apache.reef.io.network.naming.NameServerConfiguration
DNS hostname running the name service.
NAME_SERVER_IDENTIFIER_FACTORY - Static variable in class org.apache.reef.io.network.naming.NameServerConfiguration
Identifier factory for the name service.
NAME_SERVICE_PORT - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
The port used by name server.
NAME_SERVICE_PORT - Static variable in class org.apache.reef.io.network.naming.NameServerConfiguration
The port used by name server.
NameAssignment - Interface in org.apache.reef.io.naming
Pair of an identifier and an address.
NameAssignmentTuple - Class in org.apache.reef.io.network.naming
An implementation of the NameAssignment interface.
NameAssignmentTuple(Identifier, InetSocketAddress) - Constructor for class org.apache.reef.io.network.naming.NameAssignmentTuple
Constructs a name assignment tuple.
NameCache - Class in org.apache.reef.io.network.naming
Naming cache implementation.
NameCache(long) - Constructor for class org.apache.reef.io.network.naming.NameCache
Constructs a naming cache.
NameClient - Class in org.apache.reef.io.network.naming
Naming client looking up remote server.
NAMED_PARAMETER_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
NAMED_PARAMETER_NODE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
NamedParameter - Annotation Type in org.apache.reef.tang.annotations
 
namedParameterName - Variable in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Deprecated.
namedParameterNode - Variable in class org.apache.reef.tang.implementation.avro.AvroNode
Deprecated.
NamedParameterNode<T> - Interface in org.apache.reef.tang.types
 
NamedParameterNodeImpl<T> - Class in org.apache.reef.tang.implementation.types
 
NamedParameterNodeImpl(Node, String, String, String, String, boolean, boolean, String, String, String[]) - Constructor for class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
NameLookupClient - Class in org.apache.reef.io.network.naming
Naming lookup client.
NameRegistryClient - Class in org.apache.reef.io.network.naming
Naming registry client.
NameResolutionException - Exception in org.apache.reef.tang.exceptions
Thrown when Tang encounters an unknown (to the current classloader) class or configuration option.
NameResolutionException(String, String) - Constructor for exception org.apache.reef.tang.exceptions.NameResolutionException
 
NameResolver - Interface in org.apache.reef.io.network.naming
NameClient interface.
NameResolverCacheTimeout - Class in org.apache.reef.io.network.naming.parameters
 
NameResolverCacheTimeout() - Constructor for class org.apache.reef.io.network.naming.parameters.NameResolverCacheTimeout
 
NameResolverConfiguration - Class in org.apache.reef.io.network.naming
Configuration Module Builder for NameResolver.
NameResolverConfiguration() - Constructor for class org.apache.reef.io.network.naming.NameResolverConfiguration
 
NameResolverIdentifierFactory - Class in org.apache.reef.io.network.naming.parameters
 
NameResolverIdentifierFactory() - Constructor for class org.apache.reef.io.network.naming.parameters.NameResolverIdentifierFactory
 
NameResolverNameServerAddr - Class in org.apache.reef.io.network.naming.parameters
 
NameResolverNameServerAddr() - Constructor for class org.apache.reef.io.network.naming.parameters.NameResolverNameServerAddr
 
NameResolverNameServerPort - Class in org.apache.reef.io.network.naming.parameters
 
NameResolverNameServerPort() - Constructor for class org.apache.reef.io.network.naming.parameters.NameResolverNameServerPort
 
NameResolverRetryCount - Class in org.apache.reef.io.network.naming.parameters
 
NameResolverRetryCount() - Constructor for class org.apache.reef.io.network.naming.parameters.NameResolverRetryCount
 
NameResolverRetryTimeout - Class in org.apache.reef.io.network.naming.parameters
 
NameResolverRetryTimeout() - Constructor for class org.apache.reef.io.network.naming.parameters.NameResolverRetryTimeout
 
NameServer - Interface in org.apache.reef.io.network.naming
Naming server interface.
NameServerConfiguration - Class in org.apache.reef.io.network.naming
Configuration Module Builder for NameServer.
NameServerConfiguration() - Constructor for class org.apache.reef.io.network.naming.NameServerConfiguration
 
NameServerImpl - Class in org.apache.reef.io.network.naming
Naming server implementation.
NameServerParameters - Class in org.apache.reef.io.network.naming
 
NameServerParameters() - Constructor for class org.apache.reef.io.network.naming.NameServerParameters
 
NameServerParameters.NameServerAddr - Class in org.apache.reef.io.network.naming
 
NameServerParameters.NameServerAddr() - Constructor for class org.apache.reef.io.network.naming.NameServerParameters.NameServerAddr
 
NameServerParameters.NameServerIdentifierFactory - Class in org.apache.reef.io.network.naming
 
NameServerParameters.NameServerIdentifierFactory() - Constructor for class org.apache.reef.io.network.naming.NameServerParameters.NameServerIdentifierFactory
 
NameServerParameters.NameServerPort - Class in org.apache.reef.io.network.naming
 
NameServerParameters.NameServerPort() - Constructor for class org.apache.reef.io.network.naming.NameServerParameters.NameServerPort
 
NameServiceCloseHandler - Class in org.apache.reef.io.network.impl
 
NameServiceCloseHandler(NameServer) - Constructor for class org.apache.reef.io.network.impl.NameServiceCloseHandler
 
Naming - Interface in org.apache.reef.io.naming
Implementations of this interface facilitate address lookups based on Identifiers and allow to register and unregister addresses for Identifiers.
NamingException - Exception in org.apache.reef.io.network.naming.exception
Naming exception.
NamingException(String, Throwable) - Constructor for exception org.apache.reef.io.network.naming.exception.NamingException
Constructs a new resourcemanager naming exception with the specified detail message and cause.
NamingException(String) - Constructor for exception org.apache.reef.io.network.naming.exception.NamingException
Constructs a new resourcemanager naming exception with the specified detail message.
NamingException(Throwable) - Constructor for exception org.apache.reef.io.network.naming.exception.NamingException
Constructs a new resourcemanager naming exception with the specified cause.
NamingLookup - Interface in org.apache.reef.io.naming
Implementations of this interface facilitate address lookups based on Identifiers.
NamingLookupRequest - Class in org.apache.reef.io.network.naming.serialization
Naming lookup request.
NamingLookupRequest(Iterable<Identifier>) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingLookupRequest
Constructs a naming lookup request.
NamingLookupRequestCodec - Class in org.apache.reef.io.network.naming.serialization
Naming lookup request codec.
NamingLookupRequestCodec(IdentifierFactory) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingLookupRequestCodec
Constructs a naming lookup request codec.
NamingLookupResponse - Class in org.apache.reef.io.network.naming.serialization
Naming lookup response.
NamingLookupResponse(List<NameAssignment>) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingLookupResponse
Constructs a naming lookup response.
NamingLookupResponseCodec - Class in org.apache.reef.io.network.naming.serialization
Naming lookup response codec.
NamingLookupResponseCodec(IdentifierFactory) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingLookupResponseCodec
Constructs a naming lookup response codec.
NamingMessage - Class in org.apache.reef.io.network.naming.serialization
An abstract base class for naming messages.
NamingMessage() - Constructor for class org.apache.reef.io.network.naming.serialization.NamingMessage
 
NamingRegisterRequest - Class in org.apache.reef.io.network.naming.serialization
naming registration request.
NamingRegisterRequest(NameAssignment) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingRegisterRequest
Constructs a naming registration request.
NamingRegisterRequestCodec - Class in org.apache.reef.io.network.naming.serialization
Naming registration request codec.
NamingRegisterRequestCodec(IdentifierFactory) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingRegisterRequestCodec
Constructs a naming registration request codec.
NamingRegisterResponse - Class in org.apache.reef.io.network.naming.serialization
naming registration response.
NamingRegisterResponse(NamingRegisterRequest) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingRegisterResponse
Constructs a naming register response.
NamingRegisterResponseCodec - Class in org.apache.reef.io.network.naming.serialization
naming registration response codec.
NamingRegisterResponseCodec(NamingRegisterRequestCodec) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingRegisterResponseCodec
Constructs a naming register response codec.
NamingRegistry - Interface in org.apache.reef.io.naming
Allows to register and unregister addresses for Identifiers.
NamingRuntimeException - Exception in org.apache.reef.io.network.naming.exception
Naming resourcemanager exception.
NamingRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.io.network.naming.exception.NamingRuntimeException
Constructs a new resourcemanager naming exception with the specified detail message and cause.
NamingRuntimeException(String) - Constructor for exception org.apache.reef.io.network.naming.exception.NamingRuntimeException
Constructs a new resourcemanager naming exception with the specified detail message.
NamingRuntimeException(Throwable) - Constructor for exception org.apache.reef.io.network.naming.exception.NamingRuntimeException
Constructs a new resourcemanager naming exception with the specified cause.
NamingUnregisterRequest - Class in org.apache.reef.io.network.naming.serialization
Naming un-registration request.
NamingUnregisterRequest(Identifier) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingUnregisterRequest
Constructs a naming un-registration request.
NamingUnregisterRequestCodec - Class in org.apache.reef.io.network.naming.serialization
Naming un-registration request codec.
NamingUnregisterRequestCodec(IdentifierFactory) - Constructor for class org.apache.reef.io.network.naming.serialization.NamingUnregisterRequestCodec
Constructs a naming un-registration request codec.
NativeBridge - Class in org.apache.reef.javabridge
Abstract bridge class.
NativeBridge() - Constructor for class org.apache.reef.javabridge.NativeBridge
 
NativeInterop - Class in org.apache.reef.javabridge
Java interfaces of CLR/Java bridge.
NettyLink<T> - Class in org.apache.reef.wake.remote.transport.netty
Link implementation with Netty.
NettyLink(Channel, Encoder<? super T>) - Constructor for class org.apache.reef.wake.remote.transport.netty.NettyLink
Constructs a link.
NettyLink(Channel, Encoder<? super T>, LinkListener<? super T>) - Constructor for class org.apache.reef.wake.remote.transport.netty.NettyLink
Constructs a link.
NettyMessagingTransport - Class in org.apache.reef.wake.remote.transport.netty
Messaging transport implementation with Netty.
NetworkConnectionService - Interface in org.apache.reef.io.network
NetworkConnectionService.
NetworkConnectionServiceExceptionHandler - Class in org.apache.reef.io.network.impl
Default exception handler.
NetworkConnectionServiceExceptionHandler() - Constructor for class org.apache.reef.io.network.impl.NetworkConnectionServiceExceptionHandler
 
NetworkConnectionServiceIdFactory - Class in org.apache.reef.io.network.impl.config
 
NetworkConnectionServiceIdFactory() - Constructor for class org.apache.reef.io.network.impl.config.NetworkConnectionServiceIdFactory
 
NetworkConnectionServiceImpl - Class in org.apache.reef.io.network.impl
Default Network connection service implementation.
NetworkConnectionServicePort - Class in org.apache.reef.io.network.impl.config
 
NetworkConnectionServicePort() - Constructor for class org.apache.reef.io.network.impl.config.NetworkConnectionServicePort
 
NetworkException - Exception in org.apache.reef.exception.evaluator
Network exception.
NetworkException(String, Throwable) - Constructor for exception org.apache.reef.exception.evaluator.NetworkException
 
NetworkException(String) - Constructor for exception org.apache.reef.exception.evaluator.NetworkException
 
NetworkException(Throwable) - Constructor for exception org.apache.reef.exception.evaluator.NetworkException
 
NetworkRuntimeException - Exception in org.apache.reef.io.network.exception
Network service resourcemanager exception.
NetworkRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.io.network.exception.NetworkRuntimeException
Constructs a new network resourcemanager exception with the specified detail message and cause.
NetworkRuntimeException(String) - Constructor for exception org.apache.reef.io.network.exception.NetworkRuntimeException
Constructs a new network resourcemanager exception with the specified detail message.
NetworkRuntimeException(Throwable) - Constructor for exception org.apache.reef.io.network.exception.NetworkRuntimeException
Constructs a new network resourcemanager exception with the specified cause.
NetworkService<T> - Class in org.apache.reef.io.network.impl
Network service for Task.
NetworkServiceClosingHandler - Class in org.apache.reef.io.network.impl
 
NetworkServiceClosingHandler(NetworkService<?>) - Constructor for class org.apache.reef.io.network.impl.NetworkServiceClosingHandler
 
NetworkServiceParameters - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters
 
NetworkServiceParameters.NetworkServiceCodec - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.NetworkServiceCodec() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.NetworkServiceCodec
 
NetworkServiceParameters.NetworkServiceExceptionHandler - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.NetworkServiceExceptionHandler() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.NetworkServiceExceptionHandler
 
NetworkServiceParameters.NetworkServiceHandler - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.NetworkServiceHandler() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.NetworkServiceHandler
 
NetworkServiceParameters.NetworkServiceIdentifierFactory - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.NetworkServiceIdentifierFactory() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.NetworkServiceIdentifierFactory
 
NetworkServiceParameters.NetworkServicePort - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.NetworkServicePort() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.NetworkServicePort
 
NetworkServiceParameters.NetworkServiceTransportFactory - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.NetworkServiceTransportFactory() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.NetworkServiceTransportFactory
 
NetworkServiceParameters.TaskId - Class in org.apache.reef.io.network.impl
 
NetworkServiceParameters.TaskId() - Constructor for class org.apache.reef.io.network.impl.NetworkServiceParameters.TaskId
 
newAllocationBuilder() - Static method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
newBuilder() - Static method in class org.apache.reef.bridge.message.Acknowledgement
Creates a new Acknowledgement RecordBuilder.
newBuilder(Acknowledgement.Builder) - Static method in class org.apache.reef.bridge.message.Acknowledgement
Creates a new Acknowledgement RecordBuilder by copying an existing Builder.
newBuilder(Acknowledgement) - Static method in class org.apache.reef.bridge.message.Acknowledgement
Creates a new Acknowledgement RecordBuilder by copying an existing Acknowledgement instance.
newBuilder() - Static method in class org.apache.reef.bridge.message.BridgeInterop
Creates a new BridgeInterop RecordBuilder.
newBuilder(BridgeInterop.Builder) - Static method in class org.apache.reef.bridge.message.BridgeInterop
Creates a new BridgeInterop RecordBuilder by copying an existing Builder.
newBuilder(BridgeInterop) - Static method in class org.apache.reef.bridge.message.BridgeInterop
Creates a new BridgeInterop RecordBuilder by copying an existing BridgeInterop instance.
newBuilder() - Static method in class org.apache.reef.bridge.message.Header
Creates a new Header RecordBuilder.
newBuilder(Header.Builder) - Static method in class org.apache.reef.bridge.message.Header
Creates a new Header RecordBuilder by copying an existing Builder.
newBuilder(Header) - Static method in class org.apache.reef.bridge.message.Header
Creates a new Header RecordBuilder by copying an existing Header instance.
newBuilder() - Static method in class org.apache.reef.bridge.message.Protocol
Creates a new Protocol RecordBuilder.
newBuilder(Protocol.Builder) - Static method in class org.apache.reef.bridge.message.Protocol
Creates a new Protocol RecordBuilder by copying an existing Builder.
newBuilder(Protocol) - Static method in class org.apache.reef.bridge.message.Protocol
Creates a new Protocol RecordBuilder by copying an existing Protocol instance.
newBuilder() - Static method in class org.apache.reef.bridge.message.SetupBridge
Creates a new SetupBridge RecordBuilder.
newBuilder(SetupBridge.Builder) - Static method in class org.apache.reef.bridge.message.SetupBridge
Creates a new SetupBridge RecordBuilder by copying an existing Builder.
newBuilder(SetupBridge) - Static method in class org.apache.reef.bridge.message.SetupBridge
Creates a new SetupBridge RecordBuilder by copying an existing SetupBridge instance.
newBuilder() - Static method in class org.apache.reef.bridge.message.SystemOnStart
Creates a new SystemOnStart RecordBuilder.
newBuilder(SystemOnStart.Builder) - Static method in class org.apache.reef.bridge.message.SystemOnStart
Creates a new SystemOnStart RecordBuilder by copying an existing Builder.
newBuilder(SystemOnStart) - Static method in class org.apache.reef.bridge.message.SystemOnStart
Creates a new SystemOnStart RecordBuilder by copying an existing SystemOnStart instance.
newBuilder() - Static method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Get a new builder.
newBuilder(EvaluatorRequest) - Static method in class org.apache.reef.driver.evaluator.EvaluatorRequest
Get a new builder from the existing request.
newBuilder() - Static method in class org.apache.reef.driver.restart.RestartEvaluators
 
newBuilder() - Static method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Creates a new AvroEvaluatorRequest RecordBuilder.
newBuilder(AvroEvaluatorRequest.Builder) - Static method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Creates a new AvroEvaluatorRequest RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorRequest) - Static method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Creates a new AvroEvaluatorRequest RecordBuilder by copying an existing AvroEvaluatorRequest instance.
newBuilder() - Static method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition
 
newBuilder() - Static method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec
 
newBuilder() - Static method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec
 
newBuilder() - Static method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec
 
newBuilder() - Static method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec
 
newBuilder() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Creates a new AvroNamingAssignment RecordBuilder.
newBuilder(AvroNamingAssignment.Builder) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Creates a new AvroNamingAssignment RecordBuilder by copying an existing Builder.
newBuilder(AvroNamingAssignment) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Creates a new AvroNamingAssignment RecordBuilder by copying an existing AvroNamingAssignment instance.
newBuilder() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Creates a new AvroNamingLookupRequest RecordBuilder.
newBuilder(AvroNamingLookupRequest.Builder) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Creates a new AvroNamingLookupRequest RecordBuilder by copying an existing Builder.
newBuilder(AvroNamingLookupRequest) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Creates a new AvroNamingLookupRequest RecordBuilder by copying an existing AvroNamingLookupRequest instance.
newBuilder() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Creates a new AvroNamingLookupResponse RecordBuilder.
newBuilder(AvroNamingLookupResponse.Builder) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Creates a new AvroNamingLookupResponse RecordBuilder by copying an existing Builder.
newBuilder(AvroNamingLookupResponse) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Creates a new AvroNamingLookupResponse RecordBuilder by copying an existing AvroNamingLookupResponse instance.
newBuilder() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Creates a new AvroNamingRegisterRequest RecordBuilder.
newBuilder(AvroNamingRegisterRequest.Builder) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Creates a new AvroNamingRegisterRequest RecordBuilder by copying an existing Builder.
newBuilder(AvroNamingRegisterRequest) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Creates a new AvroNamingRegisterRequest RecordBuilder by copying an existing AvroNamingRegisterRequest instance.
newBuilder() - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Creates a new AvroNamingUnRegisterRequest RecordBuilder.
newBuilder(AvroNamingUnRegisterRequest.Builder) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Creates a new AvroNamingUnRegisterRequest RecordBuilder by copying an existing Builder.
newBuilder(AvroNamingUnRegisterRequest) - Static method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Creates a new AvroNamingUnRegisterRequest RecordBuilder by copying an existing AvroNamingUnRegisterRequest instance.
newBuilder() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
newBuilder(ReefNetworkGroupCommProtos.GroupCommMessage) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
newBuilder() - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
newBuilder(ReefNetworkGroupCommProtos.GroupMessageBody) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
newBuilder() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
newBuilder(ReefNetworkServiceProtos.NSMessagePBuf) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
newBuilder() - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
newBuilder(ReefNetworkServiceProtos.NSRecordPBuf) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
newBuilder() - Static method in class org.apache.reef.io.watcher.common.AvroFailure
Creates a new AvroFailure RecordBuilder.
newBuilder(AvroFailure.Builder) - Static method in class org.apache.reef.io.watcher.common.AvroFailure
Creates a new AvroFailure RecordBuilder by copying an existing Builder.
newBuilder(AvroFailure) - Static method in class org.apache.reef.io.watcher.common.AvroFailure
Creates a new AvroFailure RecordBuilder by copying an existing AvroFailure instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Creates a new AvroNodeDescriptor RecordBuilder.
newBuilder(AvroNodeDescriptor.Builder) - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Creates a new AvroNodeDescriptor RecordBuilder by copying an existing Builder.
newBuilder(AvroNodeDescriptor) - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Creates a new AvroNodeDescriptor RecordBuilder by copying an existing AvroNodeDescriptor instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Creates a new AvroNodeDescriptorInRackDescriptor RecordBuilder.
newBuilder(AvroNodeDescriptorInRackDescriptor.Builder) - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Creates a new AvroNodeDescriptorInRackDescriptor RecordBuilder by copying an existing Builder.
newBuilder(AvroNodeDescriptorInRackDescriptor) - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Creates a new AvroNodeDescriptorInRackDescriptor RecordBuilder by copying an existing AvroNodeDescriptorInRackDescriptor instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Creates a new AvroRackDescriptor RecordBuilder.
newBuilder(AvroRackDescriptor.Builder) - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Creates a new AvroRackDescriptor RecordBuilder by copying an existing Builder.
newBuilder(AvroRackDescriptor) - Static method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Creates a new AvroRackDescriptor RecordBuilder by copying an existing AvroRackDescriptor instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Creates a new AvroActiveContext RecordBuilder.
newBuilder(AvroActiveContext.Builder) - Static method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Creates a new AvroActiveContext RecordBuilder by copying an existing Builder.
newBuilder(AvroActiveContext) - Static method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Creates a new AvroActiveContext RecordBuilder by copying an existing AvroActiveContext instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Creates a new AvroClosedContext RecordBuilder.
newBuilder(AvroClosedContext.Builder) - Static method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Creates a new AvroClosedContext RecordBuilder by copying an existing Builder.
newBuilder(AvroClosedContext) - Static method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Creates a new AvroClosedContext RecordBuilder by copying an existing AvroClosedContext instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Creates a new AvroContextBase RecordBuilder.
newBuilder(AvroContextBase.Builder) - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Creates a new AvroContextBase RecordBuilder by copying an existing Builder.
newBuilder(AvroContextBase) - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Creates a new AvroContextBase RecordBuilder by copying an existing AvroContextBase instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Creates a new AvroContextMessage RecordBuilder.
newBuilder(AvroContextMessage.Builder) - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Creates a new AvroContextMessage RecordBuilder by copying an existing Builder.
newBuilder(AvroContextMessage) - Static method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Creates a new AvroContextMessage RecordBuilder by copying an existing AvroContextMessage instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Creates a new AvroFailedContext RecordBuilder.
newBuilder(AvroFailedContext.Builder) - Static method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Creates a new AvroFailedContext RecordBuilder by copying an existing Builder.
newBuilder(AvroFailedContext) - Static method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Creates a new AvroFailedContext RecordBuilder by copying an existing AvroFailedContext instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Creates a new AvroAllocatedEvaluator RecordBuilder.
newBuilder(AvroAllocatedEvaluator.Builder) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Creates a new AvroAllocatedEvaluator RecordBuilder by copying an existing Builder.
newBuilder(AvroAllocatedEvaluator) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Creates a new AvroAllocatedEvaluator RecordBuilder by copying an existing AvroAllocatedEvaluator instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Creates a new AvroCompletedEvaluator RecordBuilder.
newBuilder(AvroCompletedEvaluator.Builder) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Creates a new AvroCompletedEvaluator RecordBuilder by copying an existing Builder.
newBuilder(AvroCompletedEvaluator) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Creates a new AvroCompletedEvaluator RecordBuilder by copying an existing AvroCompletedEvaluator instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Creates a new AvroEvaluatorDescriptor RecordBuilder.
newBuilder(AvroEvaluatorDescriptor.Builder) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Creates a new AvroEvaluatorDescriptor RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorDescriptor) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Creates a new AvroEvaluatorDescriptor RecordBuilder by copying an existing AvroEvaluatorDescriptor instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Creates a new AvroEvaluatorProcess RecordBuilder.
newBuilder(AvroEvaluatorProcess.Builder) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Creates a new AvroEvaluatorProcess RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorProcess) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Creates a new AvroEvaluatorProcess RecordBuilder by copying an existing AvroEvaluatorProcess instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Creates a new AvroFailedEvaluator RecordBuilder.
newBuilder(AvroFailedEvaluator.Builder) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Creates a new AvroFailedEvaluator RecordBuilder by copying an existing Builder.
newBuilder(AvroFailedEvaluator) - Static method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Creates a new AvroFailedEvaluator RecordBuilder by copying an existing AvroFailedEvaluator instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Creates a new AvroCompletedTask RecordBuilder.
newBuilder(AvroCompletedTask.Builder) - Static method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Creates a new AvroCompletedTask RecordBuilder by copying an existing Builder.
newBuilder(AvroCompletedTask) - Static method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Creates a new AvroCompletedTask RecordBuilder by copying an existing AvroCompletedTask instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Creates a new AvroFailedTask RecordBuilder.
newBuilder(AvroFailedTask.Builder) - Static method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Creates a new AvroFailedTask RecordBuilder by copying an existing Builder.
newBuilder(AvroFailedTask) - Static method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Creates a new AvroFailedTask RecordBuilder by copying an existing AvroFailedTask instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Creates a new AvroRunningTask RecordBuilder.
newBuilder(AvroRunningTask.Builder) - Static method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Creates a new AvroRunningTask RecordBuilder by copying an existing Builder.
newBuilder(AvroRunningTask) - Static method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Creates a new AvroRunningTask RecordBuilder by copying an existing AvroRunningTask instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Creates a new AvroSuspendedTask RecordBuilder.
newBuilder(AvroSuspendedTask.Builder) - Static method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Creates a new AvroSuspendedTask RecordBuilder by copying an existing Builder.
newBuilder(AvroSuspendedTask) - Static method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Creates a new AvroSuspendedTask RecordBuilder by copying an existing AvroSuspendedTask instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Creates a new AvroTaskMessage RecordBuilder.
newBuilder(AvroTaskMessage.Builder) - Static method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Creates a new AvroTaskMessage RecordBuilder by copying an existing Builder.
newBuilder(AvroTaskMessage) - Static method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Creates a new AvroTaskMessage RecordBuilder by copying an existing AvroTaskMessage instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Creates a new AvroStartTime RecordBuilder.
newBuilder(AvroStartTime.Builder) - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Creates a new AvroStartTime RecordBuilder by copying an existing Builder.
newBuilder(AvroStartTime) - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Creates a new AvroStartTime RecordBuilder by copying an existing AvroStartTime instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Creates a new AvroStopTime RecordBuilder.
newBuilder(AvroStopTime.Builder) - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Creates a new AvroStopTime RecordBuilder by copying an existing Builder.
newBuilder(AvroStopTime) - Static method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Creates a new AvroStopTime RecordBuilder by copying an existing AvroStopTime instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Creates a new AvroRuntimeStart RecordBuilder.
newBuilder(AvroRuntimeStart.Builder) - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Creates a new AvroRuntimeStart RecordBuilder by copying an existing Builder.
newBuilder(AvroRuntimeStart) - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Creates a new AvroRuntimeStart RecordBuilder by copying an existing AvroRuntimeStart instance.
newBuilder() - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Creates a new AvroRuntimeStop RecordBuilder.
newBuilder(AvroRuntimeStop.Builder) - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Creates a new AvroRuntimeStop RecordBuilder by copying an existing Builder.
newBuilder(AvroRuntimeStop) - Static method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Creates a new AvroRuntimeStop RecordBuilder by copying an existing AvroRuntimeStop instance.
newBuilder() - Static method in class org.apache.reef.javabridge.avro.AvroFailedTask
Creates a new AvroFailedTask RecordBuilder.
newBuilder(AvroFailedTask.Builder) - Static method in class org.apache.reef.javabridge.avro.AvroFailedTask
Creates a new AvroFailedTask RecordBuilder by copying an existing Builder.
newBuilder(AvroFailedTask) - Static method in class org.apache.reef.javabridge.avro.AvroFailedTask
Creates a new AvroFailedTask RecordBuilder by copying an existing AvroFailedTask instance.
newBuilder() - Static method in class org.apache.reef.javabridge.avro.DefinedRuntimes
Creates a new DefinedRuntimes RecordBuilder.
newBuilder(DefinedRuntimes.Builder) - Static method in class org.apache.reef.javabridge.avro.DefinedRuntimes
Creates a new DefinedRuntimes RecordBuilder by copying an existing Builder.
newBuilder(DefinedRuntimes) - Static method in class org.apache.reef.javabridge.avro.DefinedRuntimes
Creates a new DefinedRuntimes RecordBuilder by copying an existing DefinedRuntimes instance.
newBuilder() - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
newBuilder(ClientRuntimeProtocol.JobControlProto) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
newBuilder(EvaluatorRuntimeProtocol.AddContextProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
newBuilder(EvaluatorRuntimeProtocol.ContextControlProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
newBuilder(EvaluatorRuntimeProtocol.ContextMessageProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
newBuilder(EvaluatorRuntimeProtocol.DoneEvaluatorProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
newBuilder(EvaluatorRuntimeProtocol.EvaluatorControlProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
newBuilder(EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
newBuilder(EvaluatorRuntimeProtocol.KillEvaluatorProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
newBuilder(EvaluatorRuntimeProtocol.RemoveContextProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
newBuilder(EvaluatorRuntimeProtocol.StartTaskProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
newBuilder(EvaluatorRuntimeProtocol.StopEvaluatorProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
newBuilder(EvaluatorRuntimeProtocol.StopTaskProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
newBuilder() - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
newBuilder(EvaluatorRuntimeProtocol.SuspendTaskProto) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
newBuilder() - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
newBuilder(REEFProtocol.REEFMessage) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
newBuilder(ReefServiceProtos.ContextStatusProto.ContextMessageProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
newBuilder(ReefServiceProtos.ContextStatusProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
newBuilder(ReefServiceProtos.EvaluatorStatusProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
newBuilder(ReefServiceProtos.JobStatusProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
newBuilder(ReefServiceProtos.RuntimeErrorProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
newBuilder(ReefServiceProtos.TaskStatusProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
newBuilder() - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
newBuilder(ReefServiceProtos.TaskStatusProto.TaskMessageProto) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Creates a new AvroAppSubmissionParameters RecordBuilder.
newBuilder(AvroAppSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Creates a new AvroAppSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroAppSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Creates a new AvroAppSubmissionParameters RecordBuilder by copying an existing AvroAppSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Creates a new AvroJobSubmissionParameters RecordBuilder.
newBuilder(AvroJobSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Creates a new AvroJobSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroJobSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Creates a new AvroJobSubmissionParameters RecordBuilder by copying an existing AvroJobSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Creates a new AvroLocalAppSubmissionParameters RecordBuilder.
newBuilder(AvroLocalAppSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Creates a new AvroLocalAppSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroLocalAppSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Creates a new AvroLocalAppSubmissionParameters RecordBuilder by copying an existing AvroLocalAppSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Creates a new AvroLocalJobSubmissionParameters RecordBuilder.
newBuilder(AvroLocalJobSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Creates a new AvroLocalJobSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroLocalJobSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Creates a new AvroLocalJobSubmissionParameters RecordBuilder by copying an existing AvroLocalJobSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Creates a new AvroMultiRuntimeAppSubmissionParameters RecordBuilder.
newBuilder(AvroMultiRuntimeAppSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Creates a new AvroMultiRuntimeAppSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroMultiRuntimeAppSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Creates a new AvroMultiRuntimeAppSubmissionParameters RecordBuilder by copying an existing AvroMultiRuntimeAppSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Creates a new AvroYarnAppSubmissionParameters RecordBuilder.
newBuilder(AvroYarnAppSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Creates a new AvroYarnAppSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroYarnAppSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Creates a new AvroYarnAppSubmissionParameters RecordBuilder by copying an existing AvroYarnAppSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Creates a new AvroYarnClusterJobSubmissionParameters RecordBuilder.
newBuilder(AvroYarnClusterJobSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Creates a new AvroYarnClusterJobSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroYarnClusterJobSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Creates a new AvroYarnClusterJobSubmissionParameters RecordBuilder by copying an existing AvroYarnClusterJobSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Creates a new AvroYarnJobSubmissionParameters RecordBuilder.
newBuilder(AvroYarnJobSubmissionParameters.Builder) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Creates a new AvroYarnJobSubmissionParameters RecordBuilder by copying an existing Builder.
newBuilder(AvroYarnJobSubmissionParameters) - Static method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Creates a new AvroYarnJobSubmissionParameters RecordBuilder by copying an existing AvroYarnJobSubmissionParameters instance.
newBuilder() - Static method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.common.files.FileResourceImpl
 
newBuilder() - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Creates a new EvaluatorControl RecordBuilder.
newBuilder(EvaluatorControl.Builder) - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Creates a new EvaluatorControl RecordBuilder by copying an existing Builder.
newBuilder(EvaluatorControl) - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Creates a new EvaluatorControl RecordBuilder by copying an existing EvaluatorControl instance.
newBuilder() - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Creates a new EvaluatorLaunch RecordBuilder.
newBuilder(EvaluatorLaunch.Builder) - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Creates a new EvaluatorLaunch RecordBuilder by copying an existing Builder.
newBuilder(EvaluatorLaunch) - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Creates a new EvaluatorLaunch RecordBuilder by copying an existing EvaluatorLaunch instance.
newBuilder() - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Creates a new EvaluatorRelease RecordBuilder.
newBuilder(EvaluatorRelease.Builder) - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Creates a new EvaluatorRelease RecordBuilder by copying an existing Builder.
newBuilder(EvaluatorRelease) - Static method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Creates a new EvaluatorRelease RecordBuilder by copying an existing EvaluatorRelease instance.
newBuilder() - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Creates a new AvroMultiRuntimeDefinition RecordBuilder.
newBuilder(AvroMultiRuntimeDefinition.Builder) - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Creates a new AvroMultiRuntimeDefinition RecordBuilder by copying an existing Builder.
newBuilder(AvroMultiRuntimeDefinition) - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Creates a new AvroMultiRuntimeDefinition RecordBuilder by copying an existing AvroMultiRuntimeDefinition instance.
newBuilder() - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Creates a new AvroRuntimeDefinition RecordBuilder.
newBuilder(AvroRuntimeDefinition.Builder) - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Creates a new AvroRuntimeDefinition RecordBuilder by copying an existing Builder.
newBuilder(AvroRuntimeDefinition) - Static method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Creates a new AvroRuntimeDefinition RecordBuilder by copying an existing AvroRuntimeDefinition instance.
newBuilder() - Method in interface org.apache.reef.tang.Configuration
Create a new ConfigurationBuilder object based on the same classpath as this Configuration, and populate it with the configuration options of this object.
newBuilder() - Static method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Creates a new AvroConfiguration RecordBuilder.
newBuilder(AvroConfiguration.Builder) - Static method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Creates a new AvroConfiguration RecordBuilder by copying an existing Builder.
newBuilder(AvroConfiguration) - Static method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Creates a new AvroConfiguration RecordBuilder by copying an existing AvroConfiguration instance.
newBuilder() - Static method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Creates a new ConfigurationEntry RecordBuilder.
newBuilder(ConfigurationEntry.Builder) - Static method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Creates a new ConfigurationEntry RecordBuilder by copying an existing Builder.
newBuilder(ConfigurationEntry) - Static method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Creates a new ConfigurationEntry RecordBuilder by copying an existing ConfigurationEntry instance.
newBuilder() - Static method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Creates a new AvroClassNode RecordBuilder.
newBuilder(AvroClassNode.Builder) - Static method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Creates a new AvroClassNode RecordBuilder by copying an existing Builder.
newBuilder(AvroClassNode) - Static method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Creates a new AvroClassNode RecordBuilder by copying an existing AvroClassNode instance.
newBuilder() - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Creates a new AvroConstructorArg RecordBuilder.
newBuilder(AvroConstructorArg.Builder) - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Creates a new AvroConstructorArg RecordBuilder by copying an existing Builder.
newBuilder(AvroConstructorArg) - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Creates a new AvroConstructorArg RecordBuilder by copying an existing AvroConstructorArg instance.
newBuilder() - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Creates a new AvroConstructorDef RecordBuilder.
newBuilder(AvroConstructorDef.Builder) - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Creates a new AvroConstructorDef RecordBuilder by copying an existing Builder.
newBuilder(AvroConstructorDef) - Static method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Creates a new AvroConstructorDef RecordBuilder by copying an existing AvroConstructorDef instance.
newBuilder() - Static method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Creates a new AvroNamedParameterNode RecordBuilder.
newBuilder(AvroNamedParameterNode.Builder) - Static method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Creates a new AvroNamedParameterNode RecordBuilder by copying an existing Builder.
newBuilder(AvroNamedParameterNode) - Static method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Creates a new AvroNamedParameterNode RecordBuilder by copying an existing AvroNamedParameterNode instance.
newBuilder() - Static method in class org.apache.reef.tang.implementation.avro.AvroNode
Creates a new AvroNode RecordBuilder.
newBuilder(AvroNode.Builder) - Static method in class org.apache.reef.tang.implementation.avro.AvroNode
Creates a new AvroNode RecordBuilder by copying an existing Builder.
newBuilder(AvroNode) - Static method in class org.apache.reef.tang.implementation.avro.AvroNode
Creates a new AvroNode RecordBuilder by copying an existing AvroNode instance.
newBuilder() - Static method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
Creates a new AvroPackageNode RecordBuilder.
newBuilder(AvroPackageNode.Builder) - Static method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
Creates a new AvroPackageNode RecordBuilder by copying an existing Builder.
newBuilder(AvroPackageNode) - Static method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
Creates a new AvroPackageNode RecordBuilder by copying an existing AvroPackageNode instance.
newBuilder() - Method in class org.apache.reef.tang.implementation.ConfigurationImpl
 
newBuilder() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
newBuilder(ClassHierarchyProto.ClassNode) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
newBuilder() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
newBuilder(ClassHierarchyProto.ConstructorArg) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
newBuilder() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
newBuilder(ClassHierarchyProto.ConstructorDef) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
newBuilder() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
newBuilder(ClassHierarchyProto.NamedParameterNode) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
newBuilder() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
newBuilder(ClassHierarchyProto.Node) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
newBuilder() - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
newBuilder(ClassHierarchyProto.PackageNode) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
newBuilder() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
newBuilder(InjectionPlanProto.Constructor) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
newBuilder() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
newBuilder(InjectionPlanProto.InjectionPlan) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
newBuilder() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
newBuilder(InjectionPlanProto.Instance) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
newBuilder() - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
newBuilder(InjectionPlanProto.Subplan) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
newBuilder() - Static method in class org.apache.reef.vortex.api.VortexAggregatePolicy
 
newBuilder() - Static method in class org.apache.reef.vortex.driver.VortexJobConf
Create a Builder object for Vortex job configuration.
newBuilder() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
newBuilder(WakeRemoteProtos.WakeMessagePBuf) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
newBuilder() - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
newBuilder(WakeRemoteProtos.WakeTuplePBuf) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
newBuilder() - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
newBuilder(TestProtos.TestEventPBuf) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
newBuilder() - Static method in class org.apache.reef.webserver.AvroDriverInfo
Creates a new AvroDriverInfo RecordBuilder.
newBuilder(AvroDriverInfo.Builder) - Static method in class org.apache.reef.webserver.AvroDriverInfo
Creates a new AvroDriverInfo RecordBuilder by copying an existing Builder.
newBuilder(AvroDriverInfo) - Static method in class org.apache.reef.webserver.AvroDriverInfo
Creates a new AvroDriverInfo RecordBuilder by copying an existing AvroDriverInfo instance.
newBuilder() - Static method in class org.apache.reef.webserver.AvroEvaluatorEntry
Creates a new AvroEvaluatorEntry RecordBuilder.
newBuilder(AvroEvaluatorEntry.Builder) - Static method in class org.apache.reef.webserver.AvroEvaluatorEntry
Creates a new AvroEvaluatorEntry RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorEntry) - Static method in class org.apache.reef.webserver.AvroEvaluatorEntry
Creates a new AvroEvaluatorEntry RecordBuilder by copying an existing AvroEvaluatorEntry instance.
newBuilder() - Static method in class org.apache.reef.webserver.AvroEvaluatorInfo
Creates a new AvroEvaluatorInfo RecordBuilder.
newBuilder(AvroEvaluatorInfo.Builder) - Static method in class org.apache.reef.webserver.AvroEvaluatorInfo
Creates a new AvroEvaluatorInfo RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorInfo) - Static method in class org.apache.reef.webserver.AvroEvaluatorInfo
Creates a new AvroEvaluatorInfo RecordBuilder by copying an existing AvroEvaluatorInfo instance.
newBuilder() - Static method in class org.apache.reef.webserver.AvroEvaluatorList
Creates a new AvroEvaluatorList RecordBuilder.
newBuilder(AvroEvaluatorList.Builder) - Static method in class org.apache.reef.webserver.AvroEvaluatorList
Creates a new AvroEvaluatorList RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorList) - Static method in class org.apache.reef.webserver.AvroEvaluatorList
Creates a new AvroEvaluatorList RecordBuilder by copying an existing AvroEvaluatorList instance.
newBuilder() - Static method in class org.apache.reef.webserver.AvroEvaluatorsInfo
Creates a new AvroEvaluatorsInfo RecordBuilder.
newBuilder(AvroEvaluatorsInfo.Builder) - Static method in class org.apache.reef.webserver.AvroEvaluatorsInfo
Creates a new AvroEvaluatorsInfo RecordBuilder by copying an existing Builder.
newBuilder(AvroEvaluatorsInfo) - Static method in class org.apache.reef.webserver.AvroEvaluatorsInfo
Creates a new AvroEvaluatorsInfo RecordBuilder by copying an existing AvroEvaluatorsInfo instance.
newBuilder() - Static method in class org.apache.reef.webserver.AvroHttpRequest
Creates a new AvroHttpRequest RecordBuilder.
newBuilder(AvroHttpRequest.Builder) - Static method in class org.apache.reef.webserver.AvroHttpRequest
Creates a new AvroHttpRequest RecordBuilder by copying an existing Builder.
newBuilder(AvroHttpRequest) - Static method in class org.apache.reef.webserver.AvroHttpRequest
Creates a new AvroHttpRequest RecordBuilder by copying an existing AvroHttpRequest instance.
newBuilder() - Static method in class org.apache.reef.webserver.AvroReefServiceInfo
Creates a new AvroReefServiceInfo RecordBuilder.
newBuilder(AvroReefServiceInfo.Builder) - Static method in class org.apache.reef.webserver.AvroReefServiceInfo
Creates a new AvroReefServiceInfo RecordBuilder by copying an existing Builder.
newBuilder(AvroReefServiceInfo) - Static method in class org.apache.reef.webserver.AvroReefServiceInfo
Creates a new AvroReefServiceInfo RecordBuilder by copying an existing AvroReefServiceInfo instance.
newBuilder() - Static method in class org.apache.reef.webserver.HeaderEntry
Creates a new HeaderEntry RecordBuilder.
newBuilder(HeaderEntry.Builder) - Static method in class org.apache.reef.webserver.HeaderEntry
Creates a new HeaderEntry RecordBuilder by copying an existing Builder.
newBuilder(HeaderEntry) - Static method in class org.apache.reef.webserver.HeaderEntry
Creates a new HeaderEntry RecordBuilder by copying an existing HeaderEntry instance.
newBuilderForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
newBuilderForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
newBuilderForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
newBuilderForType() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
newBuilderForType() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
newBuilderForType() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
newBuilderForType() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
newBuilderForType() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
newBuilderForType() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
newBuilderForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
newBuilderForType() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
newBuilderForType() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
newCommunicationGroup(Class<? extends Name<String>>, int) - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
Create a new communication group with the specified name.
newCommunicationGroup(Class<? extends Name<String>>, int, int) - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
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.
newCommunicationGroup(Class<? extends Name<String>>, Class<? extends Topology>, int, int) - Method in interface org.apache.reef.io.network.group.api.driver.GroupCommDriver
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.
newCommunicationGroup(Class<? extends Name<String>>, int) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
newCommunicationGroup(Class<? extends Name<String>>, int, int) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
newCommunicationGroup(Class<? extends Name<String>>, Class<? extends Topology>, int, int) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommDriverImpl
 
newConfigurationBuilder() - Method in class org.apache.reef.tang.implementation.TangImpl
 
newConfigurationBuilder(ClassHierarchy) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newConfigurationBuilder(URL...) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newConfigurationBuilder(Configuration...) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newConfigurationBuilder(Class<? extends ExternalConstructor<?>>...) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newConfigurationBuilder(URL[], Configuration[], Class<? extends ExternalConstructor<?>>[]) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newConfigurationBuilder(ClassHierarchy) - Method in interface org.apache.reef.tang.Tang
Return a new ConfigurationBuilder that is backed by the provided ClassHierarchy object.
newConfigurationBuilder(URL...) - Method in interface org.apache.reef.tang.Tang
Create a new ConfigurationBuilder that is backed by the default classloader and the provided jars.
newConfigurationBuilder(Configuration...) - Method in interface org.apache.reef.tang.Tang
Merge a set of configurations into a new JavaConfiurationBuilder.
newConfigurationBuilder(Class<? extends ExternalConstructor<?>>...) - Method in interface org.apache.reef.tang.Tang
Create an empty JavaConfigurationBuilder that is capable of parsing application-specific configuration values.
newConfigurationBuilder(URL[], Configuration[], Class<? extends ExternalConstructor<?>>[]) - Method in interface org.apache.reef.tang.Tang
Create a new JavaConfiguration builder that has additional jars, incorporates existing configuration data and / or can parse application-specific types.
newConfigurationBuilder() - Method in interface org.apache.reef.tang.Tang
Create a new empty ConfigurationBuilder that is backed by the default classloader.
newConnection(Identifier) - Method in interface org.apache.reef.io.network.ConnectionFactory
Creates a new connection.
newConnection(Identifier) - Method in class org.apache.reef.io.network.impl.NetworkService
 
newEvaluatorProcess() - Method in class org.apache.reef.driver.evaluator.CLRProcessFactory
 
newEvaluatorProcess() - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcessFactory
 
newEvaluatorProcess() - Method in class org.apache.reef.driver.evaluator.JVMProcessFactory
 
newFile() - Method in class org.apache.reef.io.storage.local.LocalScratchSpace
 
newInjector(Configuration...) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newInjector(Configuration) - Method in class org.apache.reef.tang.implementation.TangImpl
 
newInjector() - Method in class org.apache.reef.tang.implementation.TangImpl
 
newInjector(Configuration...) - Method in interface org.apache.reef.tang.Tang
Returns an Injector for the given Configurations.
newInjector(Configuration) - Method in interface org.apache.reef.tang.Tang
Returns an Injector for the given Configuration.
newInjector() - Method in interface org.apache.reef.tang.Tang
Returns an Injector based on an empty Configuration.
newInstance() - Method in class org.apache.reef.examples.group.utils.math.DenseVector
 
newInstance() - Method in interface org.apache.reef.examples.group.utils.math.Vector
Create a new instance of the current type.
newInstance() - Method in class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration.FileSystemConstructor
 
newInstance() - Method in class org.apache.reef.io.data.loading.impl.InputFormatExternalConstructor
 
newInstance() - Method in class org.apache.reef.io.data.loading.impl.InputSplitExternalConstructor
 
newInstance() - Method in class org.apache.reef.io.data.loading.impl.JobConfExternalConstructor
 
newInstance() - Method in class org.apache.reef.runtime.hdinsight.client.sslhacks.DefaultClientConstructor
 
newInstance() - Method in class org.apache.reef.runtime.hdinsight.client.sslhacks.UnsafeClientConstructor
 
newInstance() - Method in class org.apache.reef.runtime.local.client.ExecutorServiceConstructor
 
newInstance() - Method in class org.apache.reef.runtime.mesos.util.HDFSConfigurationConstructor
 
newInstance() - Method in class org.apache.reef.runtime.yarn.util.YarnConfigurationConstructor
 
newInstance() - Method in interface org.apache.reef.tang.ExternalConstructor
This method will only be called once.
newInstance() - Method in class org.apache.reef.tang.util.ValidateConfiguration.FileParser
 
newInstance(int, EventHandler<TransportEvent>, EventHandler<TransportEvent>, EventHandler<Exception>) - Method in class org.apache.reef.wake.remote.transport.netty.MessagingTransportFactory
Creates a transport.
newInstance(String, int, EStage<TransportEvent>, EStage<TransportEvent>, int, int) - Method in class org.apache.reef.wake.remote.transport.netty.MessagingTransportFactory
Creates a transport.
newInstance(String, int, EStage<TransportEvent>, EStage<TransportEvent>, int, int, TcpPortProvider) - Method in class org.apache.reef.wake.remote.transport.netty.MessagingTransportFactory
Creates a transport.
newInstance(int, EventHandler<TransportEvent>, EventHandler<TransportEvent>, EventHandler<Exception>) - Method in interface org.apache.reef.wake.remote.transport.TransportFactory
Creates a transport.
newInstance(String, int, EStage<TransportEvent>, EStage<TransportEvent>, int, int) - Method in interface org.apache.reef.wake.remote.transport.TransportFactory
Creates a transport.
newInstance(String, int, EStage<TransportEvent>, EStage<TransportEvent>, int, int, TcpPortProvider) - Method in interface org.apache.reef.wake.remote.transport.TransportFactory
Creates a transport.
newRecoveryBuilder() - Static method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl
 
newRequest() - Method in interface org.apache.reef.driver.evaluator.EvaluatorRequestor
Get a new Builder for the evaluator with fluid interface.
newRequest() - Method in class org.apache.reef.runtime.common.driver.EvaluatorRequestorImpl
Get a new builder.
newThread(Runnable) - Method in class org.apache.reef.wake.impl.DefaultThreadFactory
Creates a new thread.
next() - Method in class org.apache.reef.io.storage.MergingIterator
 
nextFrame() - Method in class org.apache.reef.io.storage.FramingOutputStream
 
NO - Static variable in class org.apache.reef.runtime.common.client.parameters.ClientPresent
 
Node - Interface in org.apache.reef.tang.types
 
NODE_FOLDER - Static variable in class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
Folder to save the shaded jar for the remote nodes.
NODE_FOLDER - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
Folder to save the shaded jar for the remote nodes.
NODE_INFO_SET - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
Set of objects containing information about the nodes.
NODE_LIST_FILE_PATH - Static variable in class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
The file containing a list of remote ssh nodes (i.e.
NODE_LIST_FILE_PATH - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
The file containing a list of remote ssh nodes (i.e.
NodeDescriptor - Interface in org.apache.reef.driver.catalog
Descriptor of the physical setup of an Evaluator.
nodeDescriptor - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Deprecated.
NodeDescriptorEvent - Interface in org.apache.reef.runtime.common.driver.resourcemanager
Event from Driver Runtime to Driver Process.
NodeDescriptorEventImpl - Class in org.apache.reef.runtime.common.driver.resourcemanager
Default POJO implementation of NodeDescriptorEvent.
NodeDescriptorEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.resourcemanager
Builder used to create NodeDescriptorEvent instances.
NodeDescriptorEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
NodeDescriptorHandler - Class in org.apache.reef.runtime.common.driver.resourcemanager
Updates the ResourceCatalog with a new Node.
NodeDescriptorHandler(ResourceCatalogImpl) - Constructor for class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorHandler
 
NodeDescriptorImpl - Class in org.apache.reef.runtime.common.driver.catalog
Descriptor of the physical setup of an Evaluator.
NodeFolder - Class in org.apache.reef.runtime.standalone.client.parameters
The folder where required jar files shall be stored.
nodeId - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
NodeInfoSet - Class in org.apache.reef.runtime.standalone.client.parameters
Information of remote nodes available in the standalone runtime.
NodeInfoSet() - Constructor for class org.apache.reef.runtime.standalone.client.parameters.NodeInfoSet
 
NodeListFilePath - Class in org.apache.reef.runtime.standalone.client.parameters
The file which will contain information of remote nodes.
nodeName - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
nodeNames - Variable in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Deprecated.
nodes - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Deprecated.
NodeStruct - Interface in org.apache.reef.io.network.group.api.task
The actual node that is part of the operator topology Receives data from the handlers and provides them to the operators/OperatorTopologyStruct when they need it.
NodeStructImpl - Class in org.apache.reef.io.network.group.impl.task
 
NodeStructImpl(String, int) - Constructor for class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
NodeVisitor<T> - Interface in org.apache.reef.tang.util.walk
Generic interface to traverse nodes of the configuration graph.
NonBlockingJoin - Class in org.apache.reef.wake.examples.join
Non-blocking Join.
NonBlockingJoin(Observer<TupleEvent>) - Constructor for class org.apache.reef.wake.examples.join.NonBlockingJoin
 
NONE - Static variable in class org.apache.reef.runtime.common.driver.parameters.ClientRemoteIdentifier
Indicates that there is no Client.
NONE - Static variable in class org.apache.reef.runtime.common.launch.parameters.ErrorHandlerRID
Indicates that no ErrorHandler is bound.
NonSerializableException - Exception in org.apache.reef.exception
An Exception that indicates that an Exception from the Evaluator was not able to be serialized.
NonSerializableException(String, byte[]) - Constructor for exception org.apache.reef.exception.NonSerializableException
 
NoOpHttpServerImpl - Class in org.apache.reef.webserver
Empty implementation for the HttpServer.
NoopTask - Class in org.apache.reef.tests.fail.driver
A basic task that quite successfully does nothing.
NoopTask() - Constructor for class org.apache.reef.tests.fail.driver.NoopTask
 
NoopTask - Class in org.apache.reef.tests.library.tasks
A Task that does nothing and returns null.
NoopTask.DriverMessageHandler - Class in org.apache.reef.tests.fail.driver
Handler for DriverMessage.
NoopTask.DriverMessageHandler() - Constructor for class org.apache.reef.tests.fail.driver.NoopTask.DriverMessageHandler
 
NoopTask.TaskCloseHandler - Class in org.apache.reef.tests.fail.driver
Handler for CloseEvent.
NoopTask.TaskCloseHandler() - Constructor for class org.apache.reef.tests.fail.driver.NoopTask.TaskCloseHandler
 
NoopTask.TaskStopHandler - Class in org.apache.reef.tests.fail.driver
Handler for TaskStop.
NoopTask.TaskStopHandler() - Constructor for class org.apache.reef.tests.fail.driver.NoopTask.TaskStopHandler
 
NoopTask.TaskSuspendHandler - Class in org.apache.reef.tests.fail.driver
Handler for SuspendEvent.
NoopTask.TaskSuspendHandler() - Constructor for class org.apache.reef.tests.fail.driver.NoopTask.TaskSuspendHandler
 
norm2() - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
Computes the L2 norm of this Vector.
norm2Sqr() - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
Computes the square of the L2 norm of this Vector.
normalize() - Method in class org.apache.reef.examples.group.utils.math.AbstractVector
 
normalize() - Method in interface org.apache.reef.examples.group.utils.math.Vector
Normalizes the Vector according to the L2 norm.
notContains(V) - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
NotFoundException - Exception in org.apache.reef.examples.scheduler.driver.exceptions
An object specified in the operation was not found.
NotFoundException(String) - Constructor for exception org.apache.reef.examples.scheduler.driver.exceptions.NotFoundException
 
notNull(T) - Static method in class org.apache.reef.util.BuilderUtils
Throws a runtime exception if the parameter is null.
now() - Method in interface org.apache.reef.util.cache.CurrentTime
 
now() - Method in class org.apache.reef.util.cache.SystemTime
 
NSMessage<T> - Class in org.apache.reef.io.network.impl
Network service message that implements the Message interface.
NSMessage(Identifier, Identifier, T) - Constructor for class org.apache.reef.io.network.impl.NSMessage
Constructs a network service message.
NSMessage(Identifier, Identifier, List<T>) - Constructor for class org.apache.reef.io.network.impl.NSMessage
Constructs a network service message.
NSMessageCodec<T> - Class in org.apache.reef.io.network.impl
Network service message codec.
NSMessageCodec(Codec<T>, IdentifierFactory) - Constructor for class org.apache.reef.io.network.impl.NSMessageCodec
Constructs a network service message codec.
nullToEmpty(T[]) - Static method in class org.apache.reef.util.CollectionUtils
Return an empty array if input is null; works as identity function otherwise.
NUM_OF_THREADS - Static variable in class org.apache.reef.vortex.driver.VortexWorkerConf
Worker Threads.
NUM_OF_VORTEX_START_THREAD - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Number of Vortex Start threads.
number - Variable in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Deprecated.
Numberable - Interface in org.apache.reef.io
Interface for objects which can form ordered sequences, e.g.
NumberedSplit<E> - Class in org.apache.reef.io.data.loading.impl
A tuple of an object of type E and an integer index.
NumberedSplit(E, int, DistributedDataSetPartition) - Constructor for class org.apache.reef.io.data.loading.impl.NumberedSplit
 
numberOfCores - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Deprecated.
NumberOfReceivers - Class in org.apache.reef.examples.group.bgd.parameters
 
NumberOfReceivers() - Constructor for class org.apache.reef.examples.group.bgd.parameters.NumberOfReceivers
 
NumberOfReceivers - Class in org.apache.reef.examples.group.broadcast.parameters
 
NumberOfReceivers() - Constructor for class org.apache.reef.examples.group.broadcast.parameters.NumberOfReceivers
 
NumEvaluatorsToFail - Class in org.apache.reef.tests.evaluator.failure.parameters
The number of Evaluators to fail and resubmit in FailureDriver.
NumEvaluatorsToSubmit - Class in org.apache.reef.tests.evaluator.failure.parameters
The number of Evaluators to submit in FailureDriver.
NumSplits - Class in org.apache.reef.examples.group.bgd.parameters
Number of splits.
NumSplits() - Constructor for class org.apache.reef.examples.group.bgd.parameters.NumSplits
 

O

objectGraphToString() - Method in class org.apache.reef.wake.profiler.WakeProfiler
 
ObjectInstantiationLogger - Class in org.apache.reef.util
A utility class used as a default at times.
ObjectInstantiationLogger() - Constructor for class org.apache.reef.util.ObjectInstantiationLogger
 
ObjectSerializableCodec<T> - Class in org.apache.reef.wake.remote.impl
Codec that uses Java serialization.
ObjectSerializableCodec() - Constructor for class org.apache.reef.wake.remote.impl.ObjectSerializableCodec
 
ObjectWritableCodec<T extends org.apache.hadoop.io.Writable> - Class in org.apache.reef.examples.suspend
Codec for Hadoop Writable object serialization.
ObjectWritableCodec(Class<? extends T>) - Constructor for class org.apache.reef.examples.suspend.ObjectWritableCodec
Create a new codec for Hadoop Writables.
Observable - Interface in org.apache.reef.wake.rx
Defines a provider for push-based notification.
Observer<T> - Interface in org.apache.reef.wake.rx
Provides a mechanism for receiving push-based notifications.
ObserverCompletedException - Exception in org.apache.reef.wake.rx.exception
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.
ObserverCompletedException() - Constructor for exception org.apache.reef.wake.rx.exception.ObserverCompletedException
 
of(T) - Static method in class org.apache.reef.util.Optional
 
offset - Variable in class org.apache.reef.bridge.message.Protocol
Deprecated.
ofNullable(T) - Static method in class org.apache.reef.util.Optional
 
ON_CLIENT_CLOSED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for close messages sent by the client.
ON_CLIENT_CLOSED_MESSAGE - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for close messages sent by the client.
ON_CLIENT_MESSAGE - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for client messages.
ON_CLOSE - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Handler for closure requests from the driver.
ON_CONTEXT_ACTIVE - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for active context.
ON_CONTEXT_ACTIVE - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for active context.
ON_CONTEXT_CLOSED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for closed context.
ON_CONTEXT_CLOSED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for closed context.
ON_CONTEXT_FAILED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for closed context.
ON_CONTEXT_FAILED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for closed context.
ON_CONTEXT_MESSAGE - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for context messages.
ON_CONTEXT_MESSAGE - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for context messages.
ON_CONTEXT_STARTED - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Event handler for context start.
ON_CONTEXT_STARTED - Static variable in class org.apache.reef.driver.context.ServiceConfiguration
Event handler for context start.
ON_CONTEXT_STOP - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Event handler for context stop.
ON_CONTEXT_STOP - Static variable in class org.apache.reef.driver.context.ServiceConfiguration
Event handler for context stop.
ON_DRIVER_RECONNECT - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Implementation for reconnecting to driver after driver restart.
ON_DRIVER_RESTART_COMPLETED - Static variable in class org.apache.reef.client.DriverRestartConfiguration
Event handler for the event of driver restart completion, default to logging if not bound.
ON_DRIVER_RESTART_CONTEXT_ACTIVE - Static variable in class org.apache.reef.client.DriverRestartConfiguration
Event handler for active context when driver restart.
ON_DRIVER_RESTART_EVALUATOR_FAILED - Static variable in class org.apache.reef.client.DriverRestartConfiguration
Event handler for the event of driver restart completion, default to logging if not bound.
ON_DRIVER_RESTART_TASK_RUNNING - Static variable in class org.apache.reef.client.DriverRestartConfiguration
Event handler for running tasks in previous evaluator, when driver restarted.
ON_DRIVER_RESTARTED - Static variable in class org.apache.reef.client.DriverRestartConfiguration
This event is fired in place of the ON_DRIVER_STARTED when the Driver is in fact restarted after failure.
ON_DRIVER_RESTARTED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
The event handler invoked right after the driver restarts.
ON_DRIVER_STARTED - Static variable in class org.apache.reef.client.DriverConfiguration
The event handler invoked right after the driver boots up.
ON_DRIVER_STARTED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
The event handler invoked right after the driver boots up.
ON_DRIVER_STOP - Static variable in class org.apache.reef.client.DriverConfiguration
The event handler invoked right before the driver shuts down.
ON_DRIVER_STOP - Static variable in class org.apache.reef.client.DriverServiceConfiguration
The event handler invoked right before the driver shuts down.
ON_EVALUATOR_ALLOCATED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for allocated evaluators.
ON_EVALUATOR_ALLOCATED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for allocated evaluators.
ON_EVALUATOR_COMPLETED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for completed evaluators.
ON_EVALUATOR_COMPLETED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for completed evaluators.
ON_EVALUATOR_FAILED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for failed evaluators.
ON_EVALUATOR_FAILED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for failed evaluators.
ON_JOB_COMPLETED - Static variable in class org.apache.reef.client.ClientConfiguration
Handler for the event when a submitted REEF Job is completed.
ON_JOB_FAILED - Static variable in class org.apache.reef.client.ClientConfiguration
Handler for the event when a submitted REEF Job has failed.
ON_JOB_MESSAGE - Static variable in class org.apache.reef.client.ClientConfiguration
Event handler for messages from the running job.
ON_JOB_RUNNING - Static variable in class org.apache.reef.client.ClientConfiguration
Handler for the event when a submitted REEF Job is running.
ON_JOB_SUBMITTED - Static variable in class org.apache.reef.client.ClientConfiguration
Handler for the event when a REEF job is submitted to the Resource Manager.
ON_MESSAGE - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Driver has sent the context a message, and this parameter is used to register a handler on the context for processing that message.
ON_MESSAGE - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Handler for messages from the driver.
ON_RUNTIME_ERROR - Static variable in class org.apache.reef.client.ClientConfiguration
Receives fatal resourcemanager errors.
ON_SEND_MESSAGE - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Source of messages to be called whenever the evaluator is about to make a heartbeat.
ON_SEND_MESSAGE - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Message source invoked upon each evaluator heartbeat.
ON_SUSPEND - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Handler for task suspension.
ON_TASK_COMPLETED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for completed tasks.
ON_TASK_COMPLETED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for completed tasks.
ON_TASK_FAILED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for failed tasks.
ON_TASK_FAILED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for failed tasks.
ON_TASK_MESSAGE - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for task messages.
ON_TASK_MESSAGE - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for task messages.
ON_TASK_RUNNING - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for running tasks.
ON_TASK_RUNNING - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for running tasks.
ON_TASK_STARTED - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Event handlers to be informed right before a Task enters its call() method.
ON_TASK_STARTED - Static variable in class org.apache.reef.driver.context.ServiceConfiguration
Event handlers to be informed right before a Task enters its call() method.
ON_TASK_STARTED - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Event handler to receive TaskStart after the Task.call() method was called.
ON_TASK_STOP - Static variable in class org.apache.reef.driver.context.ContextConfiguration
Event handlers to be informed right after a Task exits its call() method.
ON_TASK_STOP - Static variable in class org.apache.reef.driver.context.ServiceConfiguration
Event handlers to be informed right after a Task exits its call() method.
ON_TASK_STOP - Static variable in class org.apache.reef.driver.task.TaskConfiguration
Event handler to receive TaskStop after the Task.call() method returned.
ON_TASK_SUSPENDED - Static variable in class org.apache.reef.client.DriverConfiguration
Event handler for suspended tasks.
ON_TASK_SUSPENDED - Static variable in class org.apache.reef.client.DriverServiceConfiguration
Event handler for suspended tasks.
ON_WAKE_ERROR - Static variable in class org.apache.reef.client.ClientConfiguration
Error handler for events on Wake-spawned threads.
onChildDead(String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onChildDead(String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
onChildRunning(String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onChildRunning(String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
onClientKill() - Method in class org.apache.reef.webserver.ReefEventStateManager
Kill driver by calling onComplete() .
onComplete() - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Perform a clean shutdown of the Driver.
onCompleted() - Method in class org.apache.reef.wake.examples.join.EventPrinter
 
onCompleted() - Method in class org.apache.reef.wake.rx.AbstractObserver
 
onCompleted() - Method in class org.apache.reef.wake.rx.impl.RxSyncStage
Notifies the observer that the provider has finished sending push-based notifications.
onCompleted() - Method in class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Notifies the observer that the provider has finished sending push-based notifications.
onCompleted() - Method in class org.apache.reef.wake.rx.impl.SimpleSubject
Provides the observer with it has finished sending push-based notifications.
onCompleted() - Method in interface org.apache.reef.wake.rx.Observer
Notifies the observer that the provider has finished sending push-based notifications.
onContainerRequest(AMRMClient.ContainerRequest...) - Method in interface org.apache.reef.runtime.yarn.driver.YarnContainerRequestHandler
Enqueue a set of container requests with YARN.
onContainerRequest(AMRMClient.ContainerRequest...) - Method in class org.apache.reef.runtime.yarn.driver.YarnContainerRequestHandlerImpl
 
onContextActive(ActiveContext) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onContextClose(ClosedContext) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onContextFailed(FailedContext) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onContextMessage(ContextMessage) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onContextStatusMessages(Iterable<ContextStatusPOJO>, boolean) - Method in class org.apache.reef.runtime.common.driver.context.ContextRepresenters
Process heartbeats from the contexts on an Evaluator.
onDriverRestartContextActive(ActiveContext) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onDriverRestartEvaluatorFailed(FailedEvaluator) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onDriverRestartTaskRunning(RunningTask) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
OnDriverStartedAllocateOne - Class in org.apache.reef.tests.library.driver
A Driver start handler that requests a single Evaluator of size 64MB.
OnDriverStartedAllocateOneInRack - Class in org.apache.reef.tests.rack.awareness
A Driver start handler that requests a single Evaluator of size 64MB in the specified rack.
ONE_MINUTE - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
onError(String) - Method in class org.apache.reef.javabridge.NativeBridge
 
onError(Throwable) - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
End the Driver with an exception.
onError(Exception) - Method in class org.apache.reef.wake.examples.join.EventPrinter
 
onError(Exception) - Method in class org.apache.reef.wake.rx.AbstractObserver
 
onError(Exception) - Method in class org.apache.reef.wake.rx.impl.RxSyncStage
Notifies the observer that the provider has experienced an error condition.
onError(Exception) - Method in class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Notifies the observer that the provider has experienced an error condition.
onError(Exception) - Method in class org.apache.reef.wake.rx.impl.SimpleSubject
Provides the observer with the error.
onError(Exception) - Method in interface org.apache.reef.wake.rx.Observer
Notifies the observer that the provider has experienced an error condition.
onEvaluatorAllocated(AllocatedEvaluator) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onEvaluatorCompleted(CompletedEvaluator) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onEvaluatorException(EvaluatorException) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
EvaluatorException will trigger is FailedEvaluator and state transition to FAILED.
onEvaluatorExit(String) - Method in class org.apache.reef.runtime.local.driver.ResourceManager
Called when the ReefRunnableProcessObserver detects that the Evaluator process has exited.
onEvaluatorFailed(FailedEvaluator) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onEvaluatorHeartbeatMessage(RemoteMessage<EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto>) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Process an evaluator heartbeat message.
onEvaluatorLaunch(EvaluatorLaunch) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
onEvaluatorRelease(EvaluatorRelease) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
onEvent(EventType, String) - Method in interface org.apache.reef.io.watcher.EventStream
Write an eventRecord with specific type.
onEvent(EventType, String) - Method in class org.apache.reef.io.watcher.FileEventStream
 
onEvent(EventType, String) - Method in class org.apache.reef.io.watcher.LogEventStream
 
onEvent(EventType, String) - Method in class org.apache.reef.tests.watcher.TestEventStream
 
onException(Throwable, SocketAddress, T) - Method in interface org.apache.reef.wake.remote.transport.LinkListener
Called when the sent message to remoteAddress is failed to be transferred.
onException(Throwable, SocketAddress, T) - Method in class org.apache.reef.wake.remote.transport.netty.LoggingLinkListener
Called when the sent message to remoteAddress is failed to be transferred.
onFailedTask() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onFailedTask(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Update state on receipt of FailedTask.
onFailedTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
onFailedTask() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
* Methods pertaining to my status change ***.
onFailedTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
onFailure(Throwable) - Method in interface org.apache.reef.vortex.api.FutureCallback
Invoked with the error of the Tasklet computation on failure.
onHttpRequest(ParsedHttpRequest, HttpServletResponse) - Method in class org.apache.reef.examples.scheduler.driver.http.SchedulerHttpHandler
HttpRequest handler.
onHttpRequest(ParsedHttpRequest, HttpServletResponse) - Method in interface org.apache.reef.webserver.HttpHandler
Will be called when request comes.
onHttpRequest(ParsedHttpRequest, HttpServletResponse) - Method in class org.apache.reef.webserver.HttpServerReefEventHandler
Event handler that is called when receiving a http request.
onInit() - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Changes the driver status to INIT and sends message to the client about the transition.
onNext(CompletedJob) - Method in class org.apache.reef.client.DriverLauncher.CompletedJobHandler
 
onNext(FailedJob) - Method in class org.apache.reef.client.DriverLauncher.FailedJobHandler
 
onNext(RunningJob) - Method in class org.apache.reef.client.DriverLauncher.RunningJobHandler
 
onNext(FailedRuntime) - Method in class org.apache.reef.client.DriverLauncher.RuntimeErrorHandler
 
onNext(SubmittedJob) - Method in class org.apache.reef.client.DriverLauncher.SubmittedJobHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.driver.restart.EvaluatorPreservingEvaluatorAllocatedHandler
Records the allocatedEvaluator ID with the DriverRuntimeRestartManager.
onNext(CompletedEvaluator) - Method in class org.apache.reef.driver.restart.EvaluatorPreservingEvaluatorCompletedHandler
Removes the completed evaluator from the list of evaluators to recover once it is completed.
onNext(FailedEvaluator) - Method in class org.apache.reef.driver.restart.EvaluatorPreservingEvaluatorFailedHandler
Removes the completed evaluator from the list of evaluators to recover once it is failed.
onNext(byte[]) - Method in interface org.apache.reef.evaluator.context.ContextMessageHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.examples.data.loading.LineCounter.ContextActiveHandler
 
onNext(CompletedTask) - Method in class org.apache.reef.examples.data.loading.LineCounter.TaskCompletedHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.examples.data.output.OutputServiceDriver.ActiveContextHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.examples.data.output.OutputServiceDriver.EvaluatorAllocatedHandler
 
onNext(StartTime) - Method in class org.apache.reef.examples.data.output.OutputServiceDriver.StartHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.examples.group.broadcast.BroadcastDriver.ContextActiveHandler
 
onNext(ClosedContext) - Method in class org.apache.reef.examples.group.broadcast.BroadcastDriver.ContextCloseHandler
 
onNext(FailedTask) - Method in class org.apache.reef.examples.group.broadcast.BroadcastDriver.FailedTaskHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.examples.hello.HelloDriver.EvaluatorAllocatedHandler
 
onNext(StartTime) - Method in class org.apache.reef.examples.hello.HelloDriver.StartHandler
 
onNext(DriverRestarted) - Method in class org.apache.reef.examples.hello.HelloDriverRestart.DriverRestartHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.examples.hello.HelloJVMOptionsDriver.EvaluatorAllocatedHandler
 
onNext(StartTime) - Method in class org.apache.reef.examples.hello.HelloJVMOptionsDriver.StartHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.examples.hellomultiruntime.HelloMultiRuntimeDriver.EvaluatorAllocatedHandler
 
onNext(StartTime) - Method in class org.apache.reef.examples.hellomultiruntime.HelloMultiRuntimeDriver.StartHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver.ActiveContextHandler
 
onNext(CompletedTask) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver.CompletedTaskHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver.EvaluatorAllocatedHandler
 
onNext(StartTime) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver.StartHandler
 
onNext(SuspendEvent) - Method in class org.apache.reef.examples.suspend.SuspendTestTask.SuspendHandler
 
onNext(T) - Method in class org.apache.reef.examples.utils.wake.BlockingEventHandler
 
onNext(T) - Method in class org.apache.reef.examples.utils.wake.LoggingEventHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.io.data.loading.api.DataLoader.EvaluatorAllocatedHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.io.data.loading.api.DataLoader.EvaluatorFailedHandler
 
onNext(StartTime) - Method in class org.apache.reef.io.data.loading.api.DataLoader.StartHandler
 
onNext(EvaluatorRequest) - Method in class org.apache.reef.io.data.loading.api.ResourceRequestHandler
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.CtrlMsgSender
 
onNext(Exception) - Method in class org.apache.reef.io.network.group.impl.driver.ExceptionHandler
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommMessageHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommService.FailedEvaluatorHandler
 
onNext(FailedTask) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommService.FailedTaskHandler
 
onNext(RunningTask) - Method in class org.apache.reef.io.network.group.impl.driver.GroupCommService.RunningTaskHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.io.network.group.impl.driver.TopologyFailedEvaluatorHandler
 
onNext(FailedTask) - Method in class org.apache.reef.io.network.group.impl.driver.TopologyFailedTaskHandler
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.TopologyMessageHandler
 
onNext(RunningTask) - Method in class org.apache.reef.io.network.group.impl.driver.TopologyRunningTaskHandler
 
onNext(List<TaskNode>) - Method in class org.apache.reef.io.network.group.impl.driver.TopologyUpdateWaitHandler
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
onNext(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.CommGroupNetworkHandlerImpl
 
onNext(Message<GroupCommunicationMessage>) - Method in class org.apache.reef.io.network.group.impl.task.GroupCommNetworkHandlerImpl
 
onNext(T) - Method in class org.apache.reef.io.network.group.impl.utils.BroadcastingEventHandler
 
onNext(TaskStart) - Method in class org.apache.reef.io.network.impl.BindNSToTask
 
onNext(ContextStop) - Method in class org.apache.reef.io.network.impl.NameServiceCloseHandler
 
onNext(Exception) - Method in class org.apache.reef.io.network.impl.NetworkConnectionServiceExceptionHandler
 
onNext(ContextStop) - Method in class org.apache.reef.io.network.impl.NetworkServiceClosingHandler
 
onNext(TaskStop) - Method in class org.apache.reef.io.network.impl.UnbindNSFromTask
 
onNext(Runnable) - Method in class org.apache.reef.io.watcher.util.RunnableExecutingHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.io.watcher.Watcher.ContextActiveHandler
 
onNext(ClosedContext) - Method in class org.apache.reef.io.watcher.Watcher.ContextClosedHandler
 
onNext(FailedContext) - Method in class org.apache.reef.io.watcher.Watcher.ContextFailedHandler
 
onNext(RuntimeStart) - Method in class org.apache.reef.io.watcher.Watcher.DriverRuntimeStartHandler
 
onNext(RuntimeStop) - Method in class org.apache.reef.io.watcher.Watcher.DriverRuntimeStopHandler
 
onNext(StartTime) - Method in class org.apache.reef.io.watcher.Watcher.DriverStartHandler
 
onNext(StopTime) - Method in class org.apache.reef.io.watcher.Watcher.DriverStopHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.io.watcher.Watcher.EvaluatorAllocatedHandler
 
onNext(CompletedEvaluator) - Method in class org.apache.reef.io.watcher.Watcher.EvaluatorCompletedHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.io.watcher.Watcher.EvaluatorFailedHandler
 
onNext(CompletedTask) - Method in class org.apache.reef.io.watcher.Watcher.TaskCompletedHandler
 
onNext(FailedTask) - Method in class org.apache.reef.io.watcher.Watcher.TaskFailedHandler
 
onNext(TaskMessage) - Method in class org.apache.reef.io.watcher.Watcher.TaskMessageHandler
 
onNext(RunningTask) - Method in class org.apache.reef.io.watcher.Watcher.TaskRunningHandler
 
onNext(SuspendedTask) - Method in class org.apache.reef.io.watcher.Watcher.TaskSuspendedHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.javabridge.generic.JobDriver.ActiveContextHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.javabridge.generic.JobDriver.AllocatedEvaluatorHandler
 
onNext(ClosedContext) - Method in class org.apache.reef.javabridge.generic.JobDriver.ClosedContextHandler
 
onNext(CompletedEvaluator) - Method in class org.apache.reef.javabridge.generic.JobDriver.CompletedEvaluatorHandler
 
onNext(CompletedTask) - Method in class org.apache.reef.javabridge.generic.JobDriver.CompletedTaskHandler
 
onNext(ContextMessage) - Method in class org.apache.reef.javabridge.generic.JobDriver.ContextMessageHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.javabridge.generic.JobDriver.DriverRestartActiveContextHandler
 
onNext(DriverRestartCompleted) - Method in class org.apache.reef.javabridge.generic.JobDriver.DriverRestartCompletedHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.javabridge.generic.JobDriver.DriverRestartFailedEvaluatorHandler
 
onNext(RunningTask) - Method in class org.apache.reef.javabridge.generic.JobDriver.DriverRestartRunningTaskHandler
 
onNext(FailedContext) - Method in class org.apache.reef.javabridge.generic.JobDriver.FailedContextHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.javabridge.generic.JobDriver.FailedEvaluatorHandler
 
onNext(FailedTask) - Method in class org.apache.reef.javabridge.generic.JobDriver.FailedTaskHandler
 
onNext(DriverRestarted) - Method in class org.apache.reef.javabridge.generic.JobDriver.RestartHandler
 
onNext(RunningTask) - Method in class org.apache.reef.javabridge.generic.JobDriver.RunningTaskHandler
 
onNext(StartTime) - Method in class org.apache.reef.javabridge.generic.JobDriver.StartHandler
 
onNext(SuspendedTask) - Method in class org.apache.reef.javabridge.generic.JobDriver.SuspendedTaskHandler
 
onNext(TaskMessage) - Method in class org.apache.reef.javabridge.generic.JobDriver.TaskMessageHandler
 
onNext(ContextStart) - Method in class org.apache.reef.poison.context.PoisonedContextStartHandler
 
onNext(Alarm) - Method in class org.apache.reef.poison.PoisonedAlarmHandler
 
onNext(TaskStart) - Method in class org.apache.reef.poison.task.PoisonedTaskStartHandler
 
onNext(CompletedJob) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultCompletedJobHandler
 
onNext(FailedJob) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultFailedJobHandler
 
onNext(JobMessage) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultJobMessageHandler
 
onNext(RunningJob) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultRunningJobHandler
 
onNext(FailedRuntime) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultRuntimeErrorHandler
 
onNext(SubmittedJob) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultSubmittedJobHandler
 
onNext(ReefServiceProtos.JobStatusProto) - Method in class org.apache.reef.runtime.common.client.RunningJobImpl
 
onNext(ClientRuntimeProtocol.JobControlProto) - Method in class org.apache.reef.runtime.common.driver.client.ClientManager
This method reacts to control messages passed by the client to the driver.
onNext(ReefServiceProtos.JobStatusProto) - Method in class org.apache.reef.runtime.common.driver.client.LoggingJobStatusHandler
 
onNext(Void) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultClientCloseHandler
 
onNext(byte[]) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultClientCloseWithMessageHandler
 
onNext(byte[]) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultClientMessageHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultContextActiveHandler
 
onNext(ClosedContext) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultContextClosureHandler
 
onNext(FailedContext) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultContextFailureHandler
 
onNext(ContextMessage) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultContextMessageHandler
 
onNext(DriverRestartCompleted) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultDriverRestartCompletedHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultDriverRestartContextActiveHandler
 
onNext(RunningTask) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultDriverRestartTaskRunningHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultEvaluatorAllocationHandler
 
onNext(CompletedEvaluator) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultEvaluatorCompletionHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultEvaluatorFailureHandler
 
onNext(CompletedTask) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultTaskCompletionHandler
 
onNext(FailedTask) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultTaskFailureHandler
 
onNext(TaskMessage) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultTaskMessageHandler
 
onNext(RunningTask) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultTaskRunningHandler
 
onNext(SuspendedTask) - Method in class org.apache.reef.runtime.common.driver.defaults.DefaultTaskSuspensionHandler
 
onNext(Throwable) - Method in class org.apache.reef.runtime.common.driver.DriverExceptionHandler
 
onNext(StartTime) - Method in class org.apache.reef.runtime.common.driver.DriverStartHandler
 
onNext(RemoteMessage<EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto>) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorHeartbeatHandler
 
onNext(RemoteMessage<ReefServiceProtos.RuntimeErrorProto>) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorResourceManagerErrorHandler
 
onNext(IdleClock) - Method in class org.apache.reef.runtime.common.driver.idle.ClockIdlenessSource
 
onNext(NodeDescriptorEvent) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorHandler
 
onNext(ResourceAllocationEvent) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceAllocationHandler
 
onNext(ReefServiceProtos.RuntimeErrorProto) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceManagerErrorHandler
 
onNext(RuntimeStatusEvent) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceManagerStatus
 
onNext(ResourceStatusEvent) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusHandler
This resource status message comes from the ResourceManager layer, telling me what it thinks about the state of the resource executing an Evaluator.
onNext(byte[]) - Method in class org.apache.reef.runtime.common.evaluator.context.defaults.DefaultContextMessageHandler
 
onNext(ContextStart) - Method in class org.apache.reef.runtime.common.evaluator.context.defaults.DefaultContextStartHandler
 
onNext(ContextStop) - Method in class org.apache.reef.runtime.common.evaluator.context.defaults.DefaultContextStopHandler
 
onNext(RuntimeStart) - Method in class org.apache.reef.runtime.common.evaluator.PIDStoreStartHandler
This call is idempotent: It will only write the PID exactly once per instance.
onNext(CloseEvent) - Method in class org.apache.reef.runtime.common.evaluator.task.defaults.DefaultCloseHandler
 
onNext(DriverMessage) - Method in class org.apache.reef.runtime.common.evaluator.task.defaults.DefaultDriverMessageHandler
 
onNext(SuspendEvent) - Method in class org.apache.reef.runtime.common.evaluator.task.defaults.DefaultSuspendHandler
 
onNext(StopTime) - Method in class org.apache.reef.runtime.common.launch.ProfilingStopHandler
 
onNext(Throwable) - Method in class org.apache.reef.runtime.common.launch.REEFErrorHandler
 
onNext(E) - Method in class org.apache.reef.runtime.common.utils.BroadCastEventHandler
 
onNext(Class<T>, U) - Method in class org.apache.reef.runtime.common.utils.DispatchingEStage
Dispatch a new message by type.
onNext(JobSubmissionEvent) - Method in class org.apache.reef.runtime.hdinsight.client.HDInsightJobSubmissionHandler
 
onNext(JobSubmissionEvent) - Method in class org.apache.reef.runtime.local.client.LocalJobSubmissionHandler
 
onNext(ResourceReleaseEvent) - Method in class org.apache.reef.runtime.local.driver.LocalResourceReleaseHandler
 
onNext(SchedulerDriver) - Method in class org.apache.reef.runtime.mesos.driver.MesosSchedulerDriverExecutor
 
onNext(Throwable) - Method in class org.apache.reef.runtime.mesos.util.MesosErrorHandler
 
onNext(ResourceReleaseEvent) - Method in class org.apache.reef.runtime.standalone.driver.StandaloneResourceReleaseHandler
 
onNext(ResourceLaunchEvent) - Method in class org.apache.reef.runtime.yarn.driver.YARNResourceLaunchHandler
 
onNext(ResourceReleaseEvent) - Method in class org.apache.reef.runtime.yarn.driver.YARNResourceReleaseHandler
 
onNext(ResourceRequestEvent) - Method in class org.apache.reef.runtime.yarn.driver.YarnResourceRequestHandler
 
onNext(RuntimeStart) - Method in class org.apache.reef.runtime.yarn.driver.YARNRuntimeStartHandler
 
onNext(RuntimeStop) - Method in class org.apache.reef.runtime.yarn.driver.YARNRuntimeStopHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.tests.fail.driver.DriverFailOnFail.AllocatedEvaluatorHandler
 
onNext(FailedTask) - Method in class org.apache.reef.tests.fail.driver.DriverFailOnFail.FailedTaskHandler
 
onNext(StartTime) - Method in class org.apache.reef.tests.fail.driver.DriverFailOnFail.StartHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.ActiveContextHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.AllocatedEvaluatorHandler
 
onNext(RunningTask) - Method in class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.RunningTaskHandler
 
onNext(StartTime) - Method in class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.StartHandler
 
onNext(TaskMessage) - Method in class org.apache.reef.tests.fail.driver.FailDriverDelayedMsg.TaskMessageHandler
 
onNext(DriverMessage) - Method in class org.apache.reef.tests.fail.driver.NoopTask.DriverMessageHandler
 
onNext(CloseEvent) - Method in class org.apache.reef.tests.fail.driver.NoopTask.TaskCloseHandler
 
onNext(TaskStop) - Method in class org.apache.reef.tests.fail.driver.NoopTask.TaskStopHandler
 
onNext(SuspendEvent) - Method in class org.apache.reef.tests.fail.driver.NoopTask.TaskSuspendHandler
 
onNext(CloseEvent) - Method in class org.apache.reef.tests.fail.task.FailTaskClose
 
onNext(DriverMessage) - Method in class org.apache.reef.tests.fail.task.FailTaskMsg
 
onNext(TaskStart) - Method in class org.apache.reef.tests.fail.task.FailTaskStart
 
onNext(CloseEvent) - Method in class org.apache.reef.tests.fail.task.FailTaskStop.CloseEventHandler
 
onNext(TaskStop) - Method in class org.apache.reef.tests.fail.task.FailTaskStop
 
onNext(SuspendEvent) - Method in class org.apache.reef.tests.fail.task.FailTaskSuspend
 
onNext(FailedTask) - Method in class org.apache.reef.tests.library.driver.ExpectedTaskFailureHandler
Checks whether the FailedTask was caused by a ExpectedTaskException.
onNext(StartTime) - Method in class org.apache.reef.tests.library.driver.OnDriverStartedAllocateOne
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.tests.messaging.task.TaskMessagingDriver.EvaluatorAllocatedHandler
 
onNext(TaskMessage) - Method in class org.apache.reef.tests.messaging.task.TaskMessagingDriver.TaskMessageHandler
 
onNext(RunningTask) - Method in class org.apache.reef.tests.messaging.task.TaskMessagingDriver.TaskRunningHandler
 
onNext(DriverMessage) - Method in class org.apache.reef.tests.messaging.task.TaskMessagingTask.DriverMessageHandler
 
onNext(StartTime) - Method in class org.apache.reef.tests.rack.awareness.OnDriverStartedAllocateOneInRack
 
onNext(ContextStart) - Method in class org.apache.reef.tests.watcher.FailedContextHandler
 
onNext(TaskStart) - Method in class org.apache.reef.tests.watcher.FailedTaskStartHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.ContextActivatedHandler
 
onNext(FailedContext) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.ContextFailedHandler
 
onNext(StartTime) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.DriverStartedHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.EvaluatorAllocatedHandler
 
onNext(FailedEvaluator) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.EvaluatorFailedHandler
 
onNext(RuntimeStop) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.RuntimeStopHandler
 
onNext(FailedTask) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.TaskFailedHandler
 
onNext(RunningTask) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.TaskRunningHandler
 
onNext(SuspendedTask) - Method in class org.apache.reef.tests.watcher.WatcherTestDriver.TaskSuspendedHandler
 
onNext(SuspendEvent) - Method in class org.apache.reef.tests.watcher.WatcherTestTask.TaskSuspendedHandler
 
onNext(T) - Method in class org.apache.reef.util.ExceptionHandlingEventHandler
 
onNext(DriverMessage) - Method in class org.apache.reef.vortex.evaluator.VortexWorker.DriverMessageHandler
 
onNext(CloseEvent) - Method in class org.apache.reef.vortex.evaluator.VortexWorker.TaskCloseHandler
 
onNext(T) - Method in interface org.apache.reef.wake.EventHandler
Handles an event.
onNext(T) - Method in class org.apache.reef.wake.examples.join.EventPrinter
 
onNext(T) - Method in class org.apache.reef.wake.impl.BlockingEventHandler
 
onNext(T) - Method in class org.apache.reef.wake.impl.BlockingSignalEventHandler
 
onNext(T) - Method in class org.apache.reef.wake.impl.ForkPoolStage
 
onNext(List<T>) - Method in class org.apache.reef.wake.impl.IndependentIterationsThreadPoolStage
 
onNext(T) - Method in class org.apache.reef.wake.impl.LoggingEventHandler
Logs the event.
onNext(Void) - Method in class org.apache.reef.wake.impl.LoggingVoidEventHandler
Logs the event.
onNext(StartTime) - Method in class org.apache.reef.wake.impl.MissingStartHandlerHandler
 
onNext(T) - Method in class org.apache.reef.wake.impl.MultiEventHandler
Invokes a specific handler for the event class type if it exists.
onNext(T) - Method in class org.apache.reef.wake.impl.PubSubEventHandler
Invokes subscribed handlers for the event class type.
onNext(T) - Method in class org.apache.reef.wake.impl.SingleThreadStage
Puts the value to the queue, which will be processed by the handler later.
onNext(T) - Method in class org.apache.reef.wake.impl.SyncStage
Invokes the handler for the event.
onNext(T) - Method in class org.apache.reef.wake.impl.ThreadPoolStage
Handles the event using a thread in the thread pool.
onNext(TransportEvent) - Method in class org.apache.reef.wake.remote.impl.DefaultTransportEStage
 
onNext(TransportEvent) - Method in class org.apache.reef.wake.remote.impl.OrderedRemoteReceiverStage
 
onNext(T) - Method in class org.apache.reef.wake.remote.impl.ProxyEventHandler
Sends the event to the event handler running remotely.
onNext(TransportEvent) - Method in class org.apache.reef.wake.remote.impl.RemoteReceiverStage
Handles the received event.
onNext(T) - Method in class org.apache.reef.wake.rx.impl.RxSyncStage
Provides the observer with the new value.
onNext(T) - Method in class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Provides the observer with the new value.
onNext(T) - Method in class org.apache.reef.wake.rx.impl.SimpleSubject
Provides the observer with the new value.
onNext(T) - Method in interface org.apache.reef.wake.rx.Observer
Provides the observer with new data.
onNext(ActiveContext) - Method in class org.apache.reef.webserver.ReefEventStateManager.ActiveContextStateHandler
 
onNext(AllocatedEvaluator) - Method in class org.apache.reef.webserver.ReefEventStateManager.AllocatedEvaluatorStateHandler
 
onNext(byte[]) - Method in class org.apache.reef.webserver.ReefEventStateManager.ClientMessageStateHandler
 
onNext(ActiveContext) - Method in class org.apache.reef.webserver.ReefEventStateManager.DriverRestartActiveContextStateHandler
 
onNext(DriverRestarted) - Method in class org.apache.reef.webserver.ReefEventStateManager.DriverRestartHandler
 
onNext(RunningTask) - Method in class org.apache.reef.webserver.ReefEventStateManager.DriverRestartTaskRunningStateHandler
 
onNext(StartTime) - Method in class org.apache.reef.webserver.ReefEventStateManager.StartStateHandler
 
onNext(StopTime) - Method in class org.apache.reef.webserver.ReefEventStateManager.StopStateHandler
 
onNext(RunningTask) - Method in class org.apache.reef.webserver.ReefEventStateManager.TaskRunningStateHandler
 
onParentDead() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onParentDead() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
onParentRunning() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onParentRunning() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
* Methods pertaining to my status change ends ***.
onPotentiallyIdle(IdleMessage) - Method in class org.apache.reef.runtime.common.driver.idle.DriverIdleManager
Check whether all Driver components are idle, and initiate driver shutdown if they are.
onProcessExit(String, int) - Method in class org.apache.reef.runtime.local.process.LoggingRunnableProcessObserver
 
onProcessExit(String, int) - Method in class org.apache.reef.runtime.local.process.ReefRunnableProcessObserver
 
onProcessExit(String, int) - Method in interface org.apache.reef.runtime.local.process.RunnableProcessObserver
This will be called right after the process exited.
onProcessStarted(String) - Method in class org.apache.reef.runtime.local.process.LoggingRunnableProcessObserver
 
onProcessStarted(String) - Method in class org.apache.reef.runtime.local.process.ReefRunnableProcessObserver
 
onProcessStarted(String) - Method in interface org.apache.reef.runtime.local.process.RunnableProcessObserver
This will be called right after the process is launched.
onReceiptOfAcknowledgement(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onReceiptOfAcknowledgement(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
* Methods pertaining to my neighbors status change ends ***.
onReceiptOfMessage(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Update state on receipt of a message.
onReceiptOfMessage(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
onReceiptOfMessage(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
onRecoverEvaluator(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Indicate that this Driver has re-established the connection with one more Evaluator of a previous run.
onResourceAllocation(ResourceAllocationEvent) - Method in class org.apache.reef.runtime.yarn.driver.REEFEventHandlers
Inform REEF of a fresh resource allocation.
onResourceLaunch(ResourceLaunchEvent) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
 
onResourceStatusMessage(ResourceStatusEvent) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Resource status information from the (actual) resource manager.
onRestart(StartTime, List<EventHandler<DriverRestarted>>) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Recovers the list of alive and failed evaluators and inform the driver restart handlers and inform the evaluator failure handlers based on the specific runtime.
onRunning() - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Changes the driver status to RUNNING and sends message to the client about the transition.
onRunningTask() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
onRunningTask(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Update state on receipt of RunningTask.
onRunningTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
onRunningTask() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
onRunningTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
onRuntimeStatus(RuntimeStatusEvent) - Method in class org.apache.reef.runtime.yarn.driver.REEFEventHandlers
Update REEF's view on the runtime status.
onRuntimeStop(Optional<Throwable>) - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Sends the final message to the client.
onSuccess(V) - Method in interface org.apache.reef.vortex.api.FutureCallback
Invoked with the result of the Tasklet computation on success.
onSuccess(T) - Method in interface org.apache.reef.wake.remote.transport.LinkListener
Called when the sent message is successfully transferred.
onSuccess(T) - Method in class org.apache.reef.wake.remote.transport.netty.LoggingLinkListener
Called when the sent message is transferred successfully.
onTaskCompleted(CompletedTask) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onTaskFailed(FailedTask) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onTaskMessage(TaskMessage) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onTaskRunning(RunningTask) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onTaskStatusMessage(TaskStatusPOJO) - Method in class org.apache.reef.runtime.common.driver.task.TaskRepresenter
 
onTaskSuspended(SuspendedTask) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorMessageDispatcher
 
onTopologySetupMessageSent() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
 
onTopologySetupMessageSent() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
open(CheckpointID) - Method in interface org.apache.reef.io.checkpoint.CheckpointService
Returns a reading channel to a checkpoint identified by the CheckpointID.
open(CheckpointID) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointService
 
open() - Method in interface org.apache.reef.io.network.Connection
Opens the connection.
open(SocketAddress, Encoder<? super T>, LinkListener<? super T>) - Method in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Returns a link for the remote address if cached; otherwise opens, caches and returns.
open(SocketAddress, Encoder<? super T>, LinkListener<? super T>) - Method in interface org.apache.reef.wake.remote.transport.Transport
Returns a link for the remote address if cached; otherwise opens, caches and returns.
OperatorName - Class in org.apache.reef.io.network.group.impl.config.parameters
Name of the operator.
OPERATORNAME_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
OperatorNameClass - Class in org.apache.reef.io.network.group.impl.config.parameters
NamedParameter wrapper for the name class of the operator.
OperatorSpec - Interface in org.apache.reef.io.network.group.api.config
The specification of an operator submitted by the user while configuring the communication group.
OperatorTopology - Interface in org.apache.reef.io.network.group.api.task
Represents the local topology of tasks for an operator.
OperatorTopologyImpl - Class in org.apache.reef.io.network.group.impl.task
 
OperatorTopologyImpl(Class<? extends Name<String>>, Class<? extends Name<String>>, String, String, Sender, int) - Constructor for class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
OperatorTopologyStruct - Interface in org.apache.reef.io.network.group.api.task
The actual local topology maintaining the children and parent that reacts to update and data msgs.
OperatorTopologyStructImpl - Class in org.apache.reef.io.network.group.impl.task
 
OperatorTopologyStructImpl(Class<? extends Name<String>>, Class<? extends Name<String>>, String, String, Sender, int) - Constructor for class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
OperatorTopologyStructImpl(OperatorTopologyStruct) - Constructor for class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
Optional - Annotation Type in org.apache.reef.annotations
Indicates an optional interface: It doesn't have to be implemented or bound using TANG.
Optional<T> - Class in org.apache.reef.util
Represents an optional value.
OptionalImpl<T> - Class in org.apache.reef.tang.formats
 
OptionalImpl() - Constructor for class org.apache.reef.tang.formats.OptionalImpl
 
OptionalParameter<T> - Class in org.apache.reef.tang.formats
 
OptionalParameter() - Constructor for class org.apache.reef.tang.formats.OptionalParameter
 
OrderedRemoteReceiverStage - Class in org.apache.reef.wake.remote.impl
Receive incoming events and dispatch to correct handlers in order.
OrderedRemoteReceiverStage(EventHandler<RemoteEvent<byte[]>>, EventHandler<Throwable>) - Constructor for class org.apache.reef.wake.remote.impl.OrderedRemoteReceiverStage
Constructs an ordered remote receiver stage.
orElse(T) - Method in class org.apache.reef.util.Optional
 
org.apache.reef.annotations - package org.apache.reef.annotations
Annotations used to identify interface stability and audience.
org.apache.reef.annotations.audience - package org.apache.reef.annotations.audience
Annotations for interface audience.
org.apache.reef.annotations.semantics - package org.apache.reef.annotations.semantics
Contains annotations capturing the semantics of APIs, e.g.
org.apache.reef.bridge.client - package org.apache.reef.bridge.client
Contains the client of the bridge.
org.apache.reef.bridge.message - package org.apache.reef.bridge.message
 
org.apache.reef.client - package org.apache.reef.client
Client APIs for REEF.
org.apache.reef.client.parameters - package org.apache.reef.client.parameters
Named parameters for the REEF client API.
org.apache.reef.common - package org.apache.reef.common
REEF Common.
org.apache.reef.driver - package org.apache.reef.driver
Driver APIs for REEF in terms of Rx.
org.apache.reef.driver.catalog - package org.apache.reef.driver.catalog
Interfaces describing resources available to a REEF instance (physical nodes, racks etc).
org.apache.reef.driver.client - package org.apache.reef.driver.client
Representations of the Client (i.e.
org.apache.reef.driver.context - package org.apache.reef.driver.context
Driver Contexts and their configurations.
org.apache.reef.driver.evaluator - package org.apache.reef.driver.evaluator
Evaluator-related utilities.
org.apache.reef.driver.parameters - package org.apache.reef.driver.parameters
Named parameters used by the Driver.
org.apache.reef.driver.restart - package org.apache.reef.driver.restart
This package provides restart event service handlers.
org.apache.reef.driver.task - package org.apache.reef.driver.task
Tasks and their configurations.
org.apache.reef.evaluator.context - package org.apache.reef.evaluator.context
Evaluator Contexts.
org.apache.reef.evaluator.context.events - package org.apache.reef.evaluator.context.events
Events signaling change of Evaluator state.
org.apache.reef.evaluator.context.parameters - package org.apache.reef.evaluator.context.parameters
Named parameters used by the Evaluator.
org.apache.reef.examples.data.loading - package org.apache.reef.examples.data.loading
A line counter example using data loading service.
org.apache.reef.examples.data.output - package org.apache.reef.examples.data.output
Example application using the output service.
org.apache.reef.examples.distributedshell - package org.apache.reef.examples.distributedshell
Simple Distributed Shell example.
org.apache.reef.examples.group.bgd - package org.apache.reef.examples.group.bgd
Runs BGD on the given runtime.
org.apache.reef.examples.group.bgd.data - package org.apache.reef.examples.group.bgd.data
Interface for example data instance for linear models.
org.apache.reef.examples.group.bgd.data.parser - package org.apache.reef.examples.group.bgd.data.parser
A parser interface and implementation for SVMLight records.
org.apache.reef.examples.group.bgd.loss - package org.apache.reef.examples.group.bgd.loss
Loss Functions for BGD.
org.apache.reef.examples.group.bgd.operatornames - package 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 - package org.apache.reef.examples.group.bgd.parameters
Parameters for BGD.
org.apache.reef.examples.group.bgd.utils - package org.apache.reef.examples.group.bgd.utils
Utility functions for BGD.
org.apache.reef.examples.group.broadcast - package org.apache.reef.examples.group.broadcast
Broadcast Group Communication example.
org.apache.reef.examples.group.broadcast.parameters - package org.apache.reef.examples.group.broadcast.parameters
Parameters for Broadcast group communication.
org.apache.reef.examples.group.utils.math - package org.apache.reef.examples.group.utils.math
Math utilities for Group Communication.
org.apache.reef.examples.group.utils.timer - package org.apache.reef.examples.group.utils.timer
Timer for Group Communication.
org.apache.reef.examples.hello - package org.apache.reef.examples.hello
The Hello REEF example for the HDInsight.
org.apache.reef.examples.helloCLR - package org.apache.reef.examples.helloCLR
The Hello REEF example for the CLR.
org.apache.reef.examples.hellohttp - package org.apache.reef.examples.hellohttp
Distributed shell example based on REEF HTTP Server component.
org.apache.reef.examples.hellomultiruntime - package org.apache.reef.examples.hellomultiruntime
The Hello REEF Multi Runtime example.
org.apache.reef.examples.library - package org.apache.reef.examples.library
A library for distributed shell example.
org.apache.reef.examples.pool - package org.apache.reef.examples.pool
Allocate N evaluators, submit M tasks to them, and measure the time.
org.apache.reef.examples.reefonreef - package org.apache.reef.examples.reefonreef
REEF-on-REEF example.
org.apache.reef.examples.scheduler - package org.apache.reef.examples.scheduler
Task scheduler example based on reef-webserver.
org.apache.reef.examples.scheduler.client - package org.apache.reef.examples.scheduler.client
Task scheduler example client classes.
org.apache.reef.examples.scheduler.driver - package org.apache.reef.examples.scheduler.driver
Task scheduler example driver classes.
org.apache.reef.examples.scheduler.driver.exceptions - package org.apache.reef.examples.scheduler.driver.exceptions
Task scheduler example exceptions.
org.apache.reef.examples.scheduler.driver.http - package org.apache.reef.examples.scheduler.driver.http
Task scheduler example HTTP API.
org.apache.reef.examples.suspend - package org.apache.reef.examples.suspend
Suspend/resume demo.
org.apache.reef.examples.utils.wake - package org.apache.reef.examples.utils.wake
Logging and Blocking event handlers.
org.apache.reef.exception - package org.apache.reef.exception
Exceptions thrown to Job Drivers.
org.apache.reef.exception.evaluator - package org.apache.reef.exception.evaluator
Exceptions thrown in the Evaluators.
org.apache.reef.experimental - package org.apache.reef.experimental
Experimental projects for REEF.
org.apache.reef.experimental.parquet - package org.apache.reef.experimental.parquet
Experimental projects for REEF.
org.apache.reef.io - package org.apache.reef.io
APIs for I/O in REEF: Codecs and Serializers.
org.apache.reef.io.checkpoint - package org.apache.reef.io.checkpoint
Checkpoints that provide APIs and implementations to store and retrieve the state of a task.
org.apache.reef.io.checkpoint.fs - package org.apache.reef.io.checkpoint.fs
Provides an example implementation of a CheckpointService based on a file system.
org.apache.reef.io.data.loading.api - package org.apache.reef.io.data.loading.api
Data Loading Service API.
org.apache.reef.io.data.loading.avro - package org.apache.reef.io.data.loading.avro
 
org.apache.reef.io.data.loading.impl - package org.apache.reef.io.data.loading.impl
Implementations of Data Loading Service.
org.apache.reef.io.data.output - package org.apache.reef.io.data.output
Data Output Service.
org.apache.reef.io.naming - package org.apache.reef.io.naming
Utilities for assigning Identifiers to objects and associating socket addresses with them.
org.apache.reef.io.network - package org.apache.reef.io.network
TODO: Document.
org.apache.reef.io.network.exception - package org.apache.reef.io.network.exception
Network service exceptions.
org.apache.reef.io.network.group - package org.apache.reef.io.network.group
Elastic Group Communications for REEF.
org.apache.reef.io.network.group.api - package org.apache.reef.io.network.group.api
Elastic Group Communications API.
org.apache.reef.io.network.group.api.config - package org.apache.reef.io.network.group.api.config
The operator configurations used by users.
org.apache.reef.io.network.group.api.driver - package org.apache.reef.io.network.group.api.driver
Elastic Group Communications Driver-side API Interfaces.
org.apache.reef.io.network.group.api.operators - package 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 - package org.apache.reef.io.network.group.api.task
Elastic Group Communications Task-side API Interfaces.
org.apache.reef.io.network.group.impl - package org.apache.reef.io.network.group.impl
Implementations for Elastic Group Communications.
org.apache.reef.io.network.group.impl.config - package org.apache.reef.io.network.group.impl.config
Group Communication Operator Specifications.
org.apache.reef.io.network.group.impl.config.parameters - package org.apache.reef.io.network.group.impl.config.parameters
Parameters for Elastic Group Communications.
org.apache.reef.io.network.group.impl.driver - package 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 - package org.apache.reef.io.network.group.impl.operators
Implementations for Group Communication Operators.
org.apache.reef.io.network.group.impl.task - package org.apache.reef.io.network.group.impl.task
Implementations for Elastic Group Communications Task-side API.
org.apache.reef.io.network.group.impl.utils - package org.apache.reef.io.network.group.impl.utils
Utilities for group communication.
org.apache.reef.io.network.impl - package org.apache.reef.io.network.impl
TODO: Document.
org.apache.reef.io.network.impl.config - package org.apache.reef.io.network.impl.config
TODO: Document.
org.apache.reef.io.network.naming - package org.apache.reef.io.network.naming
TODO: Document.
org.apache.reef.io.network.naming.avro - package org.apache.reef.io.network.naming.avro
 
org.apache.reef.io.network.naming.exception - package org.apache.reef.io.network.naming.exception
TODO: Document.
org.apache.reef.io.network.naming.parameters - package org.apache.reef.io.network.naming.parameters
TODO: Document.
org.apache.reef.io.network.naming.serialization - package org.apache.reef.io.network.naming.serialization
Contains naming serialization codecs.
org.apache.reef.io.network.proto - package org.apache.reef.io.network.proto
 
org.apache.reef.io.network.util - package org.apache.reef.io.network.util
Utility for REEF IO network module.
org.apache.reef.io.parameters - package org.apache.reef.io.parameters
Parameters for reef-common.src.main.java.org.apache.reef.io.
org.apache.reef.io.serialization - package org.apache.reef.io.serialization
Serialization utilities.
org.apache.reef.io.storage - package org.apache.reef.io.storage
APIs for Storage Service.
org.apache.reef.io.storage.local - package org.apache.reef.io.storage.local
Implementations for local filesystem-based storage service.
org.apache.reef.io.storage.ram - package org.apache.reef.io.storage.ram
Implementations for RAM-based storage service.
org.apache.reef.io.storage.util - package org.apache.reef.io.storage.util
Utilities for storage services.
org.apache.reef.io.watcher - package org.apache.reef.io.watcher
Watcher subscribes events and writes them to the destination using a certain EventStream.
org.apache.reef.io.watcher.common - package org.apache.reef.io.watcher.common
 
org.apache.reef.io.watcher.driver.catalog - package org.apache.reef.io.watcher.driver.catalog
 
org.apache.reef.io.watcher.driver.context - package org.apache.reef.io.watcher.driver.context
 
org.apache.reef.io.watcher.driver.evaluator - package org.apache.reef.io.watcher.driver.evaluator
 
org.apache.reef.io.watcher.driver.task - package org.apache.reef.io.watcher.driver.task
 
org.apache.reef.io.watcher.param - package org.apache.reef.io.watcher.param
Parameters for Watcher.
org.apache.reef.io.watcher.util - package org.apache.reef.io.watcher.util
Utility classes for Watcher.
org.apache.reef.io.watcher.wake.time.event - package org.apache.reef.io.watcher.wake.time.event
 
org.apache.reef.io.watcher.wake.time.runtime.event - package org.apache.reef.io.watcher.wake.time.runtime.event
 
org.apache.reef.javabridge - package org.apache.reef.javabridge
The Java-side of the CLR/Java bridge.
org.apache.reef.javabridge.avro - package org.apache.reef.javabridge.avro
 
org.apache.reef.javabridge.generic - package org.apache.reef.javabridge.generic
Generic java bridge driver/client.
org.apache.reef.javabridge.utils - package org.apache.reef.javabridge.utils
utils for clr bridge.
org.apache.reef.poison - package org.apache.reef.poison
Fault injection for REEF.
org.apache.reef.poison.context - package org.apache.reef.poison.context
Fault Injection into REEF contexts.
org.apache.reef.poison.params - package org.apache.reef.poison.params
Parameters of fault injections.
org.apache.reef.poison.task - package org.apache.reef.poison.task
Fault Injection into REEF tasks.
org.apache.reef.proto - package org.apache.reef.proto
 
org.apache.reef.reef.bridge.client.avro - package org.apache.reef.reef.bridge.client.avro
 
org.apache.reef.runtime.common - package org.apache.reef.runtime.common
REEF implementation.
org.apache.reef.runtime.common.client - package org.apache.reef.runtime.common.client
Implementation of the client-side REEF API.
org.apache.reef.runtime.common.client.api - package org.apache.reef.runtime.common.client.api
Client-Side Event Handlers to be implemented by a specific resourcemanager.
org.apache.reef.runtime.common.client.defaults - package org.apache.reef.runtime.common.client.defaults
Default implementations for the optional client-side event handlers.
org.apache.reef.runtime.common.client.parameters - package org.apache.reef.runtime.common.client.parameters
Parameters used by client.
org.apache.reef.runtime.common.driver - package org.apache.reef.runtime.common.driver
Implementation of the Driver-side REEF APIs.
org.apache.reef.runtime.common.driver.api - package 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.catalog - package org.apache.reef.runtime.common.driver.catalog
Implementations of descriptors for resources available to a REEF instance (physical nodes, racks etc).
org.apache.reef.runtime.common.driver.client - package org.apache.reef.runtime.common.driver.client
Objects representing the Client on the Driver.
org.apache.reef.runtime.common.driver.context - package org.apache.reef.runtime.common.driver.context
Implementations of Driver-Side representations of Contexts running on an Evaluator.
org.apache.reef.runtime.common.driver.defaults - package org.apache.reef.runtime.common.driver.defaults
Default implementations for the optional driver-side event handlers.
org.apache.reef.runtime.common.driver.evaluator - package org.apache.reef.runtime.common.driver.evaluator
Driver-Side representations of Evaluators.
org.apache.reef.runtime.common.driver.evaluator.pojos - package org.apache.reef.runtime.common.driver.evaluator.pojos
POJOs in this package encapsulate the content of an EvaluatorHeartbeatProto on the DriverSide.
org.apache.reef.runtime.common.driver.idle - package org.apache.reef.runtime.common.driver.idle
Contains the Driver idle handling and extension APIs.
org.apache.reef.runtime.common.driver.parameters - package org.apache.reef.runtime.common.driver.parameters
Parameters for the driver.
org.apache.reef.runtime.common.driver.resourcemanager - package org.apache.reef.runtime.common.driver.resourcemanager
Classes that interface with the resourcemanager (Local, YARN, ...) in the Driver.
org.apache.reef.runtime.common.driver.task - package org.apache.reef.runtime.common.driver.task
Driver-Side representations of tasks.
org.apache.reef.runtime.common.evaluator - package org.apache.reef.runtime.common.evaluator
Evaluator-side implementation of the REEF API.
org.apache.reef.runtime.common.evaluator.context - package org.apache.reef.runtime.common.evaluator.context
Context implementation of the Evaluator resourcemanager.
org.apache.reef.runtime.common.evaluator.context.defaults - package org.apache.reef.runtime.common.evaluator.context.defaults
Default implementations for the optional context interfaces.
org.apache.reef.runtime.common.evaluator.parameters - package org.apache.reef.runtime.common.evaluator.parameters
Parameters used by Evaluator.
org.apache.reef.runtime.common.evaluator.task - package org.apache.reef.runtime.common.evaluator.task
Task-related implementation of the Evaluator resourcemanager.
org.apache.reef.runtime.common.evaluator.task.defaults - package org.apache.reef.runtime.common.evaluator.task.defaults
Default implementations for the optional task interfaces.
org.apache.reef.runtime.common.evaluator.task.exceptions - package org.apache.reef.runtime.common.evaluator.task.exceptions
Exceptions thrown by Tasks and Task Handlers.
org.apache.reef.runtime.common.files - package org.apache.reef.runtime.common.files
This package will contain the implementation of the REEF file system standard.
org.apache.reef.runtime.common.launch - package org.apache.reef.runtime.common.launch
Common launch code between Driver and Evaluator.
org.apache.reef.runtime.common.launch.parameters - package org.apache.reef.runtime.common.launch.parameters
Parameters of the Launcher.
org.apache.reef.runtime.common.parameters - package org.apache.reef.runtime.common.parameters
Parameters used by runtime.
org.apache.reef.runtime.common.utils - package org.apache.reef.runtime.common.utils
Runtime utilities used by various REEF modules.
org.apache.reef.runtime.hdinsight - package org.apache.reef.runtime.hdinsight
HDInsight support for REEF.
org.apache.reef.runtime.hdinsight.cli - package org.apache.reef.runtime.hdinsight.cli
A command line interface for HDInsight.
org.apache.reef.runtime.hdinsight.client - package org.apache.reef.runtime.hdinsight.client
The client to submit jobs to HDInsight.
org.apache.reef.runtime.hdinsight.client.sslhacks - package org.apache.reef.runtime.hdinsight.client.sslhacks
Utils which do not check SSL.
org.apache.reef.runtime.hdinsight.client.yarnrest - package org.apache.reef.runtime.hdinsight.client.yarnrest
Some minimal abstraction over the YARN REST API.
org.apache.reef.runtime.hdinsight.driver - package org.apache.reef.runtime.hdinsight.driver
HDInsight support for REEF.
org.apache.reef.runtime.hdinsight.parameters - package org.apache.reef.runtime.hdinsight.parameters
Parameters for HDInsight connection.
org.apache.reef.runtime.local - package org.apache.reef.runtime.local
A local implementation of REEF that uses local JVMs for execution.
org.apache.reef.runtime.local.client - package org.apache.reef.runtime.local.client
Client-side event handlers for the local resourcemanager.
org.apache.reef.runtime.local.client.parameters - package org.apache.reef.runtime.local.client.parameters
Parameters of the local runtime.
org.apache.reef.runtime.local.driver - package org.apache.reef.runtime.local.driver
The resource manager for the local resourcemanager.
org.apache.reef.runtime.local.process - package org.apache.reef.runtime.local.process
Infrastructure for managing processes.
org.apache.reef.runtime.mesos - package org.apache.reef.runtime.mesos
An YARN implementation of REEF that uses Mesos slaves for execution.
org.apache.reef.runtime.mesos.client - package org.apache.reef.runtime.mesos.client
Client-side event handlers for Mesos resourcemanager.
org.apache.reef.runtime.mesos.client.parameters - package org.apache.reef.runtime.mesos.client.parameters
Client-side parameters for Mesos job submission.
org.apache.reef.runtime.mesos.driver - package org.apache.reef.runtime.mesos.driver
Driver-side event handlers for Mesos resourcemanager.
org.apache.reef.runtime.mesos.driver.parameters - package org.apache.reef.runtime.mesos.driver.parameters
Driver-side parameters for Mesos job submission.
org.apache.reef.runtime.mesos.evaluator - package org.apache.reef.runtime.mesos.evaluator
Evaluator-side event handlers for Mesos resourcemanager.
org.apache.reef.runtime.mesos.evaluator.parameters - package org.apache.reef.runtime.mesos.evaluator.parameters
Evaluator-side parameters for Mesos job.
org.apache.reef.runtime.mesos.util - package org.apache.reef.runtime.mesos.util
Utility for Mesos runtime.
org.apache.reef.runtime.multi.client - package org.apache.reef.runtime.multi.client
client side for the multi runtime implementation.
org.apache.reef.runtime.multi.client.parameters - package org.apache.reef.runtime.multi.client.parameters
Parameters for the multi runtime.
org.apache.reef.runtime.multi.driver - package org.apache.reef.runtime.multi.driver
A multi runtime implementation of REEF that uses several runtime implementationsi for execution.
org.apache.reef.runtime.multi.driver.parameters - package org.apache.reef.runtime.multi.driver.parameters
Parameters for multi runtime driver.
org.apache.reef.runtime.multi.utils - package org.apache.reef.runtime.multi.utils
Utils for multi runtime.
org.apache.reef.runtime.multi.utils.avro - package org.apache.reef.runtime.multi.utils.avro
 
org.apache.reef.runtime.standalone - package org.apache.reef.runtime.standalone
A standalone implementation of REEF that uses remote JVMs for execution.
org.apache.reef.runtime.standalone.client - package org.apache.reef.runtime.standalone.client
Client-side event handlers for the standalone resourcemanager.
org.apache.reef.runtime.standalone.client.parameters - package org.apache.reef.runtime.standalone.client.parameters
Parameters of the standalone runtime.
org.apache.reef.runtime.standalone.driver - package org.apache.reef.runtime.standalone.driver
The resource manager for the standalone resourcemanager.
org.apache.reef.runtime.yarn - package org.apache.reef.runtime.yarn
An YARN implementation of REEF that uses YARN container for execution.
org.apache.reef.runtime.yarn.client - package org.apache.reef.runtime.yarn.client
Client-side event handlers for YARN resourcemanager.
org.apache.reef.runtime.yarn.client.parameters - package org.apache.reef.runtime.yarn.client.parameters
Client-side parameters for YARN job submission.
org.apache.reef.runtime.yarn.client.unmanaged - package org.apache.reef.runtime.yarn.client.unmanaged
Client-side event handlers for YARN resourcemanager and AM running in unmanaged mode.
org.apache.reef.runtime.yarn.client.uploader - package org.apache.reef.runtime.yarn.client.uploader
Uploader to copy job resource files to YARN.
org.apache.reef.runtime.yarn.driver - package org.apache.reef.runtime.yarn.driver
The Driver-Side implementation of the YARN adapter for REEF.
org.apache.reef.runtime.yarn.driver.parameters - package org.apache.reef.runtime.yarn.driver.parameters
Driver-side parameters of YARN job submission.
org.apache.reef.runtime.yarn.driver.restart - package org.apache.reef.runtime.yarn.driver.restart
The package contains classes that are used specifically on restart.
org.apache.reef.runtime.yarn.util - package org.apache.reef.runtime.yarn.util
Utility for YARN runtime.
org.apache.reef.tang - package org.apache.reef.tang
Public interfaces and factories for Tang's core API.
org.apache.reef.tang.annotations - package org.apache.reef.tang.annotations
Annotations that application developers can use to register configuration metadata with Tang.
org.apache.reef.tang.examples - package org.apache.reef.tang.examples
Example code from the tutorial on Tang's home page.
org.apache.reef.tang.examples.timer - package org.apache.reef.tang.examples.timer
A more complicated version of the Timer example, including delegating interfaces to default implementations.
org.apache.reef.tang.exceptions - package org.apache.reef.tang.exceptions
Exceptions thrown by Tang, including runtime exceptions that reflect compile-time inconsistencies and other problems that can't be meaningfully handled by application code.
org.apache.reef.tang.formats - package org.apache.reef.tang.formats
Tang format classes encode and decode information that Tang gathers at runtime.
org.apache.reef.tang.formats.avro - package org.apache.reef.tang.formats.avro
 
org.apache.reef.tang.implementation - package org.apache.reef.tang.implementation
Tang's implementation.
org.apache.reef.tang.implementation.avro - package org.apache.reef.tang.implementation.avro
Implementation classes that translate between Tang's core API and Avro.
org.apache.reef.tang.implementation.java - package org.apache.reef.tang.implementation.java
Private implementation classes that configure and inject code written in Java.
org.apache.reef.tang.implementation.protobuf - package org.apache.reef.tang.implementation.protobuf
Implementation classes that translate between Tang's core API and protocol buffers.
org.apache.reef.tang.implementation.types - package org.apache.reef.tang.implementation.types
Implementations of the ClassHierarchy type system.
org.apache.reef.tang.proto - package org.apache.reef.tang.proto
 
org.apache.reef.tang.types - package org.apache.reef.tang.types
The interfaces that define Tang's ClassHierarchy objects.
org.apache.reef.tang.util - package org.apache.reef.tang.util
Utilities for Tang.
org.apache.reef.tang.util.walk - package org.apache.reef.tang.util.walk
Utility classes for configuration graph and injection plan traversal.
org.apache.reef.tang.util.walk.graphviz - package org.apache.reef.tang.util.walk.graphviz
produce Graphviz representation of TANG configuration graph and injection plan.
org.apache.reef.task - package org.apache.reef.task
Tasks.
org.apache.reef.task.events - package org.apache.reef.task.events
Task-related events.
org.apache.reef.tests - package org.apache.reef.tests
Tests for REEF implementations.
org.apache.reef.tests.driver - package org.apache.reef.tests.driver
Tests whether a Driver can successfully be launched and shut down.
org.apache.reef.tests.evaluator.failure - package org.apache.reef.tests.evaluator.failure
Tests for Evaluator failures.
org.apache.reef.tests.evaluator.failure.parameters - package org.apache.reef.tests.evaluator.failure.parameters
Parameters for FailureDriver.
org.apache.reef.tests.evaluatorreuse - package org.apache.reef.tests.evaluatorreuse
This package contains a test of the Evaluator reuse.
org.apache.reef.tests.fail.driver - package org.apache.reef.tests.fail.driver
Tests for Driver-side failures.
org.apache.reef.tests.fail.task - package org.apache.reef.tests.fail.task
Tests for Tasks fail in various cases.
org.apache.reef.tests.group - package org.apache.reef.tests.group
Tests for group communication.
org.apache.reef.tests.group.conf - package org.apache.reef.tests.group.conf
Classes used in tang configuration related tests for group communication.
org.apache.reef.tests.library - package org.apache.reef.tests.library
Commonly used event handlers and task implementations in our tests.
org.apache.reef.tests.library.driver - package org.apache.reef.tests.library.driver
Commonly used event handler implementations in our tests.
org.apache.reef.tests.library.exceptions - package org.apache.reef.tests.library.exceptions
Exceptions used in our tests.
org.apache.reef.tests.library.tasks - package org.apache.reef.tests.library.tasks
Commonly used task implementations in our tests.
org.apache.reef.tests.messaging.driver - package org.apache.reef.tests.messaging.driver
Tests the messaging channel between client and driver.
org.apache.reef.tests.messaging.task - package org.apache.reef.tests.messaging.task
Test message exchange between the Task and the Driver.
org.apache.reef.tests.rack.awareness - package org.apache.reef.tests.rack.awareness
Tests for Rack-awareness.
org.apache.reef.tests.statepassing - package org.apache.reef.tests.statepassing
Tests for State-passing.
org.apache.reef.tests.watcher - package org.apache.reef.tests.watcher
Test reef.io.watcher.
org.apache.reef.util - package org.apache.reef.util
Utilities for using REEF on Hadoop.
org.apache.reef.util.cache - package org.apache.reef.util.cache
Cache utilities.
org.apache.reef.util.logging - package org.apache.reef.util.logging
Logging handler for clr bridge.
org.apache.reef.vortex - package org.apache.reef.vortex
Vortex, a distributed runtime that makes efficient use of unreliable resources.
org.apache.reef.vortex.api - package org.apache.reef.vortex.api
Vortex user api for running jobs on Vortex.
org.apache.reef.vortex.common - package org.apache.reef.vortex.common
Code commonly used in VortexMaster and VortexWorker.
org.apache.reef.vortex.driver - package org.apache.reef.vortex.driver
Vortex Code that runs as part of REEF Driver.
org.apache.reef.vortex.evaluator - package org.apache.reef.vortex.evaluator
Vortex Code that runs as part of REEF Evaluator.
org.apache.reef.vortex.examples.addone - package org.apache.reef.vortex.examples.addone
A Simple Vortex vector calculation example.
org.apache.reef.vortex.examples.hello - package org.apache.reef.vortex.examples.hello
Vortex Hello World Example.
org.apache.reef.vortex.examples.matmul - package org.apache.reef.vortex.examples.matmul
A Simple Vortex matrix multiplication example.
org.apache.reef.vortex.examples.sumones - package org.apache.reef.vortex.examples.sumones
A Simple Vortex addition and aggregation example.
org.apache.reef.vortex.protocol.mastertoworker - package org.apache.reef.vortex.protocol.mastertoworker
Protocol from VortexMaster to VortexWorker.
org.apache.reef.vortex.protocol.workertomaster - package org.apache.reef.vortex.protocol.workertomaster
Protocol from VortexWorker to VortexMaster.
org.apache.reef.wake - package org.apache.reef.wake
Public interfaces and factories for Wake's core API.
org.apache.reef.wake.examples - package org.apache.reef.wake.examples
Wake examples.
org.apache.reef.wake.examples.accumulate - package org.apache.reef.wake.examples.accumulate
A key-value combiner example.
org.apache.reef.wake.examples.join - package org.apache.reef.wake.examples.join
Blocking and non-blocking join example.
org.apache.reef.wake.examples.p2p - package org.apache.reef.wake.examples.p2p
A simple pull to push adapter.
org.apache.reef.wake.exception - package org.apache.reef.wake.exception
Wake exceptions.
org.apache.reef.wake.impl - package org.apache.reef.wake.impl
Wake's implementation.
org.apache.reef.wake.metrics - package org.apache.reef.wake.metrics
Implementations of standard latency and throughput instrumentation.
org.apache.reef.wake.profiler - package org.apache.reef.wake.profiler
A graphical profiler that automatically instruments Tang-based Wake applications.
org.apache.reef.wake.remote - package org.apache.reef.wake.remote
Wake's remote communication.
org.apache.reef.wake.remote.address - package org.apache.reef.wake.remote.address
Local address resolution.
org.apache.reef.wake.remote.exception - package org.apache.reef.wake.remote.exception
Wake remote exceptions.
org.apache.reef.wake.remote.impl - package org.apache.reef.wake.remote.impl
Implementations for Wake's remote communication.
org.apache.reef.wake.remote.ports - package org.apache.reef.wake.remote.ports
TCP port providers.
org.apache.reef.wake.remote.ports.parameters - package org.apache.reef.wake.remote.ports.parameters
Parameters for TCP port selection.
org.apache.reef.wake.remote.proto - package org.apache.reef.wake.remote.proto
 
org.apache.reef.wake.remote.transport - package org.apache.reef.wake.remote.transport
Wake's remote transportation.
org.apache.reef.wake.remote.transport.exception - package org.apache.reef.wake.remote.transport.exception
Wake remote transport exceptions.
org.apache.reef.wake.remote.transport.netty - package org.apache.reef.wake.remote.transport.netty
Netty-based remote transport implementation.
org.apache.reef.wake.rx - package org.apache.reef.wake.rx
Wake's RX-style communication.
org.apache.reef.wake.rx.exception - package org.apache.reef.wake.rx.exception
RX-style communication exceptions.
org.apache.reef.wake.rx.impl - package org.apache.reef.wake.rx.impl
Wake's RX-style communication implementation.
org.apache.reef.wake.test.proto - package org.apache.reef.wake.test.proto
 
org.apache.reef.wake.time - package org.apache.reef.wake.time
Clock and time-based events(start/stop/alarm) implementation.
org.apache.reef.wake.time.event - package org.apache.reef.wake.time.event
Time-based events (start/stop/alarm).
org.apache.reef.wake.time.runtime - package org.apache.reef.wake.time.runtime
 
org.apache.reef.wake.time.runtime.event - package org.apache.reef.wake.time.runtime.event
Runtime-related Wake events.
org.apache.reef.webserver - package org.apache.reef.webserver
HTTP Server component to implement a REST API for the Driver or Evaluators.
OSUtils - Class in org.apache.reef.util
OS utils.
otherConstructors - Variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
Deprecated.
OTHERCONSTRUCTORS_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
OUTPUT_PATH - Static variable in class org.apache.reef.io.data.output.TaskOutputServiceBuilder
Path of the directory where output files are created.
OutputService - Interface in org.apache.reef.io.data.output
All output services should implement this interface.
OutputServiceDriver - Class in org.apache.reef.examples.data.output
The Driver code for the output service demo app.
OutputServiceDriver(EvaluatorRequestor, OutputService) - Constructor for class org.apache.reef.examples.data.output.OutputServiceDriver
Job driver constructor - instantiated via TANG.
OutputServiceDriver.ActiveContextHandler - Class in org.apache.reef.examples.data.output
Handles ActiveContext: Submit the output service demo task.
OutputServiceDriver.ActiveContextHandler() - Constructor for class org.apache.reef.examples.data.output.OutputServiceDriver.ActiveContextHandler
 
OutputServiceDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.examples.data.output
Handles AllocatedEvaluator: Submit the output service and a context for it.
OutputServiceDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.examples.data.output.OutputServiceDriver.EvaluatorAllocatedHandler
 
OutputServiceDriver.StartHandler - Class in org.apache.reef.examples.data.output
Handles the StartTime event: Request three Evaluators.
OutputServiceDriver.StartHandler() - Constructor for class org.apache.reef.examples.data.output.OutputServiceDriver.StartHandler
 
OutputServiceREEF - Class in org.apache.reef.examples.data.output
Client for the output service demo app.
OutputServiceREEF.Local - Class in org.apache.reef.examples.data.output
Command line parameter = true to run locally, or false to run on YARN.
OutputServiceREEF.Local() - Constructor for class org.apache.reef.examples.data.output.OutputServiceREEF.Local
 
OutputServiceREEF.OutputDir - Class in org.apache.reef.examples.data.output
Command line parameter = path of the output directory.
OutputServiceREEF.OutputDir() - Constructor for class org.apache.reef.examples.data.output.OutputServiceREEF.OutputDir
 
OutputServiceREEF.TimeOut - Class in org.apache.reef.examples.data.output
Command line parameter = number of minutes before timeout.
OutputServiceREEF.TimeOut() - Constructor for class org.apache.reef.examples.data.output.OutputServiceREEF.TimeOut
 
OutputServiceTask - Class in org.apache.reef.examples.data.output
The Task code for the output service demo app.
OutputServiceTask(OutputStreamProvider) - Constructor for class org.apache.reef.examples.data.output.OutputServiceTask
Task constructor - instantiated via TANG.
OutputStreamProvider - Interface in org.apache.reef.io.data.output
A provider through which users create output streams.

P

PACKAGE_NODE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
packageNode - Variable in class org.apache.reef.tang.implementation.avro.AvroNode
Deprecated.
PackageNode - Interface in org.apache.reef.tang.types
 
PackageNodeImpl - Class in org.apache.reef.tang.implementation.types
 
PackageNodeImpl(Node, String, String) - Constructor for class org.apache.reef.tang.implementation.types.PackageNodeImpl
 
PackageNodeImpl() - Constructor for class org.apache.reef.tang.implementation.types.PackageNodeImpl
 
Pair<T1,T2> - Class in org.apache.reef.io.network.util
 
Pair(T1, T2) - Constructor for class org.apache.reef.io.network.util.Pair
 
Param<T> - Interface in org.apache.reef.tang.formats
 
Parameter - Annotation Type in org.apache.reef.tang.annotations
 
ParameterParser - Class in org.apache.reef.tang.formats
 
ParameterParser() - Constructor for class org.apache.reef.tang.formats.ParameterParser
 
PARENT_CONTEXT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
PARENT_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
ParentAdd_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ParentAdd = 10;
ParentAdded_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ParentAdded = 14;
parentContext - Variable in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Deprecated.
parentContext - Variable in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Deprecated.
ParentDead_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ParentDead = 12;
ParentDeadException - Exception in org.apache.reef.io.network.exception
This exception is thrown by a child task.
ParentDeadException() - Constructor for exception org.apache.reef.io.network.exception.ParentDeadException
 
ParentDeadException(String) - Constructor for exception org.apache.reef.io.network.exception.ParentDeadException
 
ParentDeadException(Throwable) - Constructor for exception org.apache.reef.io.network.exception.ParentDeadException
 
ParentDeadException(String, Throwable) - Constructor for exception org.apache.reef.io.network.exception.ParentDeadException
 
ParentDeadException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.reef.io.network.exception.ParentDeadException
 
parentId - Variable in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Deprecated.
ParentNodeStruct - Class in org.apache.reef.io.network.group.impl.task
 
ParentNodeStruct(String, int) - Constructor for class org.apache.reef.io.network.group.impl.task.ParentNodeStruct
 
ParentRemoved_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ParentRemoved = 16;
ParquetReader - Class in org.apache.reef.experimental.parquet
A reader for Parquet files that can serialize data to local disk and return Avro schema and Avro reader.
parse(T) - Method in interface org.apache.reef.examples.group.bgd.data.parser.Parser
 
parse(String) - Method in class org.apache.reef.examples.group.bgd.data.parser.SVMLightParser
 
parse(Class<T>, String) - Method in class org.apache.reef.tang.formats.ParameterParser
 
parse(String, String) - Method in class org.apache.reef.tang.formats.ParameterParser
 
parse(NamedParameterNode<T>, String) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
Parse a string, assuming that it is of the type expected by a given NamedParameter.
parse(NamedParameterNode<T>, String) - Method in interface org.apache.reef.tang.JavaClassHierarchy
Parse a string value that has been passed into a named parameter.
parseCommandLine(String[]) - Static method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
parseDefaultValue(NamedParameterNode<T>) - Method in class org.apache.reef.tang.implementation.java.ClassHierarchyImpl
A helper method that returns the parsed default value of a given NamedParameter.
parseDefaultValue(NamedParameterNode<T>) - Method in interface org.apache.reef.tang.JavaClassHierarchy
Obtain a parsed instance of the default value of a named parameter.
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
ParsedHttpRequest - Class in org.apache.reef.webserver
Parsed HttpServletRequest.
ParsedHttpRequest(HttpServletRequest) - Constructor for class org.apache.reef.webserver.ParsedHttpRequest
parse HttpServletRequest.
ParseException - Exception in org.apache.reef.tang.exceptions
Thrown when a string fails to parse as the requested type.
ParseException(String, Throwable) - Constructor for exception org.apache.reef.tang.exceptions.ParseException
 
ParseException(String) - Constructor for exception org.apache.reef.tang.exceptions.ParseException
 
parseFrom(ByteString) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(byte[]) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
parseFrom(ByteString) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(byte[]) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
parseFrom(ByteString) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(byte[]) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
parseFrom(ByteString) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(byte[]) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(InputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(byte[]) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(InputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
parseFrom(ByteString) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(byte[]) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(InputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
parseFrom(ByteString) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(byte[]) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(InputStream) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
parseFrom(ByteString) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(byte[]) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(InputStream) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
parseFrom(ByteString) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(byte[]) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(InputStream) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(CodedInputStream) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseList(String, IdentifierFactory) - Static method in class org.apache.reef.io.network.util.Utils
Parse a string of multiple IDs.
Parser<T> - Interface in org.apache.reef.examples.group.bgd.data.parser
Parses inputs into Examples.
PARSER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
PARSER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
PARSER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
PARSER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
PARSER - Static variable in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
PARSER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
PARSER - Static variable in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
PARSER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
PARSER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
PARSER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
PARSER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
PARSER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
PARSER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
PARSER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
PARSER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
PARSER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
PARSER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
PARSER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
PARSER - Static variable in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
PARSER - Static variable in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
PARSER - Static variable in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
parseToConfiguration(String[], Class<? extends Name<?>>...) - Static method in class org.apache.reef.tang.formats.CommandLine
Utility method to quickly parse a command line to a Configuration.
parseToConfigurationBuilder(String[], Class<? extends Name<?>>...) - Static method in class org.apache.reef.tang.formats.CommandLine
Utility method to quickly parse a command line to a ConfigurationBuilder.
PartitionSpec - Class in org.apache.reef.io
This was another more type safe alternative to integer partitions.
PartitionSpec(PartitionSpec.Type, int) - Constructor for class org.apache.reef.io.PartitionSpec
 
PartitionSpec.Type - Enum in org.apache.reef.io
Partition type.
PASSWORD - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The password to be used for connecting to hdinsight.
PASSWORD - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
The password to be used for connecting to hdinsight.
PATH - Static variable in class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration
Path to be used to store the checkpoints on file system.
pathInfo - Variable in class org.apache.reef.webserver.AvroHttpRequest
Deprecated.
peakEdenMemoryUsageMB() - Static method in class org.apache.reef.util.MemoryUtils
 
peakOldMemoryUsageMB() - Static method in class org.apache.reef.util.MemoryUtils
 
peakPermMemoryUsageMB() - Static method in class org.apache.reef.util.MemoryUtils
 
PeriodicEvent - Class in org.apache.reef.wake.impl
Periodic event for timers.
PeriodicEvent() - Constructor for class org.apache.reef.wake.impl.PeriodicEvent
 
PID_FILE_NAME - Static variable in class org.apache.reef.runtime.common.evaluator.PIDStoreStartHandler
The file name of the PID file created in the current working directory of the process.
PIDStoreStartHandler - Class in org.apache.reef.runtime.common.evaluator
This Handler writes the Process ID (PID) to a file with a name given in PID_FILE_NAME to the local working directory.
PLANS_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
PoisonedAlarmHandler - Class in org.apache.reef.poison
To be registered on the Clock to handle Alarms.
PoisonedAlarmHandler() - Constructor for class org.apache.reef.poison.PoisonedAlarmHandler
 
PoisonedConfiguration - Class in org.apache.reef.poison
Configure a Context with a lethal injection.
PoisonedConfiguration() - Constructor for class org.apache.reef.poison.PoisonedConfiguration
 
PoisonedContextStartHandler - Class in org.apache.reef.poison.context
Fault-injected handler for ContextStart.
PoisonedContextStartHandler(double, int, Clock) - Constructor for class org.apache.reef.poison.context.PoisonedContextStartHandler
 
PoisonedTaskStartHandler - Class in org.apache.reef.poison.task
Fault-injected handler for TaskStart.
PoisonedTaskStartHandler(double, int, Clock) - Constructor for class org.apache.reef.poison.task.PoisonedTaskStartHandler
 
PoisonException - Exception in org.apache.reef.poison
Exception thrown by REEF Poison.
PoisonException(String) - Constructor for exception org.apache.reef.poison.PoisonException
 
port - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Deprecated.
port - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Deprecated.
predict(Vector) - Method in interface org.apache.reef.examples.group.bgd.data.Example
Computes the prediction for this Example, given the model w.
predict(Vector) - Method in class org.apache.reef.examples.group.bgd.data.SparseExample
 
PreemptionEvent - Interface in org.apache.reef.driver
Represents Preemption requests issued by the underlying resource manager.
PreemptionHandler - Interface in org.apache.reef.driver
This EventHandler will receive preemption events from the underlying resourcemanager.
PREFIX - Static variable in class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration
Prefix for checkpoint files (optional).
preorder(NodeVisitor<T>, EdgeVisitor<T>, T) - Static method in class org.apache.reef.tang.util.walk.Walk
Traverse the configuration (sub)tree in preorder, starting from the given node.
PreparedDriverFolderLauncher - Class in org.apache.reef.runtime.local.client
Launcher for a already prepared driver folder.
PrintTypeHierarchy - Class in org.apache.reef.tang.examples
Build a Graphviz representation of TANG configuration and injection plan.
PrintTypeHierarchy(int) - Constructor for class org.apache.reef.tang.examples.PrintTypeHierarchy
Constructor to test the parameter injection.
PRIORITY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Private - Annotation Type in org.apache.reef.annotations.audience
Annotates code that is meant to be private to the project it is in.
ProbabilityOfFailure - Class in org.apache.reef.examples.group.bgd.parameters
Break criterion for the optimizer.
ProbabilityOfFailure() - Constructor for class org.apache.reef.examples.group.bgd.parameters.ProbabilityOfFailure
 
ProbabilityOfSuccessfulIteration - Class in org.apache.reef.examples.group.bgd.parameters
Break criterion for the optimizer.
ProbabilityOfSuccessfulIteration() - Constructor for class org.apache.reef.examples.group.bgd.parameters.ProbabilityOfSuccessfulIteration
 
process - Variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Deprecated.
process(Option) - Method in interface org.apache.reef.tang.formats.CommandLine.CommandLineCallback
 
processAcknowledgement(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
Process the msg that was received and update.
processAcknowledgement(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
processCommandLine(String[], Class<? extends Name<?>>...) - Method in class org.apache.reef.tang.formats.CommandLine
Process command line arguments.
ProcessContainer - Class in org.apache.reef.runtime.local.driver
A Container that runs an Evaluator in a Process.
processMsg(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
ProcessType - Enum in org.apache.reef.runtime.common.launch
The type of a process to be launched by the Runtime.
ProfilerState - Class in org.apache.reef.wake.profiler
A class that contains parameters and states for wake profiler.
ProfilingStopHandler - Class in org.apache.reef.runtime.common.launch
An EventHandler that writes out the profiler results.
ProfilingStopHandler(String) - Constructor for class org.apache.reef.runtime.common.launch.ProfilingStopHandler
 
PROGRESS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
PROGRESS_PROVIDER - Static variable in class org.apache.reef.client.DriverConfiguration
Progress provider.
ProgressProvider - Interface in org.apache.reef.driver
Used in the to report the progress of the REEF application.
Protocol - Class in org.apache.reef.bridge.message
 
Protocol() - Constructor for class org.apache.reef.bridge.message.Protocol
Default constructor.
Protocol(Integer) - Constructor for class org.apache.reef.bridge.message.Protocol
All-args constructor.
Protocol.Builder - Class in org.apache.reef.bridge.message
RecordBuilder for Protocol instances.
ProtocolBufferClassHierarchy - Class in org.apache.reef.tang.implementation.protobuf
Deprecated.
in 0.12. Use AvroClassHierarchy instead
ProtocolBufferClassHierarchy(ClassHierarchyProto.Node) - Constructor for class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
in 0.12. Use AvroClassHierarchy instead
ProtocolBufferInjectionPlan - Class in org.apache.reef.tang.implementation.protobuf
 
ProtocolBufferInjectionPlan() - Constructor for class org.apache.reef.tang.implementation.protobuf.ProtocolBufferInjectionPlan
 
Provided - Annotation Type in org.apache.reef.annotations
Indicates that an implementation of the annotated class / interface will be provided by REEF.
Provides<T> - Class in org.apache.reef.tang.formats
 
Provides() - Constructor for class org.apache.reef.tang.formats.Provides
 
ProxyEventHandler<T> - Class in org.apache.reef.wake.remote.impl
Proxy of the event handler that runs remotely.
ProxyEventHandler(RemoteIdentifier, RemoteIdentifier, String, EventHandler<RemoteEvent<T>>, RemoteSeqNumGenerator) - Constructor for class org.apache.reef.wake.remote.impl.ProxyEventHandler
Constructs a proxy event handler.
Public - Annotation Type in org.apache.reef.annotations.audience
Annotates code for public consumption.
publish(LogRecord) - Method in class org.apache.reef.util.logging.CLRBufferedLogHandler
Called whenever a log message is received on the java side.
publish(LogRecord) - Method in class org.apache.reef.util.logging.DFSHandler
 
PubSubEventHandler<T> - Class in org.apache.reef.wake.impl
Event handler that provides publish/subscribe interfaces.
PubSubEventHandler() - Constructor for class org.apache.reef.wake.impl.PubSubEventHandler
Constructs a pub-sub event handler.
PubSubEventHandler(Map<Class<? extends T>, List<EventHandler<? extends T>>>) - Constructor for class org.apache.reef.wake.impl.PubSubEventHandler
Constructs a pub-sub event handler with initial subscribed event handlers.
Pull2Push<T> - Class in org.apache.reef.wake.examples.p2p
Performs a Pull-to-Push conversion in Wake.
Pull2Push(EventHandler<T>) - Constructor for class org.apache.reef.wake.examples.p2p.Pull2Push
 
put(int, Object) - Method in class org.apache.reef.bridge.message.Acknowledgement
 
put(int, Object) - Method in class org.apache.reef.bridge.message.BridgeInterop
 
put(int, Object) - Method in class org.apache.reef.bridge.message.Header
 
put(int, Object) - Method in class org.apache.reef.bridge.message.Protocol
 
put(int, Object) - Method in class org.apache.reef.bridge.message.SetupBridge
 
put(int, Object) - Method in class org.apache.reef.bridge.message.SystemOnStart
 
put(int, Object) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
put(CharSequence, T) - Method in interface org.apache.reef.io.ExternalMap
Put a record into the map.
put(int, Object) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
put(int, Object) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
put(int, Object) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
put(int, Object) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
put(int, Object) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
put(CharSequence, T) - Method in class org.apache.reef.io.storage.ram.CodecRamMap
 
put(CharSequence, T) - Method in class org.apache.reef.io.storage.ram.RamMap
 
put(int, Object) - Method in class org.apache.reef.io.watcher.common.AvroFailure
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
put(int, Object) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
put(int, Object) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
put(int, Object) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
put(int, Object) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
put(int, Object) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
put(int, Object) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
 
put(int, Object) - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
put(int, Object) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
put(EvaluatorManagerFactory, ResourceAllocationEvent) - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
Create new EvaluatorManager and add it to the collection.
put(EvaluatorManager) - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
Adds an EvaluatorManager.
put(int, Object) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
put(int, Object) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
put(int, Object) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
put(int, Object) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
put(int, Object) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
put(int, Object) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
put(int, Object) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
put(int, Object) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
put(int, Object) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
put(int, Object) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
put(int, Object) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
put(int, Object) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
 
put(int, Object) - Method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
put(Node) - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
put(Node) - Method in class org.apache.reef.tang.implementation.types.PackageNodeImpl
Unlike normal nodes, the root node needs to take the package name of its children into account.
put(Node) - Method in interface org.apache.reef.tang.types.Node
 
put(K, V) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
put(T, U) - Method in class org.apache.reef.tang.util.MonotonicHashMap
 
put(T, U) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
put(K, V) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroDriverInfo
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroEvaluatorList
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroHttpRequest
 
put(int, Object) - Method in class org.apache.reef.webserver.AvroReefServiceInfo
 
put(int, Object) - Method in class org.apache.reef.webserver.HeaderEntry
 
put(String, EvaluatorDescriptor) - Method in class org.apache.reef.webserver.ReefEventStateManager
pus a entry to evaluators.
putAll(Map<? extends CharSequence, ? extends T>) - Method in interface org.apache.reef.io.ExternalMap
Copies all of the mappings from the specified map to this map (optional operation).
putAll(Map<? extends CharSequence, ? extends T>) - Method in class org.apache.reef.io.storage.ram.CodecRamMap
 
putAll(Map<? extends CharSequence, ? extends T>) - Method in class org.apache.reef.io.storage.ram.RamMap
 
putAll(Map<? extends T, ? extends U>) - Method in class org.apache.reef.tang.util.MonotonicHashMap
 
putAll(Map<? extends T, ? extends U>) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
putImpl(ClassNode<T>) - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
putImpl(ClassNode<T>) - Method in interface org.apache.reef.tang.types.ClassNode
 

Q

queNProcessMsg(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
queryString - Variable in class org.apache.reef.webserver.AvroHttpRequest
Deprecated.
QUEUE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
QUEUE - Static variable in class org.apache.reef.runtime.yarn.client.YarnDriverConfiguration
The queue to submit this Driver to.

R

RACK_NAME_FORMATTER - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
RACK_NAME_FORMATTER - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
RACK_NAMES - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
The rack names that will be available in the local runtime.
RACK_NAMES - Static variable in class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
The rack names that will be available in the local runtime.
RACK_NAMES - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The rack names that will be available in the local runtime.
RACK_PATH_SEPARATOR - Static variable in class org.apache.reef.runtime.common.utils.Constants
Rack path separator.
RackDescriptor - Interface in org.apache.reef.driver.catalog
A rack in the cluster.
rackDescriptor - Variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Deprecated.
RackDescriptorImpl - Class in org.apache.reef.runtime.common.driver.catalog
A rack in the cluster.
RackNameFormatter - Interface in org.apache.reef.runtime.yarn.driver
Provides a method to retrieve the rack name from a container, which may be dependent on the Hadoop distribution.
RackNameParameter - Class in org.apache.reef.tests.rack.awareness
Rack name.
RackNameParameter() - Constructor for class org.apache.reef.tests.rack.awareness.RackNameParameter
 
rackNames - Variable in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Deprecated.
RackNames - Class in org.apache.reef.runtime.local.client.parameters
The name of the default racks available in the local runtime.
RamMap<T> - Class in org.apache.reef.io.storage.ram
Simple in-memory ExternalMap implementation.
RamMap(RamStorageService) - Constructor for class org.apache.reef.io.storage.ram.RamMap
 
RamSpool<T> - Class in org.apache.reef.io.storage.ram
A SpoolFile implementation that is backed by RAM.
RamSpool(RamStorageService) - Constructor for class org.apache.reef.io.storage.ram.RamSpool
 
RamStorageService - Class in org.apache.reef.io.storage.ram
 
RamStorageService() - Constructor for class org.apache.reef.io.storage.ram.RamStorageService
 
rand(int) - Static method in class org.apache.reef.examples.group.utils.math.DenseVector
Creates a random Vector of size 'size' where each element is individually.
rand(int, Random) - Static method in class org.apache.reef.examples.group.utils.math.DenseVector
Creates a random Vector of size 'size' where each element is individually.
RandomNameCNS - Class in org.apache.reef.io.checkpoint
A naming service that generates a random checkpoint name by appending a random alphanumeric string (suffix) of a given length to a user-supplied prefix string.
RandomNameCNS(String) - Constructor for class org.apache.reef.io.checkpoint.RandomNameCNS
Deprecated.
RandomNameCNS.LengthOfRandomSuffix - Class in org.apache.reef.io.checkpoint
Number of alphanumeric characters in the random part of a checkpoint name.
RandomNameCNS.LengthOfRandomSuffix() - Constructor for class org.apache.reef.io.checkpoint.RandomNameCNS.LengthOfRandomSuffix
 
RandomNameCNS.PREFIX - Class in org.apache.reef.io.checkpoint
The prefix used for the random names returned.
RandomNameCNS.PREFIX() - Constructor for class org.apache.reef.io.checkpoint.RandomNameCNS.PREFIX
 
RangeTcpPortProvider - Class in org.apache.reef.wake.remote.ports
A TcpPortProvider which gives out random ports in a range.
RangeTcpPortProvider(int, int, int) - Constructor for class org.apache.reef.wake.remote.ports.RangeTcpPortProvider
 
raw() - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
readExternal(ObjectInput) - Method in class org.apache.reef.bridge.message.Acknowledgement
 
readExternal(ObjectInput) - Method in class org.apache.reef.bridge.message.BridgeInterop
 
readExternal(ObjectInput) - Method in class org.apache.reef.bridge.message.Header
 
readExternal(ObjectInput) - Method in class org.apache.reef.bridge.message.Protocol
 
readExternal(ObjectInput) - Method in class org.apache.reef.bridge.message.SetupBridge
 
readExternal(ObjectInput) - Method in class org.apache.reef.bridge.message.SystemOnStart
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.common.AvroFailure
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
readExternal(ObjectInput) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
readExternal(ObjectInput) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
 
readExternal(ObjectInput) - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
readExternal(ObjectInput) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
readExternal(ObjectInput) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
readExternal(ObjectInput) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
readExternal(ObjectInput) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
readExternal(ObjectInput) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
 
readExternal(ObjectInput) - Method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroDriverInfo
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroEvaluatorList
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroHttpRequest
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.AvroReefServiceInfo
 
readExternal(ObjectInput) - Method in class org.apache.reef.webserver.HeaderEntry
 
readFields(DataInput) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
readFrame() - Method in class org.apache.reef.io.storage.FramingInputStream
 
readFromEvaluatorLog() - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogAppendReaderWriter
 
readFromEvaluatorLog() - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogOverwriteReaderWriter
Since the FileSystem does not support appends, this DFSEvaluatorLogReaderWriter uses a two-file approach, where when we read, we always read from the newer file.
readFromEvaluatorLog() - Method in interface org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogReaderWriter
Reads a formatted entry (addition or removal) from the DFS evaluator log.
READY_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
READY = 0;
RealTimer - Class in org.apache.reef.wake.time.runtime
Implementation of the Timer that uses the system clock.
reason - Variable in class org.apache.reef.io.watcher.common.AvroFailure
Deprecated.
receive() - Method in interface org.apache.reef.io.network.group.api.operators.Broadcast.Receiver
Receiver the element broadcasted by sender.
receive() - Method in interface org.apache.reef.io.network.group.api.operators.Gather.Receiver
Receive the elements sent by the senders in default order.
receive(List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.Gather.Receiver
Receive the elements sent by the senders in specified order.
receive() - Method in interface org.apache.reef.io.network.group.api.operators.Scatter.Receiver
Receive the sub-list of elements targeted for the current receiver.
receive() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
receive() - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
receive(List<? extends Identifier>) - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
receive() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
recordAllocatedEvaluator(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Records the evaluators when it is allocated.
recordAllocatedEvaluator(String) - Method in interface org.apache.reef.driver.restart.DriverRuntimeRestartManager
Records the evaluators when it is allocated.
recordAllocatedEvaluator(String) - Method in interface org.apache.reef.runtime.common.driver.EvaluatorPreserver
Called when an evaluator is to be preserved.
recordAllocatedEvaluator(String) - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorPreserver
Adds the allocated evaluator entry to the evaluator log.
recordAllocatedEvaluator(String) - Method in class org.apache.reef.runtime.yarn.driver.YarnDriverRuntimeRestartManager
 
recordRemovedEvaluator(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Records a removed evaluator into the evaluator log.
recordRemovedEvaluator(String) - Method in interface org.apache.reef.driver.restart.DriverRuntimeRestartManager
Records a removed evaluator into the evaluator log.
recordRemovedEvaluator(String) - Method in interface org.apache.reef.runtime.common.driver.EvaluatorPreserver
Called when an evaluator is to be removed.
recordRemovedEvaluator(String) - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorPreserver
Adds the removed evaluator entry to the evaluator log.
recordRemovedEvaluator(String) - Method in class org.apache.reef.runtime.yarn.driver.YarnDriverRuntimeRestartManager
 
recoverEvaluators() - Method in interface org.apache.reef.runtime.common.driver.EvaluatorPreserver
Called on driver restart when evaluators are to be recovered.
recoverEvaluators() - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorPreserver
Recovers the set of evaluators that are alive.
RECOVERY_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
RECOVERY_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
RECOVERY_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
recvFromChildren(Reduce.ReduceFunction<T>, Codec<T>) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
recvFromChildren() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
recvFromChildren(Reduce.ReduceFunction<T>, Codec<T>) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
recvFromChildren() - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
recvFromChildren(Reduce.ReduceFunction<T>, Codec<T>) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
recvFromChildren() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
recvFromChildren(Reduce.ReduceFunction<T>, Codec<T>) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
recvFromChildren() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
Receive data from all children as a single byte array.
recvFromParent(ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
recvFromParent(ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
recvFromParent(ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
recvFromParent(ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
Reduce - Interface in org.apache.reef.io.network.group.api.operators
MPI Reduce operator.
reduce() - Method in interface org.apache.reef.io.network.group.api.operators.Reduce.Receiver
Receive values sent by senders and pass them through the reduce function in default order.
reduce(List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.Reduce.Receiver
Receive values sent by senders and pass them through the reduce function in specified order.
reduce() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
reduce(List<? extends Identifier>) - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
Reduce.Receiver<T> - Interface in org.apache.reef.io.network.group.api.operators
Receiver or Root.
Reduce.ReduceFunction<T> - Interface in org.apache.reef.io.network.group.api.operators
Interface for a Reduce Function takes in an Iterable returns an.
Reduce.Sender<T> - Interface in org.apache.reef.io.network.group.api.operators
Senders or non roots.
Reduce_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
Reduce = 4;
ReduceFunctionParam - Class in org.apache.reef.io.network.group.impl.config.parameters
The reduce function class that is associated with a reduce operator.
ReduceOperatorSpec - Class in org.apache.reef.io.network.group.impl.config
The specification for the Reduce operator.
ReduceOperatorSpec(String, Class<? extends Codec>, Class<? extends Reduce.ReduceFunction>) - Constructor for class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec
 
ReduceOperatorSpec.Builder - Class in org.apache.reef.io.network.group.impl.config
 
ReduceOperatorSpec.Builder() - Constructor for class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec.Builder
 
ReduceReceiver<T> - Class in org.apache.reef.io.network.group.impl.operators
 
ReduceReceiver(String, String, String, Codec<T>, Reduce.ReduceFunction<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient) - Constructor for class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
ReduceScatter<T> - Interface in org.apache.reef.io.network.group.api.operators
MPI Reduce Scatter operator.
ReduceScatter_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
ReduceScatter = 7;
ReduceSender<T> - Class in org.apache.reef.io.network.group.impl.operators
 
ReduceSender(String, String, String, Codec<T>, Reduce.ReduceFunction<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient) - Constructor for class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
REEF - Interface in org.apache.reef.client
The main entry point into the REEF resourcemanager.
REEF_SUBMIT - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
REEF_UNINITIALIZED_VALUE - Static variable in annotation type org.apache.reef.tang.annotations.NamedParameter
 
REEF_YARN_APPLICATION_ID_ENV_VAR - Static variable in class org.apache.reef.runtime.yarn.util.YarnUtilities
 
REEFEnvironment - Class in org.apache.reef.runtime.common
The main entry point into any REEF process (Driver and Evaluator).
REEFErrorHandler - Class in org.apache.reef.runtime.common.launch
The error handler REEF registers with Wake.
REEFEventHandlers - Class in org.apache.reef.runtime.yarn.driver
Helper that represents the REEF layer to the YARN runtime.
ReefEventStateManager - Class in org.apache.reef.webserver
Reef Event Manager that manages Reef states.
ReefEventStateManager(RemoteManager, DriverStatusManager) - Constructor for class org.apache.reef.webserver.ReefEventStateManager
ReefEventStateManager that keeps the states of Reef components.
ReefEventStateManager.ActiveContextStateHandler - Class in org.apache.reef.webserver
Receive notification that a new Context is available.
ReefEventStateManager.ActiveContextStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.ActiveContextStateHandler
 
ReefEventStateManager.AllocatedEvaluatorStateHandler - Class in org.apache.reef.webserver
Receive notification that an Evaluator had been allocated.
ReefEventStateManager.AllocatedEvaluatorStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.AllocatedEvaluatorStateHandler
 
ReefEventStateManager.ClientMessageStateHandler - Class in org.apache.reef.webserver
Receive notification from the client.
ReefEventStateManager.ClientMessageStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.ClientMessageStateHandler
 
ReefEventStateManager.DriverRestartActiveContextStateHandler - Class in org.apache.reef.webserver
Receive notification that a new Context is available.
ReefEventStateManager.DriverRestartActiveContextStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.DriverRestartActiveContextStateHandler
 
ReefEventStateManager.DriverRestartHandler - Class in org.apache.reef.webserver
Job Driver has been restarted.
ReefEventStateManager.DriverRestartHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.DriverRestartHandler
 
ReefEventStateManager.DriverRestartTaskRunningStateHandler - Class in org.apache.reef.webserver
Receive event during driver restart that a task is running in previous evaluator.
ReefEventStateManager.DriverRestartTaskRunningStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.DriverRestartTaskRunningStateHandler
 
ReefEventStateManager.StartStateHandler - Class in org.apache.reef.webserver
Job Driver is ready and the clock is set up.
ReefEventStateManager.StartStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.StartStateHandler
 
ReefEventStateManager.StopStateHandler - Class in org.apache.reef.webserver
Job driver stopped, log the stop time.
ReefEventStateManager.StopStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.StopStateHandler
 
ReefEventStateManager.TaskRunningStateHandler - Class in org.apache.reef.webserver
Receive event when task is running.
ReefEventStateManager.TaskRunningStateHandler() - Constructor for class org.apache.reef.webserver.ReefEventStateManager.TaskRunningStateHandler
 
REEFExecutor - Class in org.apache.reef.runtime.mesos.evaluator
REEF implementation of Mesos Executor.
REEFFileNames - Class in org.apache.reef.runtime.common.files
Access to the various places things go according to the REEF file system standard.
REEFFileNames() - Constructor for class org.apache.reef.runtime.common.files.REEFFileNames
 
REEFImplementation - Class in org.apache.reef.runtime.common.client
Default REEF implementation.
REEFImplementation.DriverRemoteIdentifier - Class in org.apache.reef.runtime.common.client
The driver remote identifier.
REEFImplementation.DriverRemoteIdentifier() - Constructor for class org.apache.reef.runtime.common.client.REEFImplementation.DriverRemoteIdentifier
 
REEFLauncher - Class in org.apache.reef.runtime.common
The main entry point into any REEF process (Driver and Evaluator).
REEFMessageCodec - Class in org.apache.reef.runtime.common.launch
Codec for REEF's control flow messages.
ReefNetworkGroupCommProtos - Class in org.apache.reef.io.network.proto
 
ReefNetworkGroupCommProtos.GroupCommMessage - Class in org.apache.reef.io.network.proto
Protobuf type GroupCommMessage
ReefNetworkGroupCommProtos.GroupCommMessage.Builder - Class in org.apache.reef.io.network.proto
Protobuf type GroupCommMessage
ReefNetworkGroupCommProtos.GroupCommMessage.Type - Enum in org.apache.reef.io.network.proto
Protobuf enum GroupCommMessage.Type
ReefNetworkGroupCommProtos.GroupCommMessageOrBuilder - Interface in org.apache.reef.io.network.proto
 
ReefNetworkGroupCommProtos.GroupMessageBody - Class in org.apache.reef.io.network.proto
Protobuf type GroupMessageBody
ReefNetworkGroupCommProtos.GroupMessageBody.Builder - Class in org.apache.reef.io.network.proto
Protobuf type GroupMessageBody
ReefNetworkGroupCommProtos.GroupMessageBodyOrBuilder - Interface in org.apache.reef.io.network.proto
 
ReefNetworkServiceProtos - Class in org.apache.reef.io.network.proto
 
ReefNetworkServiceProtos.NSMessagePBuf - Class in org.apache.reef.io.network.proto
Protobuf type NSMessagePBuf
ReefNetworkServiceProtos.NSMessagePBuf.Builder - Class in org.apache.reef.io.network.proto
Protobuf type NSMessagePBuf
ReefNetworkServiceProtos.NSMessagePBufOrBuilder - Interface in org.apache.reef.io.network.proto
 
ReefNetworkServiceProtos.NSRecordPBuf - Class in org.apache.reef.io.network.proto
Protobuf type NSRecordPBuf
ReefNetworkServiceProtos.NSRecordPBuf.Builder - Class in org.apache.reef.io.network.proto
Protobuf type NSRecordPBuf
ReefNetworkServiceProtos.NSRecordPBufOrBuilder - Interface in org.apache.reef.io.network.proto
 
REEFProtocol - Class in org.apache.reef.proto
 
REEFProtocol.REEFMessage - Class in org.apache.reef.proto
Protobuf type REEFMessage
REEFProtocol.REEFMessage.Builder - Class in org.apache.reef.proto
Protobuf type REEFMessage
REEFProtocol.REEFMessageOrBuilder - Interface in org.apache.reef.proto
 
ReefRunnableProcessObserver - Class in org.apache.reef.runtime.local.process
a RunnableProcessObserver that relies events to REEF's ResourceStatusHandler.
ReefRunnableProcessObserver(EventHandler<ResourceStatusEvent>, InjectionFuture<ResourceManager>) - Constructor for class org.apache.reef.runtime.local.process.ReefRunnableProcessObserver
 
ReefServiceProtos - Class in org.apache.reef.proto
 
ReefServiceProtos.ContextStatusProto - Class in org.apache.reef.proto
Protobuf type ContextStatusProto
ReefServiceProtos.ContextStatusProto.Builder - Class in org.apache.reef.proto
Protobuf type ContextStatusProto
ReefServiceProtos.ContextStatusProto.ContextMessageProto - Class in org.apache.reef.proto
Protobuf type ContextStatusProto.ContextMessageProto
ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder - Class in org.apache.reef.proto
Protobuf type ContextStatusProto.ContextMessageProto
ReefServiceProtos.ContextStatusProto.ContextMessageProtoOrBuilder - Interface in org.apache.reef.proto
 
ReefServiceProtos.ContextStatusProto.State - Enum in org.apache.reef.proto
Protobuf enum ContextStatusProto.State
ReefServiceProtos.ContextStatusProtoOrBuilder - Interface in org.apache.reef.proto
 
ReefServiceProtos.EvaluatorStatusProto - Class in org.apache.reef.proto
Protobuf type EvaluatorStatusProto
ReefServiceProtos.EvaluatorStatusProto.Builder - Class in org.apache.reef.proto
Protobuf type EvaluatorStatusProto
ReefServiceProtos.EvaluatorStatusProtoOrBuilder - Interface in org.apache.reef.proto
 
ReefServiceProtos.JobStatusProto - Class in org.apache.reef.proto
Protobuf type JobStatusProto
ReefServiceProtos.JobStatusProto.Builder - Class in org.apache.reef.proto
Protobuf type JobStatusProto
ReefServiceProtos.JobStatusProtoOrBuilder - Interface in org.apache.reef.proto
 
ReefServiceProtos.RuntimeErrorProto - Class in org.apache.reef.proto
Protobuf type RuntimeErrorProto
ReefServiceProtos.RuntimeErrorProto.Builder - Class in org.apache.reef.proto
Protobuf type RuntimeErrorProto
ReefServiceProtos.RuntimeErrorProtoOrBuilder - Interface in org.apache.reef.proto
 
ReefServiceProtos.State - Enum in org.apache.reef.proto
Protobuf enum State
ReefServiceProtos.TaskStatusProto - Class in org.apache.reef.proto
Protobuf type TaskStatusProto
ReefServiceProtos.TaskStatusProto.Builder - Class in org.apache.reef.proto
Protobuf type TaskStatusProto
ReefServiceProtos.TaskStatusProto.TaskMessageProto - Class in org.apache.reef.proto
Protobuf type TaskStatusProto.TaskMessageProto
ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder - Class in org.apache.reef.proto
Protobuf type TaskStatusProto.TaskMessageProto
ReefServiceProtos.TaskStatusProto.TaskMessageProtoOrBuilder - Interface in org.apache.reef.proto
 
ReefServiceProtos.TaskStatusProtoOrBuilder - Interface in org.apache.reef.proto
 
reefSubmit() - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time to call Reef.Submit.
REEFUncaughtExceptionHandler - Class in org.apache.reef.runtime.common.launch
This is used as the Exception handler for REEF client processes (Driver, Evaluator).
REEFUncaughtExceptionHandler(Configuration) - Constructor for class org.apache.reef.runtime.common.launch.REEFUncaughtExceptionHandler
 
REEFVersion - Class in org.apache.reef.util
Version information, retrieved from the pom (via a properties file reference).
REEFVersion() - Constructor for class org.apache.reef.util.REEFVersion
 
ReflectionUtilities - Class in org.apache.reef.tang.util
 
REGEXP - Static variable in class org.apache.reef.tang.util.ReflectionUtilities
This is used to split Java classnames.
register(Identifier, InetSocketAddress) - Method in interface org.apache.reef.io.naming.NamingRegistry
Register the given Address for the given Identifier.
register(Class<? extends Name<String>>, EventHandler<GroupCommunicationMessage>) - Method in interface org.apache.reef.io.network.group.api.task.CommGroupNetworkHandler
 
register(Class<? extends Name<String>>, EventHandler<GroupCommunicationMessage>) - Method in interface org.apache.reef.io.network.group.api.task.GroupCommNetworkHandler
 
register(Class<? extends Name<String>>, EventHandler<GroupCommunicationMessage>) - Method in class org.apache.reef.io.network.group.impl.task.CommGroupNetworkHandlerImpl
 
register(Class<? extends Name<String>>, EventHandler<GroupCommunicationMessage>) - Method in class org.apache.reef.io.network.group.impl.task.GroupCommNetworkHandlerImpl
 
register(Identifier, InetSocketAddress) - Method in class org.apache.reef.io.network.naming.LocalNameResolverImpl
 
register(Identifier, InetSocketAddress) - Method in class org.apache.reef.io.network.naming.NameClient
Registers an (identifier, address) mapping.
register(Identifier, InetSocketAddress) - Method in class org.apache.reef.io.network.naming.NameRegistryClient
Registers an (identifier, address) mapping.
register(Identifier, InetSocketAddress) - Method in interface org.apache.reef.io.network.naming.NameServer
Registers an (identifier, address) mapping locally.
register(Identifier, InetSocketAddress) - Method in class org.apache.reef.io.network.naming.NameServerImpl
Registers an (identifier, address) mapping locally.
register(Class<T>, Set<EventHandler<U>>) - Method in class org.apache.reef.runtime.common.utils.DispatchingEStage
Register a new event handler.
register(EventSource<T>) - Method in class org.apache.reef.wake.examples.p2p.Pull2Push
Registers an event source.
register(Stage) - Method in class org.apache.reef.wake.impl.StageManager
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.proto.ClientRuntimeProtocol
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.proto.EvaluatorRuntimeProtocol
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.proto.REEFProtocol
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.proto.ReefServiceProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.tang.proto.ClassHierarchyProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.tang.proto.InjectionPlanProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.reef.wake.test.proto.TestProtos
 
registerConnectionFactory(Identifier, Codec<T>, EventHandler<Message<T>>, LinkListener<Message<T>>, Identifier) - Method in class org.apache.reef.io.network.impl.NetworkConnectionServiceImpl
 
registerConnectionFactory(Identifier, Codec<T>, EventHandler<Message<T>>, LinkListener<Message<T>>, Identifier) - Method in interface org.apache.reef.io.network.NetworkConnectionService
Registers an instance of ConnectionFactory corresponding to the connectionFactoryId.
registered(ExecutorDriver, Protos.ExecutorInfo, Protos.FrameworkInfo, Protos.SlaveInfo) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
registerErrorHandler(EventHandler<Exception>) - Method in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Registers the exception event handler.
registerErrorHandler(EventHandler<Exception>) - Method in interface org.apache.reef.wake.remote.transport.Transport
Registers the exception handler.
registerHandler(String, Class<U>, EventHandler<T>) - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
registerHandler(Class<U>, EventHandler<RemoteMessage<T>>) - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
registerHandler(Class<U>, EventHandler<RemoteMessage<T>>) - Method in class org.apache.reef.runtime.mesos.util.MesosRemoteManager
 
registerHandler(RemoteIdentifier, Class<U>, EventHandler<T>) - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
Registers an event handler for a remote identifier and a message type and.
registerHandler(Class<U>, EventHandler<RemoteMessage<T>>) - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
Registers an event handler for a message type and returns a subscription.
registerHandler(RemoteIdentifier, Class<U>, EventHandler<T>) - Method in interface org.apache.reef.wake.remote.RemoteManager
Registers the given EventHandler to be invoked when messages of Type T arrive from sourceIdentifier.
registerHandler(Class<U>, EventHandler<RemoteMessage<T>>) - Method in interface org.apache.reef.wake.remote.RemoteManager
Registers the given EventHandler to be called for the given message type from any source.
registerId(Identifier) - Method in class org.apache.reef.io.network.impl.NetworkService
 
registerLegacyConstructor(ClassNode<?>, ClassNode<?>...) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Force Tang to treat the specified constructor as though it had an @Inject annotation.
registerLegacyConstructor(String, String...) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Force Tang to treat the specified constructor as though it had an @Inject annotation.
registerLegacyConstructor(ClassNode<?>, ConstructorArg...) - Method in interface org.apache.reef.tang.ConfigurationBuilder
Force Tang to treat the specified constructor as though it had an @Inject annotation.
registerLegacyConstructor(ClassNode<?>, ConstructorArg...) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
registerLegacyConstructor(String, String...) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
registerLegacyConstructor(ClassNode<?>, ClassNode<?>...) - Method in class org.apache.reef.tang.implementation.ConfigurationBuilderImpl
 
registerServiceInfo(AvroReefServiceInfo) - Method in class org.apache.reef.webserver.ReefEventStateManager
 
registerShortNameOfClass(String) - Method in class org.apache.reef.tang.formats.CommandLine
 
registerShortNameOfClass(Class<? extends Name<?>>) - Method in class org.apache.reef.tang.formats.CommandLine
 
registerShortNames(CommandLine) - Static method in class org.apache.reef.examples.group.bgd.parameters.BGDControlParameters
 
releaseResourceRequestGate() - Method in class org.apache.reef.io.data.loading.api.ResourceRequestHandler
 
REMOTE_CONNECTION_NUMBER_OF_RETRIES - Static variable in class org.apache.reef.wake.remote.RemoteConfiguration
The number of tries to reconnect the remote connection.
REMOTE_CONNECTION_RETRY_TIMEOUT - Static variable in class org.apache.reef.wake.remote.RemoteConfiguration
The timeout of connection retrying.
REMOTE_EXECUTOR_SHUTDOWN_TIMEOUT - Static variable in class org.apache.reef.wake.WakeParameters
 
remoteAddress() - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Gets the remote socket address.
RemoteConfiguration - Class in org.apache.reef.wake.remote
Configuration options and helper methods for Wake remoting.
RemoteConfiguration.ErrorHandler - Class in org.apache.reef.wake.remote
The event handler to be used for throwables.
RemoteConfiguration.ErrorHandler() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.ErrorHandler
 
RemoteConfiguration.HostAddress - Class in org.apache.reef.wake.remote
The host address to be used for messages.
RemoteConfiguration.HostAddress() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.HostAddress
 
RemoteConfiguration.ManagerName - Class in org.apache.reef.wake.remote
The name of the remote manager.
RemoteConfiguration.ManagerName() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.ManagerName
 
RemoteConfiguration.MessageCodec - Class in org.apache.reef.wake.remote
The codec to be used for messages.
RemoteConfiguration.MessageCodec() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.MessageCodec
 
RemoteConfiguration.NumberOfTries - Class in org.apache.reef.wake.remote
The number of tries.
RemoteConfiguration.NumberOfTries() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.NumberOfTries
 
RemoteConfiguration.OrderingGuarantee - Class in org.apache.reef.wake.remote
Whether or not to use the message ordering guarantee.
RemoteConfiguration.OrderingGuarantee() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.OrderingGuarantee
 
RemoteConfiguration.Port - Class in org.apache.reef.wake.remote
The port to be used for messages.
RemoteConfiguration.Port() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.Port
 
RemoteConfiguration.RemoteClientStage - Class in org.apache.reef.wake.remote
Client stage for messaging transport.
RemoteConfiguration.RemoteClientStage() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.RemoteClientStage
 
RemoteConfiguration.RemoteServerStage - Class in org.apache.reef.wake.remote
Server stage for messaging transport.
RemoteConfiguration.RemoteServerStage() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.RemoteServerStage
 
RemoteConfiguration.RetryTimeout - Class in org.apache.reef.wake.remote
The timeout of connection retrying.
RemoteConfiguration.RetryTimeout() - Constructor for class org.apache.reef.wake.remote.RemoteConfiguration.RetryTimeout
 
RemoteEvent<T> - Class in org.apache.reef.wake.remote.impl
Event that are exchanged across process boundaries.
RemoteEvent(SocketAddress, SocketAddress, long, T) - Constructor for class org.apache.reef.wake.remote.impl.RemoteEvent
Constructs a remote event.
RemoteEventCodec<T> - Class in org.apache.reef.wake.remote.impl
Codec of the event sent remotely.
RemoteEventCodec(Codec<T>) - Constructor for class org.apache.reef.wake.remote.impl.RemoteEventCodec
Constructs a remote event codec.
RemoteEventComparator<T> - Class in org.apache.reef.wake.remote.impl
Comparator for the remote event.
RemoteEventComparator() - Constructor for class org.apache.reef.wake.remote.impl.RemoteEventComparator
 
RemoteEventDecoder<T> - Class in org.apache.reef.wake.remote.impl
Remote event decoder using the WakeMessage protocol buffer.
RemoteEventDecoder(Decoder<T>) - Constructor for class org.apache.reef.wake.remote.impl.RemoteEventDecoder
Constructs a remote event decoder.
RemoteEventEncoder<T> - Class in org.apache.reef.wake.remote.impl
Remote event encoder using the WakeMessage protocol buffer.
RemoteEventEncoder(Encoder<T>) - Constructor for class org.apache.reef.wake.remote.impl.RemoteEventEncoder
Constructs a remote event encoder.
remoteId - Variable in class org.apache.reef.webserver.AvroDriverInfo
Deprecated.
RemoteIdentifier - Interface in org.apache.reef.wake.remote
Wake remote identifier.
RemoteIdentifierFactory - Interface in org.apache.reef.wake.remote
Factory that creates a RemoteIdentifier.
remoteLookup(Identifier) - Method in class org.apache.reef.io.network.naming.NameClient
Retrieves an address for an identifier remotely.
remoteLookup(Identifier) - Method in class org.apache.reef.io.network.naming.NameLookupClient
Retrieves an address for an identifier remotely.
RemoteManager - Class in org.apache.reef.runtime.common.utils
Wrapper for org.apache.reef.wake.remote.RemoteManager.
RemoteManager(RemoteManager, RemoteIdentifierFactory) - Constructor for class org.apache.reef.runtime.common.utils.RemoteManager
 
RemoteManager - Interface in org.apache.reef.wake.remote
Represents all remote connections to and from one process to another.
RemoteManagerFactory - Interface in org.apache.reef.wake.remote
Injectable Factory for RemoteManager instances.
RemoteMessage<T> - Interface in org.apache.reef.wake.remote
Message received from a remote handler.
RemoteNodeManager - Class in org.apache.reef.runtime.standalone.driver
Management module for remote nodes in standalone runtime.
RemoteReceiverStage - Class in org.apache.reef.wake.remote.impl
Receive incoming events and dispatch to correct handlers.
RemoteReceiverStage(EventHandler<RemoteEvent<byte[]>>, EventHandler<Throwable>, int) - Constructor for class org.apache.reef.wake.remote.impl.RemoteReceiverStage
Constructs a remote receiver stage.
RemoteRuntimeException - Exception in org.apache.reef.wake.remote.exception
Wake remote runtime exception.
RemoteRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.wake.remote.exception.RemoteRuntimeException
Constructs a new runtime remote exception with the specified detail message and cause.
RemoteRuntimeException(String) - Constructor for exception org.apache.reef.wake.remote.exception.RemoteRuntimeException
Constructs a new runtime remote exception with the specified detail message.
RemoteRuntimeException(Throwable) - Constructor for exception org.apache.reef.wake.remote.exception.RemoteRuntimeException
Constructs a new runtime remote exception with the specified cause.
RemoteSenderStage - Class in org.apache.reef.wake.remote.impl
Stage to manage resources related to sending event remotely.
RemoteSenderStage(Encoder, Transport, int) - Constructor for class org.apache.reef.wake.remote.impl.RemoteSenderStage
Constructs a remote sender stage.
RemoteSeqNumGenerator - Class in org.apache.reef.wake.remote.impl
Generates the sequence number for remote messages per destination.
RemoteSeqNumGenerator() - Constructor for class org.apache.reef.wake.remote.impl.RemoteSeqNumGenerator
 
remove(CharSequence) - Method in interface org.apache.reef.io.ExternalMap
Removes the mapping for a key from this map if it is present (optional operation).
remove(K, V) - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
remove(L) - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
remove(K, V) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
remove(MsgKey) - Method in class org.apache.reef.io.network.group.impl.utils.SetMap
 
remove() - Method in class org.apache.reef.io.storage.MergingIterator
 
remove(CharSequence) - Method in class org.apache.reef.io.storage.ram.CodecRamMap
 
remove(CharSequence) - Method in class org.apache.reef.io.storage.ram.RamMap
 
remove(Object) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
remove(Object) - Method in class org.apache.reef.tang.util.MonotonicHashMap
 
remove(Object) - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
remove(Object) - Method in class org.apache.reef.tang.util.MonotonicSet
 
remove(Object) - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
remove(Object) - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
REMOVE_CONTEXT_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
removeAll(Collection<?>) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
removeAll(Collection<?>) - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
removeAll(Collection<?>) - Method in class org.apache.reef.tang.util.MonotonicSet
 
removeArgs(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
removeArgs(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
removeChild(TaskNode) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
removeChild(TaskNode) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
removeChildren(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
removeClosedEvaluator(EvaluatorManager) - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
Moves evaluator from map of active evaluators to set of closed evaluators.
removeContextMessage(int) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
removeContextStatus(int) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
removeInjectableConstructors(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
removeMsgs(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
removeMsgs(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
removeOtherConstructors(int) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
removePlans(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
removeTask(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Remove task with id 'taskId' from.
removeTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
removeTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
removeTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
removeTaskMessage(int) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
renewFailedEvaluators(boolean) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
REPLICATION_FACTOR - Static variable in class org.apache.reef.io.checkpoint.fs.FSCheckPointServiceConfiguration
Replication factor to be used for the checkpoints.
requestUrl - Variable in class org.apache.reef.webserver.AvroHttpRequest
Deprecated.
RequiredImpl<T> - Class in org.apache.reef.tang.formats
 
RequiredImpl() - Constructor for class org.apache.reef.tang.formats.RequiredImpl
 
RequiredParameter<T> - Class in org.apache.reef.tang.formats
 
RequiredParameter() - Constructor for class org.apache.reef.tang.formats.RequiredParameter
 
reregistered(ExecutorDriver, Protos.SlaveInfo) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
reset() - Static method in class org.apache.reef.tang.implementation.TangImpl
Only for testing.
resetPeakUsage() - Static method in class org.apache.reef.util.MemoryUtils
 
ResettingCountDownLatch - Class in org.apache.reef.io.network.group.impl.utils
 
ResettingCountDownLatch(int) - Constructor for class org.apache.reef.io.network.group.impl.utils.ResettingCountDownLatch
 
resetTopologySetupSent() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
reset topology setup ensures that update topology is not sent to someone.
resetTopologySetupSent() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
RESOURCE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Resource - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
Represents the resoure field in the YARN REST API.
Resource() - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.Resource
 
ResourceAllocationEvent - Interface in org.apache.reef.runtime.common.driver.resourcemanager
Event from Driver Runtime to Driver Process A Resource allocated by the Driver Runtime.
ResourceAllocationHandler - Class in org.apache.reef.runtime.common.driver.resourcemanager
Handles new resource allocations by adding a new EvaluatorManager.
ResourceCatalog - Interface in org.apache.reef.driver.catalog
A catalog of the resources available to a REEF instance.
ResourceCatalog.Descriptor - Interface in org.apache.reef.driver.catalog
Resource descriptor interface.
ResourceCatalogImpl - Class in org.apache.reef.runtime.common.driver.catalog
A catalog of the resources available to a REEF instance.
ResourceEvent - Interface in org.apache.reef.runtime.common.driver.resourcemanager
An interface capturing the characteristics of a resource event.
ResourceEventImpl - Class in org.apache.reef.runtime.common.driver.resourcemanager
Default POJO implementation of ResourceAllocationEvent and ResourceRecoverEvent.
ResourceEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.resourcemanager
Builder used to create ResourceAllocationEvent instances.
ResourceLaunchEvent - Interface in org.apache.reef.runtime.common.driver.api
Event from Driver Process to Driver Runtime.
ResourceLaunchEventImpl - Class in org.apache.reef.runtime.common.driver.api
Default POJO implementation of ResourceLaunchEvent.
ResourceLaunchEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.api
Builder used to create ResourceLaunchEvent instances.
ResourceLaunchEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
ResourceLaunchHandler - Interface in org.apache.reef.runtime.common.driver.api
 
ResourceManager - Class in org.apache.reef.runtime.local.driver
A resource manager that uses threads to execute containers.
ResourceManagerErrorHandler - Class in org.apache.reef.client.parameters
Client EventHandler triggered on resource manager error.
ResourceManagerErrorHandler - Class in org.apache.reef.runtime.common.driver.resourcemanager
Informs the client and then shuts down the driver forcefully in case of Resource Manager errors.
ResourceManagerPreserveEvaluators - Class in org.apache.reef.driver.parameters
Whether the resource manager should preserve evaluators on job driver failure.
ResourceManagerStartHandler - Interface in org.apache.reef.runtime.common.driver.api
Initialize the resource manager.
ResourceManagerStatus - Class in org.apache.reef.runtime.common.driver.resourcemanager
Manages the status of the Resource Manager and tracks whether it is idle.
ResourceManagerStopHandler - Interface in org.apache.reef.runtime.common.driver.api
Shutdown the resource manager.
ResourceRecoverEvent - Interface in org.apache.reef.runtime.common.driver.resourcemanager
A Resource recovered by the DriverRestartManager.
ResourceReleaseEvent - Interface in org.apache.reef.runtime.common.driver.api
Event from Driver Process to Driver Runtime.
ResourceReleaseEventImpl - Class in org.apache.reef.runtime.common.driver.api
Default POJO implementation of ResourceReleaseEvent.
ResourceReleaseEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.api
Builder used to create ResourceReleaseEvent instances.
ResourceReleaseEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl.Builder
 
ResourceReleaseHandler - Interface in org.apache.reef.runtime.common.driver.api
 
ResourceRequestEvent - Interface in org.apache.reef.runtime.common.driver.api
Event from Driver Process to Driver Runtime.
ResourceRequestEventImpl - Class in org.apache.reef.runtime.common.driver.api
Default POJO implementation of ResourceRequestEvent.
ResourceRequestEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.api
Builder used to create ResourceRequestEvent instances.
ResourceRequestEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
ResourceRequestHandler - Class in org.apache.reef.io.data.loading.api
 
ResourceRequestHandler(EvaluatorRequestor) - Constructor for class org.apache.reef.io.data.loading.api.ResourceRequestHandler
 
ResourceRequestHandler - Interface in org.apache.reef.runtime.common.driver.api
The evaluator request handler.
ResourceStatusEvent - Interface in org.apache.reef.runtime.common.driver.resourcemanager
Event from Driver Runtime to Driver Process.
ResourceStatusEventImpl - Class in org.apache.reef.runtime.common.driver.resourcemanager
Default POJO implementation of ResourceStatusEvent.
ResourceStatusEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.resourcemanager
Builder used to create ResourceStatusEvent instances.
ResourceStatusEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
ResourceStatusHandler - Class in org.apache.reef.runtime.common.driver.resourcemanager
A ResourceStatusProto message comes from the ResourceManager layer to indicate what it thinks about the current state of a given resource.
RESPONSE_APPLICATION_TYPE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
RestartEvaluators - Class in org.apache.reef.driver.restart
Represents holds the set of Evaluator information needed to recover EvaluatorManagers on the restarted Driver.
RestartEvaluators.Builder - Class in org.apache.reef.driver.restart
Builder to build RestartEvaluators.
RESULT_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
retainAll(Collection<?>) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
retainAll(Collection<?>) - Method in class org.apache.reef.tang.util.MonotonicHashSet
 
retainAll(Collection<?>) - Method in class org.apache.reef.tang.util.MonotonicSet
 
RETRY_COUNT - Static variable in class org.apache.reef.io.network.naming.LocalNameResolverConfiguration
The number of retrying connection.
RETRY_COUNT - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
The number of retrying connection.
RETRY_TIMEOUT - Static variable in class org.apache.reef.io.network.naming.LocalNameResolverConfiguration
The timeout of retrying connection.
RETRY_TIMEOUT - Static variable in class org.apache.reef.io.network.naming.NameResolverConfiguration
The timeout of retrying connection.
ROOT_CONTEXT_CONFIGURATION - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
ROOT_FOLDER - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The root folder of the job.
ROOT_FOLDER - Static variable in class org.apache.reef.runtime.mesos.client.MesosClientConfiguration
The folder in which the sub-folders for REEF drivers, one per job, will be created.
ROOT_FOLDER - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
The root folder of the job.
ROOT_FOLDER - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnClientConfiguration
 
ROOT_SERVICE_CONFIGURATION - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
RootContextConfiguration - Class in org.apache.reef.runtime.common.evaluator.parameters
The evaluator root context configuration.
RootFolder - Class in org.apache.reef.runtime.local.client.parameters
The folder where logs etc.
RootFolder - Class in org.apache.reef.runtime.mesos.client.parameters
The root folder where logs etc.
RootFolder() - Constructor for class org.apache.reef.runtime.mesos.client.parameters.RootFolder
 
RootFolder - Class in org.apache.reef.runtime.standalone.client.parameters
The folder where logs etc.
RootFolder - Class in org.apache.reef.runtime.yarn.client.parameters
Directory in the local filesystem to hold resources required to run the driver and submit evaluators.
RootServiceConfiguration - Class in org.apache.reef.runtime.common.evaluator.parameters
The service configuration for the root context.
row(StringBuffer) - Method in class org.apache.reef.tang.util.Tint
 
run(Configuration) - Method in class org.apache.reef.client.DriverLauncher
Run a job.
run(Configuration, long) - Method in class org.apache.reef.client.DriverLauncher
Run a job with a waiting timeout after which it will be killed, if it did not complete yet.
run(Configuration, String, int) - Method in class org.apache.reef.examples.group.bgd.BGDClient
Runs BGD on the given runtime - with timeout.
run() - Method in class org.apache.reef.examples.suspend.Control
 
run() - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
Run the task: Fire TaskStart, call Task.call(), fire TaskStop.
run() - Method in class org.apache.reef.runtime.common.REEFEnvironment
Launch REEF component (Driver or Evaluator).
run(String[]) - Method in class org.apache.reef.runtime.hdinsight.cli.HDICLI
 
run(List<String>) - Method in interface org.apache.reef.runtime.local.driver.Container
Run the given commandLine in the container.
run(List<String>) - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
run() - Method in class org.apache.reef.runtime.local.process.RunnableProcess
Runs the configured process.
run(Class<? extends Task>, Configuration, int) - Static method in class org.apache.reef.tests.fail.task.Client
 
run(Configuration, int) - Static method in class org.apache.reef.tests.messaging.driver.DriverMessaging
 
run(Configuration) - Method in class org.apache.reef.tests.TestDriverLauncher
Run a job.
run(Configuration, long) - Method in class org.apache.reef.tests.TestDriverLauncher
Run a job with a waiting timeout after which it will be killed, if it did not complete yet.
run() - Method in class org.apache.reef.wake.examples.p2p.Pull2Push
Executes the message loop.
run() - Method in class org.apache.reef.wake.time.event.Alarm
Invoke the event handler and pass a reference to self as a parameter.
run() - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
Main event loop.
runBGDReef(Configuration) - Static method in class org.apache.reef.examples.group.broadcast.BroadcastREEF
 
runClient(Class<?>, Configuration, int) - Static method in class org.apache.reef.tests.fail.driver.FailClient
Run REEF on specified runtime and fail (raise an exception) in a specified class.
runCommand(String) - Static method in class org.apache.reef.util.CommandUtils
 
runFailureReef(Configuration, int, int, int) - Static method in class org.apache.reef.tests.evaluator.failure.FailureREEF
 
runHelloCLR(Configuration, int, File) - Static method in class org.apache.reef.examples.helloCLR.HelloCLR
 
runHelloReef(Configuration, int) - Static method in class org.apache.reef.examples.hellohttp.HelloREEFHttp
Run Hello Reef with merged configuration.
runHelloReefWithoutClient(Configuration) - Static method in class org.apache.reef.examples.hello.HelloREEFNoClient
Used in the HDInsight example.
runInProcess(Class<?>, Configuration, int) - Static method in class org.apache.reef.tests.fail.driver.FailClient
Run REEF in-process using specified runtime and fail (raise an exception) in a specified class.
RunnableExecutingHandler - Class in org.apache.reef.io.watcher.util
Handler that executes Runnable commands.
RunnableExecutingHandler() - Constructor for class org.apache.reef.io.watcher.util.RunnableExecutingHandler
 
RunnableProcess - Class in org.apache.reef.runtime.local.process
A runnable class that encapsulates a process.
RunnableProcess(List<String>, String, File, RunnableProcessObserver, String, String) - Constructor for class org.apache.reef.runtime.local.process.RunnableProcess
 
RunnableProcessObserver - Interface in org.apache.reef.runtime.local.process
Observer interface for events fired by RunnableProcess.
RUNNING - Static variable in class org.apache.reef.client.LauncherStatus
 
RUNNING_CONTAINERS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
RUNNING_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.State
RUNNING = 1;
RunningJob - Interface in org.apache.reef.client
Represents a running REEF job.
RunningJobImpl - Class in org.apache.reef.runtime.common.client
Implementation of RunningJob.
RunningTask - Interface in org.apache.reef.driver.task
Represents a running Task.
RunningTaskBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for RunningTask.
RunningTaskBridge(RunningTask, ActiveContextBridgeFactory) - Constructor for class org.apache.reef.javabridge.RunningTaskBridge
 
RunningTaskImpl - Class in org.apache.reef.runtime.common.driver.task
Implements the RunningTask client interface.
RunningTaskImpl(EvaluatorManager, String, EvaluatorContext, TaskRepresenter) - Constructor for class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
runTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.CommunicationGroupDriverImpl
 
runTaskScheduler(Configuration, String[]) - Static method in class org.apache.reef.examples.scheduler.client.SchedulerREEF
Run the Task scheduler.
RUNTIME_NAME - Static variable in class org.apache.reef.runtime.hdinsight.driver.RuntimeIdentifier
Same value is defined on the C# side in the Org.Apache.REEF.Common.Runtime.RuntimeName.
RUNTIME_NAME - Static variable in class org.apache.reef.runtime.local.driver.RuntimeIdentifier
Same value is defined on the C# side in the Org.Apache.REEF.Common.Runtime.RuntimeName.
RUNTIME_NAME - Static variable in class org.apache.reef.runtime.mesos.driver.RuntimeIdentifier
Same value is defined on the C# side in the Org.Apache.REEF.Common.Runtime.RuntimeName.
RUNTIME_NAME - Static variable in class org.apache.reef.runtime.yarn.driver.RuntimeIdentifier
Same value is defined on the C# side in the Org.Apache.REEF.Common.Runtime.RuntimeName.
RUNTIME_NAME - Static variable in class org.apache.reef.tests.driver.RuntimeNameTestConfiguration
 
RUNTIME_NAMES - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
RUNTIME_NAMES - Static variable in class org.apache.reef.runtime.local.driver.LocalDriverConfiguration
The name of the runitme.
RUNTIME_NAMES - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
The name of the configured runtimes.
RUNTIME_NAMES - Static variable in class org.apache.reef.runtime.multi.driver.MultiRuntimeDriverConfiguration
Serialized runtime configuration.
RUNTIME_NAMES - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
RUNTIME_ROOT_FOLDER - Static variable in class org.apache.reef.runtime.local.client.ExtensibleLocalRuntimeConfiguration
The folder in which the sub-folders, one per Node, will be created.
RUNTIME_ROOT_FOLDER - Static variable in class org.apache.reef.runtime.local.client.LocalRuntimeConfiguration
The folder in which the sub-folders, one per Node, will be created.
RUNTIME_ROOT_FOLDER - Static variable in class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
Folder to save the files generated by REEF.
RuntimeAlarm - Class in org.apache.reef.wake.time.runtime.event
An event for non-client alarm.
RuntimeAlarm(long, EventHandler<Alarm>) - Constructor for class org.apache.reef.wake.time.runtime.event.RuntimeAlarm
 
RuntimeAuthor - Annotation Type in org.apache.reef.annotations.audience
Indicates that an interface or API to be consumed or used by authors of additional REEF runtimes, not authors of REEF jobs.
RuntimeClasspathProvider - Interface in org.apache.reef.runtime.common.files
Interface to be implemented by each REEF runtime (YARN, Mesos, Local) to provide additional classpath elements to be pre- and postfixed to the user classpath.
RuntimeClock - Class in org.apache.reef.wake.time.runtime
Default implementation of clock.
RUNTIMEERROR_FIELD_NUMBER - Static variable in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
RuntimeIdentifier - Class in org.apache.reef.runtime.hdinsight.driver
Runtime Identifier Implementation.
RuntimeIdentifier - Class in org.apache.reef.runtime.local.driver
Runtime Identifier Implementation.
RuntimeIdentifier - Class in org.apache.reef.runtime.mesos.driver
Runtime Identifier Implementation.
RuntimeIdentifier - Class in org.apache.reef.runtime.yarn.driver
Runtime Identifier Implementation.
RuntimeName - Class in org.apache.reef.runtime.multi.driver.parameters
Serialized tang configuration for a runtime.
RuntimeName() - Constructor for class org.apache.reef.runtime.multi.driver.parameters.RuntimeName
 
runtimeName - Variable in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Deprecated.
runtimeName - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
runtimeNames - Variable in class org.apache.reef.javabridge.avro.DefinedRuntimes
Deprecated.
RuntimeNames - Class in org.apache.reef.runtime.multi.client.parameters
Serialized tang configuration for a runtime.
RuntimeNames() - Constructor for class org.apache.reef.runtime.multi.client.parameters.RuntimeNames
 
RuntimeNameTestConfiguration - Class in org.apache.reef.tests.driver
Configuration for RuntimeNameTest.
RuntimeNameTestConfiguration() - Constructor for class org.apache.reef.tests.driver.RuntimeNameTestConfiguration
 
RuntimeNameTestConfiguration.RuntimeName - Class in org.apache.reef.tests.driver
The runtime name.
RuntimeNameTestConfiguration.RuntimeName() - Constructor for class org.apache.reef.tests.driver.RuntimeNameTestConfiguration.RuntimeName
 
RuntimeParameters - Class in org.apache.reef.runtime.common.driver.api
Driver resourcemanager parameters that resourcemanager implementations use to communicate with the Driver.
RuntimeParameters() - Constructor for class org.apache.reef.runtime.common.driver.api.RuntimeParameters
 
RuntimeParameters.NodeDescriptorHandler - Class in org.apache.reef.runtime.common.driver.api
The node descriptor handler that stub runtimes send along node information.
RuntimeParameters.NodeDescriptorHandler() - Constructor for class org.apache.reef.runtime.common.driver.api.RuntimeParameters.NodeDescriptorHandler
 
RuntimeParameters.ResourceAllocationHandler - Class in org.apache.reef.runtime.common.driver.api
The resource allocation handler that stub runtimes send along allocated resources e.g., containers.
RuntimeParameters.ResourceAllocationHandler() - Constructor for class org.apache.reef.runtime.common.driver.api.RuntimeParameters.ResourceAllocationHandler
 
RuntimeParameters.ResourceStatusHandler - Class in org.apache.reef.runtime.common.driver.api
The resource status handler.
RuntimeParameters.ResourceStatusHandler() - Constructor for class org.apache.reef.runtime.common.driver.api.RuntimeParameters.ResourceStatusHandler
 
RuntimeParameters.RuntimeStatusHandler - Class in org.apache.reef.runtime.common.driver.api
The resourcemanager status handler.
RuntimeParameters.RuntimeStatusHandler() - Constructor for class org.apache.reef.runtime.common.driver.api.RuntimeParameters.RuntimeStatusHandler
 
RuntimePathProvider - Interface in org.apache.reef.runtime.common.files
Supplies the path to the executable for process (Driver, Evaluator) launches.
runtimes - Variable in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Deprecated.
runtimes - Variable in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Deprecated.
RuntimeStart - Class in org.apache.reef.wake.time.runtime.event
An event for a runtime started.
RuntimeStart(long) - Constructor for class org.apache.reef.wake.time.runtime.event.RuntimeStart
 
RuntimeStatusEvent - Interface in org.apache.reef.runtime.common.driver.resourcemanager
Event from Driver Runtime to Driver Process.
RuntimeStatusEventImpl - Class in org.apache.reef.runtime.common.driver.resourcemanager
Default POJO implementation of RuntimeStatusEvent.
RuntimeStatusEventImpl.Builder - Class in org.apache.reef.runtime.common.driver.resourcemanager
Builder used to create RuntimeStatusEvent instances.
RuntimeStatusEventImpl.Builder() - Constructor for class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
 
RuntimeStop - Class in org.apache.reef.wake.time.runtime.event
An event for a runtime stopped.
RuntimeStop(long) - Constructor for class org.apache.reef.wake.time.runtime.event.RuntimeStop
 
RuntimeStop(long, Throwable) - Constructor for class org.apache.reef.wake.time.runtime.event.RuntimeStop
 
RxStage<T> - Interface in org.apache.reef.wake.rx
Stage that executes the observer.
RxSyncStage<T> - Class in org.apache.reef.wake.rx.impl
Stage that executes the observer synchronously.
RxSyncStage(Observer<T>) - Constructor for class org.apache.reef.wake.rx.impl.RxSyncStage
Constructs a Rx synchronous stage.
RxSyncStage(String, Observer<T>) - Constructor for class org.apache.reef.wake.rx.impl.RxSyncStage
Constructs a Rx synchronous stage.
RxThreadPoolStage<T> - Class in org.apache.reef.wake.rx.impl
Stage that executes the observer with a thread pool.
RxThreadPoolStage(Observer<T>, int) - Constructor for class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Constructs a Rx thread pool stage.
RxThreadPoolStage(String, Observer<T>, int) - Constructor for class org.apache.reef.wake.rx.impl.RxThreadPoolStage
Constructs a Rx thread pool stage.

S

scale(double) - Method in class org.apache.reef.examples.group.utils.math.AbstractVector
 
scale(double) - Method in interface org.apache.reef.examples.group.utils.math.Vector
Scales this Vector: this *= factor.
Scatter - Interface in org.apache.reef.io.network.group.api.operators
MPI Scatter operator
Scatter.Receiver<T> - Interface in org.apache.reef.io.network.group.api.operators
Receiver or non-roots.
Scatter.Sender<T> - Interface in org.apache.reef.io.network.group.api.operators
Sender or Root.
Scatter_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
Scatter = 1;
ScatterData - Class in org.apache.reef.io.network.group.impl.utils
Represents data that is transferred across evaluators during Scatter.
ScatterData(byte[][], Map<String, byte[]>) - Constructor for class org.apache.reef.io.network.group.impl.utils.ScatterData
Create a ScatterData instance with the given data.
ScatterDecoder - Class in org.apache.reef.io.network.group.impl.utils
Decode messages that was created by ScatterEncoder.
ScatterEncoder - Class in org.apache.reef.io.network.group.impl.utils
Encode messages for a scatter operation, which can be decoded by ScatterDecoder.
ScatterHelper - Class in org.apache.reef.io.network.group.impl.utils
Utility class for ScatterSender.
ScatterOperatorSpec - Class in org.apache.reef.io.network.group.impl.config
The specification for the Scatter operator.
ScatterOperatorSpec(String, Class<? extends Codec>) - Constructor for class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec
 
ScatterOperatorSpec.Builder - Class in org.apache.reef.io.network.group.impl.config
 
ScatterOperatorSpec.Builder() - Constructor for class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec.Builder
 
ScatterReceiver<T> - Class in org.apache.reef.io.network.group.impl.operators
 
ScatterReceiver(String, String, String, Codec<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient, ScatterDecoder) - Constructor for class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
ScatterSender<T> - Class in org.apache.reef.io.network.group.impl.operators
 
ScatterSender(String, String, String, Codec<T>, String, int, CommGroupNetworkHandler, NetworkService<GroupCommunicationMessage>, CommunicationGroupServiceClient, ScatterEncoder) - Constructor for class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
scheduleAlarm(int, EventHandler<Alarm>) - Method in interface org.apache.reef.wake.time.Clock
Schedule a TimerEvent at the given future offset.
scheduleAlarm(int, EventHandler<Alarm>) - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
Schedule a new Alarm event in `offset` milliseconds into the future, and supply an event handler to be called at that time.
SCHEDULER_DRIVER_CAPACITY - Static variable in class org.apache.reef.runtime.mesos.driver.MesosDriverConfiguration
Capacity for running Mesos Scheduler Driver.
SchedulerDriver - Class in org.apache.reef.examples.scheduler.driver
Driver for TaskScheduler.
SchedulerDriver.ActiveContextHandler - Class in org.apache.reef.examples.scheduler.driver
Now it is ready to schedule tasks.
SchedulerDriver.ActiveContextHandler() - Constructor for class org.apache.reef.examples.scheduler.driver.SchedulerDriver.ActiveContextHandler
 
SchedulerDriver.CompletedTaskHandler - Class in org.apache.reef.examples.scheduler.driver
When a Task completes, the task is marked as finished.
SchedulerDriver.CompletedTaskHandler() - Constructor for class org.apache.reef.examples.scheduler.driver.SchedulerDriver.CompletedTaskHandler
 
SchedulerDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.examples.scheduler.driver
Evaluator is allocated.
SchedulerDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.examples.scheduler.driver.SchedulerDriver.EvaluatorAllocatedHandler
 
SchedulerDriver.StartHandler - Class in org.apache.reef.examples.scheduler.driver
The driver is ready to run.
SchedulerDriver.StartHandler() - Constructor for class org.apache.reef.examples.scheduler.driver.SchedulerDriver.StartHandler
 
SchedulerHttpHandler - Class in org.apache.reef.examples.scheduler.driver.http
Receive HttpRequest so that it can handle the command list.
SchedulerREEF - Class in org.apache.reef.examples.scheduler.client
REEF TaskScheduler.
SchedulerREEF.Retain - Class in org.apache.reef.examples.scheduler.client
Command line parameter = true to reuse evaluators,.
SchedulerREEF.Retain() - Constructor for class org.apache.reef.examples.scheduler.client.SchedulerREEF.Retain
 
SchedulerREEFYarn - Class in org.apache.reef.examples.scheduler.client
REEF TaskScheduler on YARN runtime.
SCHEMA$ - Static variable in class org.apache.reef.bridge.message.Acknowledgement
 
SCHEMA$ - Static variable in class org.apache.reef.bridge.message.BridgeInterop
 
SCHEMA$ - Static variable in class org.apache.reef.bridge.message.Header
 
SCHEMA$ - Static variable in enum org.apache.reef.bridge.message.MessageType
 
SCHEMA$ - Static variable in class org.apache.reef.bridge.message.Protocol
 
SCHEMA$ - Static variable in class org.apache.reef.bridge.message.SetupBridge
 
SCHEMA$ - Static variable in class org.apache.reef.bridge.message.SystemOnStart
 
SCHEMA$ - Static variable in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
SCHEMA$ - Static variable in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
SCHEMA$ - Static variable in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
SCHEMA$ - Static variable in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
SCHEMA$ - Static variable in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
SCHEMA$ - Static variable in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.common.AvroFailure
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
SCHEMA$ - Static variable in enum org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorType
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
SCHEMA$ - Static variable in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
SCHEMA$ - Static variable in class org.apache.reef.javabridge.avro.AvroFailedTask
 
SCHEMA$ - Static variable in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
SCHEMA$ - Static variable in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
SCHEMA$ - Static variable in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
SCHEMA$ - Static variable in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
SCHEMA$ - Static variable in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
SCHEMA$ - Static variable in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
SCHEMA$ - Static variable in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
SCHEMA$ - Static variable in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
SCHEMA$ - Static variable in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
SCHEMA$ - Static variable in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
SCHEMA$ - Static variable in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
SCHEMA$ - Static variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
SCHEMA$ - Static variable in class org.apache.reef.tang.implementation.avro.AvroNode
 
SCHEMA$ - Static variable in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroDriverInfo
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroEvaluatorEntry
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroEvaluatorInfo
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroEvaluatorList
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroHttpRequest
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.AvroReefServiceInfo
 
SCHEMA$ - Static variable in class org.apache.reef.webserver.HeaderEntry
 
ScratchSpace - Interface in org.apache.reef.io.storage
 
SECONDS_PER_MINUTE - Static variable in class org.apache.reef.wake.metrics.EWMAParameters
 
SECRETS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
securityTokenKind - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
SecurityTokenProvider - Interface in org.apache.reef.runtime.yarn.client
Provides security token for setting up YARN container context.
securityTokenService - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
SELECTED_PLAN_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
send(byte[]) - Method in interface org.apache.reef.client.RunningJob
Send a message to the Driver.
send(byte[]) - Method in interface org.apache.reef.driver.task.RunningTask
Sends the message to the running task.
send(T) - Method in interface org.apache.reef.io.network.group.api.operators.Broadcast.Sender
Send element to all receivers.
send(T) - Method in interface org.apache.reef.io.network.group.api.operators.Gather.Sender
Send the element to the root/receiver.
send(T) - Method in interface org.apache.reef.io.network.group.api.operators.Reduce.Sender
Send the element to the root.
send(List<T>) - Method in interface org.apache.reef.io.network.group.api.operators.Scatter.Sender
Distributes evenly across task ids sorted lexicographically.
send(List<T>, Integer...) - Method in interface org.apache.reef.io.network.group.api.operators.Scatter.Sender
Distributes as per counts across task ids sorted lexicographically.
send(List<T>, List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.Scatter.Sender
Distributes evenly across task ids sorted using order.
send(List<T>, List<Integer>, List<? extends Identifier>) - Method in interface org.apache.reef.io.network.group.api.operators.Scatter.Sender
Distributes as per counts across task ids sorted using order.
send(T) - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
send(T) - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
send(T) - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
send(List<T>) - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
send(List<T>, Integer...) - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
send(List<T>, List<? extends Identifier>) - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
send(List<T>, List<Integer>, List<? extends Identifier>) - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
send(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.operators.Sender
 
send(GroupCommunicationMessage, String) - Method in class org.apache.reef.io.network.group.impl.operators.Sender
 
send(byte[]) - Method in class org.apache.reef.javabridge.RunningTaskBridge
 
send(byte[]) - Method in class org.apache.reef.runtime.common.client.RunningJobImpl
 
send(ReefServiceProtos.JobStatusProto) - Method in class org.apache.reef.runtime.common.driver.client.ClientConnection
Send the given JobStatus to the client.
send(EvaluatorRuntimeProtocol.ContextControlProto) - Method in class org.apache.reef.runtime.common.driver.context.ContextControlHandler
 
send(EvaluatorRuntimeProtocol.EvaluatorControlProto) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorControlHandler
Send the evaluatorControlProto to the Evaluator.
send(byte[]) - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
sendContextControlMessage(EvaluatorRuntimeProtocol.ContextControlProto) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Packages the ContextControlProto in an EvaluatorControlProto and forward it to the EvaluatorRuntime.
sendContextStatus(ReefServiceProtos.ContextStatusProto) - Method in class org.apache.reef.runtime.common.evaluator.HeartBeatManager
Called with a specific ContextStatus that must be delivered to the driver.
Sender - Class in org.apache.reef.io.network.group.impl.operators
 
Sender(NetworkService<GroupCommunicationMessage>) - Constructor for class org.apache.reef.io.network.group.impl.operators.Sender
 
sendEvaluatorStatus(ReefServiceProtos.EvaluatorStatusProto) - Method in class org.apache.reef.runtime.common.evaluator.HeartBeatManager
Called with a specific EvaluatorStatus that must be delivered to the driver.
sendHeartbeat() - Method in class org.apache.reef.runtime.common.evaluator.HeartBeatManager
Assemble a complete new heartbeat and send it out.
sendJobEndingMessageToClient(Optional<Throwable>) - Method in class org.apache.reef.runtime.common.driver.DriverStatusManager
Deprecated.
TODO[JIRA REEF-1548] Do not use DriverStatusManager as a proxy to the job client. After release 0.16, make this method private and use it inside onRuntimeStop() method instead.
sendMessage(byte[]) - Method in interface org.apache.reef.driver.context.ActiveContext
Send the active context the message, which will be delivered to all registered ContextMessageHandler, for this context.
sendMessage(byte[]) - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
sendMessage(byte[]) - Method in class org.apache.reef.runtime.common.driver.client.ClientConnection
Send the given byte[] as a message to the client.
sendMessage(byte[]) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
sendMessageToClient(byte[]) - Method in interface org.apache.reef.driver.client.JobMessageObserver
Send a message to the client.
sendMessageToClient(byte[]) - Method in class org.apache.reef.runtime.common.driver.client.JobMessageObserverImpl
 
sendTaskStatus(ReefServiceProtos.TaskStatusProto) - Method in class org.apache.reef.runtime.common.evaluator.HeartBeatManager
Called with a specific TaskStatus that must be delivered to the driver.
sendToChildren(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
sendToChildren(Map<String, byte[]>, ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
sendToChildren(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
sendToChildren(Map<String, byte[]>, ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
sendToChildren(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
sendToChildren(Map<String, byte[]>, ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
sendToChildren(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
sendToChildren(Map<String, byte[]>, ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
sendToParent(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopology
 
sendToParent(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
sendToParent(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyImpl
 
sendToParent(byte[], ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
SEQ_FIELD_NUMBER - Static variable in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
sequence - Variable in class org.apache.reef.bridge.message.BridgeInterop
Deprecated.
SerializableCodec<T extends Serializable> - Class in org.apache.reef.io.serialization
A Codec for Serializable objects.
SerializableCodec() - Constructor for class org.apache.reef.io.serialization.SerializableCodec
Default constructor for TANG use.
serialize(DistributedDataSetPartition) - Static method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartitionSerializer
 
serialize(E) - Static method in class org.apache.reef.io.data.loading.impl.WritableSerializer
 
serialize(ClassHierarchy) - Static method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
in 0.12. Use AvroClassHierarchySerializer instead
serialize(File, ClassHierarchy) - Static method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferClassHierarchy
Deprecated.
in 0.12. Use AvroClassHierarchySerializer instead
serialize(InjectionPlan<T>) - Method in class org.apache.reef.tang.implementation.protobuf.ProtocolBufferInjectionPlan
 
serialize(Object) - Method in class org.apache.reef.vortex.common.KryoUtils
 
SERIALIZED_RUNTIME_DEFINITION - Static variable in class org.apache.reef.runtime.multi.driver.MultiRuntimeDriverConfiguration
Serialized runtime configuration.
serializedConfiguration - Variable in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Deprecated.
SerializedGroupConfigs - Class in org.apache.reef.io.network.group.impl.config.parameters
 
SerializedOperConfigs - Class in org.apache.reef.io.network.group.impl.config.parameters
Serialized operator configurations.
SerializedRuntimeDefinition - Class in org.apache.reef.runtime.multi.client.parameters
Serialized MultiRuntimeDefinition.
SerializedRuntimeDefinition() - Constructor for class org.apache.reef.runtime.multi.client.parameters.SerializedRuntimeDefinition
 
Serializer<ObjectType,OutType> - Interface in org.apache.reef.io.serialization
Stream-based multi-object serialization interface.
SerializerFileSpool<T> - Class in org.apache.reef.io.storage.local
A SpoolFile backed by the filesystem.
SerializerFileSpool(LocalStorageService, Serializer<T, OutputStream>, Deserializer<T, InputStream>) - Constructor for class org.apache.reef.io.storage.local.SerializerFileSpool
 
serializeToByteBuffer() - Method in class org.apache.reef.experimental.parquet.ParquetReader
Serialize Avro data to a in-memory ByteBuffer.
serializeToDisk(File) - Method in class org.apache.reef.experimental.parquet.ParquetReader
Serialize Avro data to a local file.
serializeToken(Token<AMRMTokenIdentifier>) - Static method in class org.apache.reef.runtime.yarn.client.UserCredentialSecurityTokenProvider
Helper method to serialize a security token.
SERVICE_CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
SERVICE_DATA - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
ServiceConfiguration - Class in org.apache.reef.driver.context
Configuration module for services.
ServiceConfiguration() - Constructor for class org.apache.reef.driver.context.ServiceConfiguration
 
ServiceContextActiveHandlers - Class in org.apache.reef.driver.parameters
Handler for ActiveContext.
ServiceContextClosedHandlers - Class in org.apache.reef.driver.parameters
Handler for ClosedContext.
ServiceContextFailedHandlers - Class in org.apache.reef.driver.parameters
Handler for FailedContext.
ServiceContextMessageHandlers - Class in org.apache.reef.driver.parameters
Context message handler.
ServiceDriverRestartCompletedHandlers - Class in org.apache.reef.driver.parameters
Service handler for driver restart completed event.
ServiceDriverRestartContextActiveHandlers - Class in org.apache.reef.driver.parameters
Handler for ActiveContext received during driver restart.
ServiceDriverRestartedHandlers - Class in org.apache.reef.driver.parameters
Service Handler for driver restarts.
ServiceDriverRestartFailedEvaluatorHandlers - Class in org.apache.reef.driver.parameters
Service handler for driver restart evaluator failed event.
ServiceDriverRestartTaskRunningHandlers - Class in org.apache.reef.driver.parameters
Running task handler during driver restart.
ServiceEvaluatorAllocatedHandlers - Class in org.apache.reef.driver.parameters
Called when an allocated evaluator is given to the client.
ServiceEvaluatorCompletedHandlers - Class in org.apache.reef.driver.parameters
Called when an exception occurs on a running evaluator.
ServiceEvaluatorFailedHandlers - Class in org.apache.reef.driver.parameters
Called when an exception occurs on a running evaluator.
ServiceException - Exception in org.apache.reef.exception.evaluator
The base class for exceptions thrown by REEF libraries and services.
ServiceException(String, Throwable) - Constructor for exception org.apache.reef.exception.evaluator.ServiceException
 
ServiceException(String) - Constructor for exception org.apache.reef.exception.evaluator.ServiceException
 
ServiceException(Throwable) - Constructor for exception org.apache.reef.exception.evaluator.ServiceException
 
serviceInfo - Variable in class org.apache.reef.webserver.AvroReefServiceInfo
Deprecated.
serviceName - Variable in class org.apache.reef.webserver.AvroReefServiceInfo
Deprecated.
ServiceRuntimeException - Exception in org.apache.reef.exception.evaluator
The base class for resourcemanager exceptions thrown by REEF services, such as storage and networking routines.
ServiceRuntimeException() - Constructor for exception org.apache.reef.exception.evaluator.ServiceRuntimeException
 
ServiceRuntimeException(ServiceException) - Constructor for exception org.apache.reef.exception.evaluator.ServiceRuntimeException
It often is the case that analogous ServiceException and ServiceRuntimeExceptions are needed so that exception types can be uniformly thrown from Reef APIs that declare throws clauses, and legacy interfaces that do not.
ServiceRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.exception.evaluator.ServiceRuntimeException
 
ServiceRuntimeException(String) - Constructor for exception org.apache.reef.exception.evaluator.ServiceRuntimeException
 
ServiceRuntimeException(Throwable) - Constructor for exception org.apache.reef.exception.evaluator.ServiceRuntimeException
 
SERVICES - Static variable in class org.apache.reef.driver.context.ServiceConfiguration
A set of services to instantiate.
Services - Class in org.apache.reef.evaluator.context.parameters
A set of classes to be instantiated and shared as singletons within this context and all child context.
Services() - Constructor for class org.apache.reef.evaluator.context.parameters.Services
 
services - Variable in class org.apache.reef.webserver.AvroDriverInfo
Deprecated.
ServiceTaskCompletedHandlers - Class in org.apache.reef.driver.parameters
Completed task handler.
ServiceTaskFailedHandlers - Class in org.apache.reef.driver.parameters
Task failure handler.
ServiceTaskMessageHandlers - Class in org.apache.reef.driver.parameters
Task message handler.
ServiceTaskRunningHandlers - Class in org.apache.reef.driver.parameters
Running task handler.
ServiceTaskSuspendedHandlers - Class in org.apache.reef.driver.parameters
Suspended task handler.
set(int, double) - Method in class org.apache.reef.examples.group.utils.math.AbstractVector
 
set(int, double) - Method in class org.apache.reef.examples.group.utils.math.DenseVector
 
set(int, double) - Method in interface org.apache.reef.examples.group.utils.math.Vector
Set dimension i of the Vector to value v.
set(String, UserCredentials) - Method in class org.apache.reef.runtime.common.client.defaults.DefaultUserCredentials
Copy credentials from another existing user.
set(String, UserCredentials) - Method in interface org.apache.reef.runtime.common.UserCredentials
Copy credentials from another existing user.
set(String, UserCredentials) - Method in class org.apache.reef.runtime.yarn.client.unmanaged.YarnProxyUser
Set YARN user.
set(String, UserGroupInformation, Token<? extends TokenIdentifier>...) - Method in class org.apache.reef.runtime.yarn.client.unmanaged.YarnProxyUser
Create YARN proxy user and add security tokens to its credentials.
set(Impl<T>, Class<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
set(Impl<T>, String) - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
set(Impl<List>, List) - Method in class org.apache.reef.tang.formats.ConfigurationModule
Binds a list to a specific optional/required Impl using ConfigurationModule.
set(Param<T>, Class<? extends T>) - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
set(Param<Boolean>, boolean) - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
set(Param<? extends Number>, Number) - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
set(Param<T>, String) - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
set(Param<List>, List) - Method in class org.apache.reef.tang.formats.ConfigurationModule
Binds a list to a specific optional/required Param using ConfigurationModule.
set(T) - Method in class org.apache.reef.util.SetOnce
 
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Sets the value of the 'activeContext' field.
setActiveContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Sets the value of the 'activeContext' field.
setActiveContextBuilder(AvroActiveContext.Builder) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Sets the Builder instance for the 'activeContext' field
setActiveContextBuilder(AvroActiveContext.Builder) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Sets the Builder instance for the 'activeContext' field
setActiveContextBuilder(AvroActiveContext.Builder) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Sets the Builder instance for the 'activeContext' field
setActiveContextBuilder(AvroActiveContext.Builder) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Sets the Builder instance for the 'activeContext' field
setActiveContextHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setAddContext(EvaluatorRuntimeProtocol.AddContextProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
setAddContext(EvaluatorRuntimeProtocol.AddContextProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .AddContextProto add_context = 5;
setAliasLanguage(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_language = 9;
setAliasLanguageBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_language = 9;
setAliasName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_name = 8;
setAliasNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string alias_name = 8;
setAllocatedEvaluatorHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setAllocatedMB(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setAllocatedVCores(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setAmContainerLogs(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setAmContainerSpec(AmContainerSpec) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setAmHostHttpAddress(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setApp(ApplicationState) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationResponse
 
setApplicationAcls(Map<String, List<StringEntry>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setApplicationId(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationID
 
setApplicationId(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setApplicationName(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setApplicationName(String) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Set the name of the application to be submitted.
setApplicationTags(List<String>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setApplicationType(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setApplicationType(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setApps(Map<String, List<ApplicationState>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ListApplicationResponse
 
setArgs(int, ClassHierarchyProto.ConstructorArg) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
setArgs(int, ClassHierarchyProto.ConstructorArg.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
repeated .ConstructorArg args = 2;
setArgs(int, InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
setArgs(int, InjectionPlanProto.InjectionPlan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor.Builder
repeated .InjectionPlan args = 1;
setAsError(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Sets the value of the 'asError' field.
setAsError(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure
Sets the value of the 'asError' field.
setBase(AvroContextBase) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Sets the value of the 'base' field.
setBase(AvroContextBase) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
Sets the value of the 'base' field.
setBase(AvroContextBase) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Sets the value of the 'base' field.
setBase(AvroContextBase) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Sets the value of the 'base' field.
setBase(AvroContextBase) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Sets the value of the 'base' field.
setBase(AvroContextBase) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Sets the value of the 'base' field.
setBaseBuilder(AvroContextBase.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext.Builder
Sets the Builder instance for the 'base' field
setBaseBuilder(AvroContextBase.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Sets the Builder instance for the 'base' field
setBaseBuilder(AvroContextBase.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Sets the Builder instance for the 'base' field
setBindings(List<ConfigurationEntry>) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Sets the value of the 'Bindings' field.
setBindings(List<ConfigurationEntry>) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Sets the value of the 'Bindings' field.
setCause(ByteBuffer) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Sets the value of the 'cause' field.
setCause(ByteBuffer) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Sets the value of the 'cause' field.
setChanges(boolean) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
setChanges(boolean) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
setChildren(List<AvroNode>) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the value of the 'children' field.
setChildren(List<AvroNode>) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Sets the value of the 'children' field.
setChildren(int, ClassHierarchyProto.Node) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
setChildren(int, ClassHierarchyProto.Node.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
repeated .Node children = 6;
setClassName(CharSequence) - Method in class org.apache.reef.bridge.message.Header.Builder
Sets the value of the 'className' field.
setClassName(CharSequence) - Method in class org.apache.reef.bridge.message.Header
Sets the value of the 'className' field.
setClassName(String) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required string className = 1;
setClassNameBytes(ByteString) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required string className = 1;
setClassNode(AvroClassNode) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the value of the 'classNode' field.
setClassNode(AvroClassNode) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Sets the value of the 'classNode' field.
setClassNode(ClassHierarchyProto.ClassNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
setClassNode(ClassHierarchyProto.ClassNode.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .ClassNode class_node = 3;
setClassNodeBuilder(AvroClassNode.Builder) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the Builder instance for the 'classNode' field
setClassPath(String) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
setClassPath(Collection<String>) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
setClosedContextHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setClusterId(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setCommand(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setCommand(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Commands
 
setCommand(CharSequence) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Sets the value of the 'command' field.
setCommand(CharSequence) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Sets the value of the 'command' field.
setCommandLines(List<CharSequence>) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Sets the value of the 'commandLines' field.
setCommandLines(List<CharSequence>) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Sets the value of the 'commandLines' field.
setCommands(Commands) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setCompletedEvaluatorHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setCompletedTaskHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setConfiguration(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string configuration = 2;
setConfiguration(Configuration) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setConfigurationBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string configuration = 2;
setConfigurationFileName(String) - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
setConfigurationFileName(String) - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
Set the name of the configuration file for the Launcher.
setConfigurationFileName(String) - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
setConfigurationFilePaths(List<String>) - Method in class org.apache.reef.runtime.common.launch.CLRLaunchCommandBuilder
 
setConfigurationFilePaths(List<String>) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
setConfigurationFilePaths(List<String>) - Method in interface org.apache.reef.runtime.common.launch.LaunchCommandBuilder
Set the name of the configuration file for the Launcher.
setConfigurationFilePaths(List<String>) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Sets the configuration file for the job.
setConstructor(InjectionPlanProto.Constructor) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
setConstructor(InjectionPlanProto.Constructor.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Constructor constructor = 2;
setConstructorArgs(List<AvroConstructorArg>) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Sets the value of the 'constructorArgs' field.
setConstructorArgs(List<AvroConstructorArg>) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Sets the value of the 'constructorArgs' field.
setContextConfiguration(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string context_configuration = 2;
setContextConfigurationBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string context_configuration = 2;
setContextControl(EvaluatorRuntimeProtocol.ContextControlProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
setContextControl(EvaluatorRuntimeProtocol.ContextControlProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .ContextControlProto context_control = 3;
setContextId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Sets the value of the 'contextId' field.
setContextId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Sets the value of the 'contextId' field.
setContextId(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required string context_id = 1;
setContextId(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
required string context_id = 1;
setContextId(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string context_id = 1;
setContextId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required string context_id = 2;
setContextId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string context_id = 2;
setContextIdBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required string context_id = 1;
setContextIdBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto.Builder
required string context_id = 1;
setContextIdBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto.Builder
required string context_id = 1;
setContextIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required string context_id = 2;
setContextIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string context_id = 2;
setContextMessage(EvaluatorRuntimeProtocol.ContextMessageProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
setContextMessage(EvaluatorRuntimeProtocol.ContextMessageProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .ContextMessageProto context_message = 2;
setContextMessage(int, ReefServiceProtos.ContextStatusProto.ContextMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
setContextMessage(int, ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
repeated .ContextStatusProto.ContextMessageProto context_message = 7;
setContextMessageHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setContextState(ReefServiceProtos.ContextStatusProto.State) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
required .ContextStatusProto.State context_state = 1;
setContextStatus(int, ReefServiceProtos.ContextStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
setContextStatus(int, ReefServiceProtos.ContextStatusProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
repeated .ContextStatusProto context_status = 3;
setCores(int) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Sets the value of the 'cores' field.
setCores(Integer) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Sets the value of the 'cores' field.
setCountTrigger(int) - Method in class org.apache.reef.vortex.api.VortexAggregatePolicy.AggregatePolicyBuilder
Sets the count trigger for aggregation.
setCredentials(Credentials) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setData(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody.Builder
required bytes data = 1;
setData(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf.Builder
required bytes data = 1;
setData(ByteBuffer) - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Sets the value of the 'data' field.
setData(ByteBuffer) - Method in class org.apache.reef.io.watcher.common.AvroFailure
Sets the value of the 'data' field.
setData(ByteBuffer) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Sets the value of the 'data' field.
setData(ByteBuffer) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Sets the value of the 'data' field.
setData(ByteString) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required bytes data = 1;
setData(ByteString) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf.Builder
required bytes data = 2;
setDataCodecClass(Class<? extends Codec>) - Method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec.Builder
 
setDataCodecClass(Class<? extends Codec>) - Method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec.Builder
 
setDataCodecClass(Class<? extends Codec>) - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec.Builder
 
setDataCodecClass(Class<? extends Codec>) - Method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec.Builder
 
setDateTime(long) - Method in class org.apache.reef.bridge.message.SystemOnStart.Builder
Sets the value of the 'dateTime' field.
setDateTime(Long) - Method in class org.apache.reef.bridge.message.SystemOnStart
Sets the value of the 'dateTime' field.
setDefaultImplementation(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'defaultImplementation' field.
setDefaultImplementation(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'defaultImplementation' field.
setDefaultImplementation(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
optional string default_implementation = 7;
setDefaultImplementationBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
optional string default_implementation = 7;
setDefaultRuntime(String) - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeConfigurationBuilder
Sets default runtime.
setDefaultRuntimeName(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the value of the 'defaultRuntimeName' field.
setDefaultRuntimeName(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Sets the value of the 'defaultRuntimeName' field.
setDefaultRuntimeName(String) - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeDefinitionBuilder
Sets default runtime name.
setDefaultRuntimeName(CharSequence) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Sets the value of the 'defaultRuntimeName' field.
setDefaultRuntimeName(CharSequence) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Sets the value of the 'defaultRuntimeName' field.
setDescription(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Sets the value of the 'description' field.
setDescription(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure
Sets the value of the 'description' field.
setDesiredSplits(int) - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition.Builder
Sets the desired number of splits for this partition.
setDestid(String) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string destid = 3;
setDestid(String) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string destid = 3;
setDestidBytes(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string destid = 3;
setDestidBytes(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string destid = 3;
setDfsJobSubmissionFolder(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Sets the value of the 'dfsJobSubmissionFolder' field.
setDfsJobSubmissionFolder(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Sets the value of the 'dfsJobSubmissionFolder' field.
setDiagnostics(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
setDiagnostics(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setDistributedDataSet(DistributedDataSet) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
Sets the distributed data set.
setDocumentation(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'documentation' field.
setDocumentation(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'documentation' field.
setDocumentation(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string documentation = 5;
setDocumentationBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string documentation = 5;
setDoneEvaluator(EvaluatorRuntimeProtocol.DoneEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
setDoneEvaluator(EvaluatorRuntimeProtocol.DoneEvaluatorProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .DoneEvaluatorProto done_evaluator = 6;
setDriverConfigurationModule(ConfigurationModule) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
setDriverInfo(String, int, String) - Method in class org.apache.reef.javabridge.generic.JobClient
Set the driver memory.
setDriverInitialized() - Method in class org.apache.reef.util.logging.CLRBufferedLogHandler
Signals the java-bridge has been initialized and that we can begin logging.
setDriverMemory(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'driverMemory' field.
setDriverMemory(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'driverMemory' field.
setDriverMemory(Integer) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setDriverMemory(int) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Set the amount of memory to be allocated to the Driver.
setDriverRecoveryTimeout(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Sets the value of the 'driverRecoveryTimeout' field.
setDriverRecoveryTimeout(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Sets the value of the 'driverRecoveryTimeout' field.
setDriverRestartActiveContextHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setDriverRestartCompletedHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setDriverRestartFailedEvaluatorHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setDriverRestartRunningTaskHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setDriverStderrFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Sets the value of the 'driverStderrFilePath' field.
setDriverStderrFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Sets the value of the 'driverStderrFilePath' field.
setDriverStderrFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'driverStderrFilePath' field.
setDriverStderrFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'driverStderrFilePath' field.
setDriverStderrPath(String) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Sets the Driver stderr file path.
setDriverStdoutFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Sets the value of the 'driverStdoutFilePath' field.
setDriverStdoutFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Sets the value of the 'driverStdoutFilePath' field.
setDriverStdoutFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'driverStdoutFilePath' field.
setDriverStdoutFilePath(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'driverStdoutFilePath' field.
setDriverStdoutPath(String) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Sets the Driver stdout file path.
setElapsedTime(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setEncoding(String) - Method in class org.apache.reef.util.logging.DFSHandler
 
setEnvironment(Map<String, List<StringEntry>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setError(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bytes error = 5;
setError(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
optional bytes error = 3;
setError(ReefServiceProtos.RuntimeErrorProto) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
 
setErrorHandler(EventHandler<Throwable>) - Method in class org.apache.reef.wake.impl.WakeUncaughtExceptionHandler
 
setErrorManager(ErrorManager) - Method in class org.apache.reef.util.logging.DFSHandler
 
setEvaluatorConf(Configuration) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
setEvaluatorControl(EvaluatorRuntimeProtocol.EvaluatorControlProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
setEvaluatorControl(EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorControlProto evaluatorControl = 5;
setEvaluatorDescriptor(AvroEvaluatorDescriptor) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Sets the value of the 'evaluatorDescriptor' field.
setEvaluatorDescriptor(AvroEvaluatorDescriptor) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Sets the value of the 'evaluatorDescriptor' field.
setEvaluatorDescriptor(AvroEvaluatorDescriptor) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Sets the value of the 'evaluatorDescriptor' field.
setEvaluatorDescriptor(AvroEvaluatorDescriptor) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Sets the value of the 'evaluatorDescriptor' field.
setEvaluatorDescriptorBuilder(AvroEvaluatorDescriptor.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Sets the Builder instance for the 'evaluatorDescriptor' field
setEvaluatorDescriptorBuilder(AvroEvaluatorDescriptor.Builder) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Sets the Builder instance for the 'evaluatorDescriptor' field
setEvaluatorException(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Sets the value of the 'evaluatorException' field.
setEvaluatorException(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Sets the value of the 'evaluatorException' field.
setEvaluatorExpired(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Signals to the DriverRestartManager that an expected evaluator has been expired.
setEvaluatorHeartBeat(EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
setEvaluatorHeartBeat(EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .EvaluatorHeartbeatProto evaluatorHeartBeat = 6;
setEvaluatorId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Sets the value of the 'evaluatorId' field.
setEvaluatorId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Sets the value of the 'evaluatorId' field.
setEvaluatorId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required string evaluator_id = 1;
setEvaluatorId(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'evaluatorId' field.
setEvaluatorId(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'evaluatorId' field.
setEvaluatorIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required string evaluator_id = 1;
setEvaluatorLaunch(EvaluatorLaunch) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Sets the value of the 'evaluator_launch' field.
setEvaluatorLaunch(EvaluatorLaunch) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Sets the value of the 'evaluator_launch' field.
setEvaluatorLaunchBuilder(EvaluatorLaunch.Builder) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Sets the Builder instance for the 'evaluator_launch' field
setEvaluatorProcessed(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Signals to the DriverRestartManager that an evaluator has had its running task or active context processed.
setEvaluatorRelease(EvaluatorRelease) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Sets the value of the 'evaluator_release' field.
setEvaluatorRelease(EvaluatorRelease) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
Sets the value of the 'evaluator_release' field.
setEvaluatorReleaseBuilder(EvaluatorRelease.Builder) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl.Builder
Sets the Builder instance for the 'evaluator_release' field
setEvaluatorReported(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Signals to the DriverRestartManager that an evaluator has reported back after restart.
setEvaluatorReregistered(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
Signals to the DriverRestartManager that an evaluator has had its recovery heartbeat processed.
setEvaluatorRestartState(EvaluatorRestartState) - Method in class org.apache.reef.driver.restart.EvaluatorRestartInfo
sets the current process of the restart.
setEvaluators(List<AvroEvaluatorEntry>) - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Sets the value of the 'evaluators' field.
setEvaluators(List<AvroEvaluatorEntry>) - Method in class org.apache.reef.webserver.AvroEvaluatorList
Sets the value of the 'evaluators' field.
setEvaluatorsInfo(List<AvroEvaluatorInfo>) - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo.Builder
Sets the value of the 'evaluatorsInfo' field.
setEvaluatorsInfo(List<AvroEvaluatorInfo>) - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
Sets the value of the 'evaluatorsInfo' field.
setEvaluatorStatus(ReefServiceProtos.EvaluatorStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
setEvaluatorStatus(ReefServiceProtos.EvaluatorStatusProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required .EvaluatorStatusProto evaluator_status = 2;
setEvaluatorType(AvroEvaluatorType) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Sets the value of the 'evaluatorType' field.
setEvaluatorType(AvroEvaluatorType) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Sets the value of the 'evaluatorType' field.
setException(CharSequence) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Sets the value of the 'exception' field.
setException(CharSequence) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Sets the value of the 'exception' field.
setException(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes exception = 4;
setException(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional bytes exception = 3;
setExitCode(int) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
setFailedContextHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setFailedContextList(List<AvroFailedContext>) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Sets the value of the 'failedContextList' field.
setFailedContextList(List<AvroFailedContext>) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Sets the value of the 'failedContextList' field.
setFailedEvaluatorHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setFailedTask(AvroFailedTask) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Sets the value of the 'failedTask' field.
setFailedTask(AvroFailedTask) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Sets the value of the 'failedTask' field.
setFailedTaskBuilder(AvroFailedTask.Builder) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Sets the Builder instance for the 'failedTask' field
setFailedTaskHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setFailure(AvroFailure) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Sets the value of the 'failure' field.
setFailure(AvroFailure) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Sets the value of the 'failure' field.
setFailure(AvroFailure) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Sets the value of the 'failure' field.
setFailure(AvroFailure) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
Sets the value of the 'failure' field.
setFailureBuilder(AvroFailure.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Sets the Builder instance for the 'failure' field
setFailureBuilder(AvroFailure.Builder) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask.Builder
Sets the Builder instance for the 'failure' field
setFileSystemUrl(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Sets the value of the 'fileSystemUrl' field.
setFileSystemUrl(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Sets the value of the 'fileSystemUrl' field.
setFilter(Filter) - Method in class org.apache.reef.util.logging.DFSHandler
 
setFinalStatus(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setFinishedTime(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setFormatter(Formatter) - Method in class org.apache.reef.util.logging.DFSHandler
 
setFullArgClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Sets the value of the 'fullArgClassName' field.
setFullArgClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Sets the value of the 'fullArgClassName' field.
setFullArgClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'fullArgClassName' field.
setFullArgClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'fullArgClassName' field.
setFullArgClassName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required string full_arg_class_name = 1;
setFullArgClassName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string full_arg_class_name = 2;
setFullArgClassNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required string full_arg_class_name = 1;
setFullArgClassNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string full_arg_class_name = 2;
setFullClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef.Builder
Sets the value of the 'fullClassName' field.
setFullClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
Sets the value of the 'fullClassName' field.
setFullClassName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
required string full_class_name = 1;
setFullClassNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef.Builder
required string full_class_name = 1;
setFullName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the value of the 'fullName' field.
setFullName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Sets the value of the 'fullName' field.
setFullName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string full_name = 2;
setFullNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string full_name = 2;
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Sets the value of the 'get' field.
setGet(ByteBuffer) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Sets the value of the 'get' field.
setGroupname(String) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string groupname = 4;
setGroupnameBytes(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string groupname = 4;
setHeader(List<HeaderEntry>) - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Sets the value of the 'header' field.
setHeader(List<HeaderEntry>) - Method in class org.apache.reef.webserver.AvroHttpRequest
Sets the value of the 'header' field.
setHost(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Sets the value of the 'host' field.
setHost(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Sets the value of the 'host' field.
setHost(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Sets the value of the 'host' field.
setHost(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Sets the value of the 'host' field.
setHostName(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
setHttpMethod(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Sets the value of the 'httpMethod' field.
setHttpMethod(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest
Sets the value of the 'httpMethod' field.
setHttpServerEventHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setHttpServerPortNumber(int) - Method in class org.apache.reef.bridge.message.SetupBridge.Builder
Sets the value of the 'httpServerPortNumber' field.
setHttpServerPortNumber(Integer) - Method in class org.apache.reef.bridge.message.SetupBridge
Sets the value of the 'httpServerPortNumber' field.
setId(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Sets the value of the 'id' field.
setId(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setId(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Sets the value of the 'id' field.
setId(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
Sets the value of the 'id' field.
setIdentifier(long) - Method in class org.apache.reef.bridge.message.Header.Builder
Sets the value of the 'identifier' field.
setIdentifier(Long) - Method in class org.apache.reef.bridge.message.Header
Sets the value of the 'identifier' field.
setIdentifier(CharSequence) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Sets the value of the 'identifier' field.
setIdentifier(CharSequence) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Sets the value of the 'identifier' field.
setIdentifier(String) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
required string identifier = 1;
setIdentifier(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required string identifier = 2;
setIdentifier(String) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required string identifier = 1;
setIdentifier(String) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional string identifier = 5;
setIdentifier(String) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setIdentifier(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
setIdentifier(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl.Builder
 
setIdentifier(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
setIdentifier(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
setIdentifier(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
setIdentifier(CharSequence) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch.Builder
Sets the value of the 'identifier' field.
setIdentifier(CharSequence) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
Sets the value of the 'identifier' field.
setIdentifier(CharSequence) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease.Builder
Sets the value of the 'identifier' field.
setIdentifier(CharSequence) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
Sets the value of the 'identifier' field.
setIdentifierBytes(ByteString) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
required string identifier = 1;
setIdentifierBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required string identifier = 2;
setIdentifierBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required string identifier = 1;
setIdentifierBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
optional string identifier = 5;
setIds(List<CharSequence>) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest.Builder
Sets the value of the 'ids' field.
setIds(List<CharSequence>) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
Sets the value of the 'ids' field.
setImplFullNames(List<CharSequence>) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'implFullNames' field.
setImplFullNames(List<CharSequence>) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'implFullNames' field.
setImplFullNames(int, String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated string impl_full_names = 6;
setInetSocketAddress(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Sets the value of the 'inetSocketAddress' field.
setInetSocketAddress(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Sets the value of the 'inetSocketAddress' field.
setInetSocketAddress(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Sets the value of the 'inetSocketAddress' field.
setInetSocketAddress(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Sets the value of the 'inetSocketAddress' field.
setInjectableConstructors(List<AvroConstructorDef>) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'injectableConstructors' field.
setInjectableConstructors(List<AvroConstructorDef>) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'injectableConstructors' field.
setInjectableConstructors(int, ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
setInjectableConstructors(int, ClassHierarchyProto.ConstructorDef.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef InjectableConstructors = 4;
SetInjectionPlan<T> - Class in org.apache.reef.tang.implementation
 
SetInjectionPlan(Node, Set<InjectionPlan<T>>) - Constructor for class org.apache.reef.tang.implementation.SetInjectionPlan
 
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
setInputPath(String) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
Sets the path of the folder where the data is.
setInputStream(ByteBuffer) - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Sets the value of the 'inputStream' field.
setInputStream(ByteBuffer) - Method in class org.apache.reef.webserver.AvroHttpRequest
Sets the value of the 'inputStream' field.
setInstance(InjectionPlanProto.Instance) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
setInstance(InjectionPlanProto.Instance.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Instance instance = 3;
setInstanceDefault(List<CharSequence>) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'instanceDefault' field.
setInstanceDefault(List<CharSequence>) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'instanceDefault' field.
setInstanceDefault(int, String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
repeated string instance_default = 7;
setInternetAddress(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'internetAddress' field.
setInternetAddress(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'internetAddress' field.
setIsExternalConstructor(boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'isExternalConstructor' field.
setIsExternalConstructor(Boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'isExternalConstructor' field.
setIsExternalConstructor(boolean) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_external_constructor = 2;
setIsInjectionCandidate(boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'isInjectionCandidate' field.
setIsInjectionCandidate(Boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'isInjectionCandidate' field.
setIsInjectionCandidate(boolean) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_injection_candidate = 1;
setIsInjectionFuture(boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Sets the value of the 'isInjectionFuture' field.
setIsInjectionFuture(Boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Sets the value of the 'isInjectionFuture' field.
setIsInjectionFuture(boolean) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
required bool is_injection_future = 3;
setIsList(boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'isList' field.
setIsList(Boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'isList' field.
setIsList(boolean) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_list = 4;
setIsOptionSet(boolean) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess.Builder
Sets the value of the 'isOptionSet' field.
setIsOptionSet(Boolean) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
Sets the value of the 'isOptionSet' field.
setIsSet(boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'isSet' field.
setIsSet(Boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'isSet' field.
setIsSet(boolean) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required bool is_set = 3;
setIsUnit(boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'isUnit' field.
setIsUnit(Boolean) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'isUnit' field.
setIsUnit(boolean) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
required bool is_unit = 3;
setJavaPath(String) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
Set the path to the java executable.
setJobControl(ClientRuntimeProtocol.JobControlProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
setJobControl(ClientRuntimeProtocol.JobControlProto.Builder) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobControlProto jobControl = 2;
setJobId(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Sets the value of the 'jobId' field.
setJobId(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Sets the value of the 'jobId' field.
setJobName(String) - Method in class org.apache.reef.vortex.driver.VortexJobConf.Builder
 
setJobStatus(ReefServiceProtos.JobStatusProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
setJobStatus(ReefServiceProtos.JobStatusProto.Builder) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .JobStatusProto jobStatus = 4;
setJobSubmissionDirectoryPrefix(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Sets the value of the 'jobSubmissionDirectoryPrefix' field.
setJobSubmissionDirectoryPrefix(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Sets the value of the 'jobSubmissionDirectoryPrefix' field.
setJobSubmissionFolder(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters.Builder
Sets the value of the 'jobSubmissionFolder' field.
setJobSubmissionFolder(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
Sets the value of the 'jobSubmissionFolder' field.
setKeepContainers(boolean) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setKey(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResourcesEntry
 
setKey(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
setKey(CharSequence) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Sets the value of the 'key' field.
setKey(CharSequence) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Sets the value of the 'key' field.
setKey(CharSequence) - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Sets the value of the 'key' field.
setKey(CharSequence) - Method in class org.apache.reef.webserver.HeaderEntry
Sets the value of the 'key' field.
setKillEvaluator(EvaluatorRuntimeProtocol.KillEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
setKillEvaluator(EvaluatorRuntimeProtocol.KillEvaluatorProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .KillEvaluatorProto kill_evaluator = 4;
setLanguage(CharSequence) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration.Builder
Sets the value of the 'language' field.
setLanguage(CharSequence) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
Sets the value of the 'language' field.
setLauncherClass(Class) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Sets the launcher class for the job.
setLevel(Level) - Method in class org.apache.reef.util.logging.DFSHandler
 
setLink(Link<byte[]>) - Method in class org.apache.reef.io.network.naming.serialization.NamingMessage
Sets the link.
setLoad(double) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required double load = 2;
setLocalAddress(SocketAddress) - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Sets the local socket address.
setLocalResources(Map<String, List<LocalResourcesEntry>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setLocalRuntimeAppParameters(AvroLocalAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the value of the 'localRuntimeAppParameters' field.
setLocalRuntimeAppParameters(AvroLocalAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Sets the value of the 'localRuntimeAppParameters' field.
setLocalRuntimeAppParametersBuilder(AvroLocalAppSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the Builder instance for the 'localRuntimeAppParameters' field
setLocation(String) - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition.Builder
Sets the location where we want the data in this partition to be loaded into.
setLoggingLevel(Level) - Static method in class org.apache.reef.wake.impl.LoggingUtils
Sets the logging level.
SetMap<K,V> - Class in org.apache.reef.io.network.group.impl.utils
Map from K to Set<V>.
SetMap() - Constructor for class org.apache.reef.io.network.group.impl.utils.SetMap
 
setMaxAppAttempts(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setMaxApplicationAttempts(int) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Sets the maximum application attempts for the application.
setMaxApplicationSubmissions(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'maxApplicationSubmissions' field.
setMaxApplicationSubmissions(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'maxApplicationSubmissions' field.
setMaxApplicationSubmissions(Integer) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setMaxEvaluators(int) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
Update the maximum number of evaluators to hold.
setMaxEvaluatorsNumberForLocalRuntime(int) - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeConfigurationBuilder
Sets the max number of local evaluators for local runtime.
setMaxNumberOfConcurrentEvaluators(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Sets the value of the 'maxNumberOfConcurrentEvaluators' field.
setMaxNumberOfConcurrentEvaluators(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Sets the value of the 'maxNumberOfConcurrentEvaluators' field.
setMegaBytes(int) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Sets the value of the 'megaBytes' field.
setMegaBytes(Integer) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Sets the value of the 'megaBytes' field.
setMemory(int) - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
setMemory(int) - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
Set memory size of process in megabytes.
setMemory(int) - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Set the amount of memory.
setMemory(int) - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
setMemory(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Sets the value of the 'memory' field.
setMemory(Integer) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Sets the value of the 'memory' field.
setMemory(int) - Method in class org.apache.reef.runtime.common.launch.CLRLaunchCommandBuilder
 
setMemory(int) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
setMemory(int) - Method in interface org.apache.reef.runtime.common.launch.LaunchCommandBuilder
Set the size of the launched process in megabytes.
setMemory(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Resource
 
setMemory(int) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'memory' field.
setMemory(Integer) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'memory' field.
setMemorySeconds(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setMemorySize(int) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
setMemorySize(int) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
setMessage(Object) - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Sets the value of the 'message' field.
setMessage(Object) - Method in class org.apache.reef.bridge.message.BridgeInterop
Sets the value of the 'message' field.
setMessage(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Sets the value of the 'message' field.
setMessage(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure
Sets the value of the 'message' field.
setMessage(CharSequence) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask.Builder
Sets the value of the 'message' field.
setMessage(CharSequence) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
Sets the value of the 'message' field.
setMessage(ByteString) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional bytes message = 3;
setMessage(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto.Builder
required bytes message = 2;
setMessage(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required bytes message = 2;
setMessage(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
optional bytes message = 3;
setMessage(String) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string message = 2;
setMessage(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required bytes message = 2;
setMessage(String) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required string message = 1;
setMessageBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string message = 2;
setMessageBytes(ByteString) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf.Builder
required string message = 1;
setMessageIdentifier(long) - Method in class org.apache.reef.bridge.message.Acknowledgement.Builder
Sets the value of the 'messageIdentifier' field.
setMessageIdentifier(Long) - Method in class org.apache.reef.bridge.message.Acknowledgement
Sets the value of the 'messageIdentifier' field.
setMessageSourceId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage.Builder
Sets the value of the 'messageSourceId' field.
setMessageSourceId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
Sets the value of the 'messageSourceId' field.
setMessageSourceId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage.Builder
Sets the value of the 'messageSourceId' field.
setMessageSourceId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
Sets the value of the 'messageSourceId' field.
setMessageType(MessageType) - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Sets the value of the 'messageType' field.
setMessageType(MessageType) - Method in class org.apache.reef.bridge.message.BridgeInterop
Sets the value of the 'messageType' field.
setMsgs(int, ReefNetworkGroupCommProtos.GroupMessageBody) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
setMsgs(int, ReefNetworkGroupCommProtos.GroupMessageBody.Builder) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
repeated .GroupMessageBody msgs = 8;
setMsgs(int, ReefNetworkServiceProtos.NSRecordPBuf) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
setMsgs(int, ReefNetworkServiceProtos.NSRecordPBuf.Builder) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
repeated .NSRecordPBuf msgs = 4;
setMultiple(Param<T>, Iterable<String>) - Method in class org.apache.reef.tang.formats.ConfigurationModule
Binds a set of values to a Param using ConfigurationModule.
setMultiple(Param<T>, String...) - Method in class org.apache.reef.tang.formats.ConfigurationModule
Binds a set of values to a Param using ConfigurationModule.
setName(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor.Builder
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Sets the value of the 'name' field.
setName(String) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string name = 1;
setName(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
 
setName(String) - Method in class org.apache.reef.runtime.common.files.FileResourceImpl.Builder
 
setName(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Sets the value of the 'name' field.
setName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string name = 1;
setName(String) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
required string name = 1;
setName(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry.Builder
Sets the value of the 'name' field.
setName(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
Sets the value of the 'name' field.
setNameBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
required string name = 1;
setNamedParameterName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg.Builder
Sets the value of the 'namedParameterName' field.
setNamedParameterName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
Sets the value of the 'namedParameterName' field.
setNamedParameterName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
optional string named_parameter_name = 2;
setNamedParameterNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg.Builder
optional string named_parameter_name = 2;
setNamedParameterNode(AvroNamedParameterNode) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the value of the 'namedParameterNode' field.
setNamedParameterNode(AvroNamedParameterNode) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Sets the value of the 'namedParameterNode' field.
setNamedParameterNode(ClassHierarchyProto.NamedParameterNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
setNamedParameterNode(ClassHierarchyProto.NamedParameterNode.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .NamedParameterNode named_parameter_node = 4;
setNamedParameterNodeBuilder(AvroNamedParameterNode.Builder) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the Builder instance for the 'namedParameterNode' field
setNodeDescriptor(AvroNodeDescriptor) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Sets the value of the 'nodeDescriptor' field.
setNodeDescriptor(AvroNodeDescriptor) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Sets the value of the 'nodeDescriptor' field.
setNodeDescriptorBuilder(AvroNodeDescriptor.Builder) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Sets the Builder instance for the 'nodeDescriptor' field
setNodeId(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
setNodeId(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'nodeId' field.
setNodeId(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'nodeId' field.
setNodeName(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'nodeName' field.
setNodeName(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'nodeName' field.
setNodeNames(List<CharSequence>) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Sets the value of the 'nodeNames' field.
setNodeNames(List<CharSequence>) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Sets the value of the 'nodeNames' field.
setNodes(List<AvroNodeDescriptorInRackDescriptor>) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor.Builder
Sets the value of the 'nodes' field.
setNodes(List<AvroNodeDescriptorInRackDescriptor>) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
Sets the value of the 'nodes' field.
setNumber(int) - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Set the number of Evaluators requested.
setNumber(int) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Sets the value of the 'number' field.
setNumber(Integer) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Sets the value of the 'number' field.
setNumberOfCores(int) - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Set number of cores.
setNumberOfCores(int) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Sets the value of the 'numberOfCores' field.
setNumberOfCores(Integer) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Sets the value of the 'numberOfCores' field.
setNumberOfDesiredSplits(int) - Method in class org.apache.reef.io.data.loading.api.DataLoadingRequestBuilder
 
setOffset(int) - Method in class org.apache.reef.bridge.message.Protocol.Builder
Sets the value of the 'offset' field.
setOffset(Integer) - Method in class org.apache.reef.bridge.message.Protocol
Sets the value of the 'offset' field.
SetOnce<T> - Class in org.apache.reef.util
A reference to a value that can be set exactly once.
SetOnce(T) - Constructor for class org.apache.reef.util.SetOnce
 
SetOnce() - Constructor for class org.apache.reef.util.SetOnce
 
setOperatorname(String) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string operatorname = 5;
setOperatornameBytes(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional string operatorname = 5;
setOperatorSpecification(OperatorSpec) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Set operator specification of the operator.
setOperatorSpecification(OperatorSpec) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
setOperatorSpecification(OperatorSpec) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
setOtherConstructors(List<AvroConstructorDef>) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode.Builder
Sets the value of the 'otherConstructors' field.
setOtherConstructors(List<AvroConstructorDef>) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
Sets the value of the 'otherConstructors' field.
setOtherConstructors(int, ClassHierarchyProto.ConstructorDef) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
setOtherConstructors(int, ClassHierarchyProto.ConstructorDef.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode.Builder
repeated .ConstructorDef OtherConstructors = 5;
setOutstandingContainerRequests(int) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
 
setPackageNode(AvroPackageNode) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the value of the 'packageNode' field.
setPackageNode(AvroPackageNode) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
Sets the value of the 'packageNode' field.
setPackageNode(ClassHierarchyProto.PackageNode) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
setPackageNode(ClassHierarchyProto.PackageNode.Builder) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node.Builder
optional .PackageNode package_node = 5;
setPackageNodeBuilder(AvroPackageNode.Builder) - Method in class org.apache.reef.tang.implementation.avro.AvroNode.Builder
Sets the Builder instance for the 'packageNode' field
setParent(TaskNode) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
setParent(TaskNode) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
setParentContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Sets the value of the 'parentContext' field.
setParentContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
Sets the value of the 'parentContext' field.
setParentContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Sets the value of the 'parentContext' field.
setParentContext(AvroActiveContext) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
Sets the value of the 'parentContext' field.
setParentContextBuilder(AvroActiveContext.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext.Builder
Sets the Builder instance for the 'parentContext' field
setParentContextBuilder(AvroActiveContext.Builder) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext.Builder
Sets the Builder instance for the 'parentContext' field
setParentContextId(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string parent_context_id = 1;
setParentContextIdBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
required string parent_context_id = 1;
setParentId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase.Builder
Sets the value of the 'parentId' field.
setParentId(CharSequence) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
Sets the value of the 'parentId' field.
setParentId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional string parent_id = 3;
setParentIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional string parent_id = 3;
setPath(String) - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition.Builder
Sets the path of the distributed data set partition.
setPath(String) - Method in class org.apache.reef.runtime.common.files.FileResourceImpl.Builder
 
setPathInfo(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Sets the value of the 'pathInfo' field.
setPathInfo(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest
Sets the value of the 'pathInfo' field.
setPlans(int, InjectionPlanProto.InjectionPlan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
setPlans(int, InjectionPlanProto.InjectionPlan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
repeated .InjectionPlan plans = 2;
setPort(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment.Builder
Sets the value of the 'port' field.
setPort(Integer) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
Sets the value of the 'port' field.
setPort(int) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest.Builder
Sets the value of the 'port' field.
setPort(Integer) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
Sets the value of the 'port' field.
setPort(int) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
setPreserveEvaluators(Boolean) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setPreserveEvaluators(boolean) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Set whether or not the resource manager should preserve evaluators across driver restarts.
setPriority(Integer) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setPriority(int) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
setPriority(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setPriority(int) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Set the priority of the job.
setProcess(EvaluatorProcess) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
Specify the process to be instantiated for the Evaluator.
setProcess(AvroEvaluatorProcess) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Sets the value of the 'process' field.
setProcess(AvroEvaluatorProcess) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
Sets the value of the 'process' field.
setProcess(EvaluatorProcess) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
setProcess(EvaluatorProcess) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
setProcess(EvaluatorProcess) - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
 
setProcessBuilder(AvroEvaluatorProcess.Builder) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor.Builder
Sets the Builder instance for the 'process' field
setProfiler(WakeProfiler) - Static method in class org.apache.reef.runtime.common.launch.ProfilingStopHandler
 
setProgress(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setProgressProvider(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setQueryRequestData(byte[]) - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
setQueryResponseData(byte[]) - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
setQueryResult(String) - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
setQueryString(String) - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
setQueryString(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Sets the value of the 'queryString' field.
setQueryString(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest
Sets the value of the 'queryString' field.
setQueue(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setQueue(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setQueue(String) - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
Assign this job submission to a queue.
setRackDescriptor(AvroRackDescriptor) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Sets the value of the 'rackDescriptor' field.
setRackDescriptor(AvroRackDescriptor) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
Sets the value of the 'rackDescriptor' field.
setRackDescriptorBuilder(AvroRackDescriptor.Builder) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor.Builder
Sets the Builder instance for the 'rackDescriptor' field
setRackName(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.NodeDescriptorEventImpl.Builder
 
setRackName(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
setRackNames(List<CharSequence>) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest.Builder
Sets the value of the 'rackNames' field.
setRackNames(List<CharSequence>) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
Sets the value of the 'rackNames' field.
setReason(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure.Builder
Sets the value of the 'reason' field.
setReason(CharSequence) - Method in class org.apache.reef.io.watcher.common.AvroFailure
Sets the value of the 'reason' field.
setReceiverId(String) - Method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec.Builder
 
setReceiverId(String) - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec.Builder
 
setRecovery(boolean) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional bool recovery = 5;
setRecovery(boolean) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.Builder
optional bool recovery = 6;
setRecovery(boolean) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bool recovery = 5;
setReduceFunctionClass(Class<? extends Reduce.ReduceFunction>) - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec.Builder
 
setRelaxLocality(boolean) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
setRemoteAddress(SocketAddress) - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Sets the remote socket address.
setRemoteId(String) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setRemoteId(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
setRemoteId(CharSequence) - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Sets the value of the 'remoteId' field.
setRemoteId(CharSequence) - Method in class org.apache.reef.webserver.AvroDriverInfo
Sets the value of the 'remoteId' field.
setRemoveContext(EvaluatorRuntimeProtocol.RemoveContextProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
setRemoveContext(EvaluatorRuntimeProtocol.RemoveContextProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .RemoveContextProto remove_context = 6;
setRequestUrl(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest.Builder
Sets the value of the 'requestUrl' field.
setRequestUrl(CharSequence) - Method in class org.apache.reef.webserver.AvroHttpRequest
Sets the value of the 'requestUrl' field.
setResource(Resource) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationID
 
setResource(Resource) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
setResource(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
setResourceCount(int) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
setResourceMemory(int) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
setResult(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
optional bytes result = 4;
setRootTask(String) - Method in interface org.apache.reef.io.network.group.api.driver.Topology
Set task with id 'senderId' as.
setRootTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.FlatTopology
 
setRootTask(String) - Method in class org.apache.reef.io.network.group.impl.driver.TreeTopology
 
setRunning() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceManagerStatus
Change the state of the Resource Manager to be RUNNING.
setRunningContainers(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setRunningJob(RunningJob) - Method in class org.apache.reef.examples.suspend.SuspendClientControl
 
setRunningTaskHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setRuntimeError(ReefServiceProtos.RuntimeErrorProto) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
setRuntimeError(ReefServiceProtos.RuntimeErrorProto.Builder) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage.Builder
optional .RuntimeErrorProto runtimeError = 3;
setRuntimeName(String) - Method in class org.apache.reef.driver.evaluator.EvaluatorRequest.Builder
Set the name of the desired runtime.
setRuntimeName(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceLaunchEventImpl.Builder
 
setRuntimeName(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceReleaseEventImpl.Builder
 
setRuntimeName(String) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
setRuntimeName(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
setRuntimeName(String) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
setRuntimeName(CharSequence) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Sets the value of the 'runtimeName' field.
setRuntimeName(CharSequence) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Sets the value of the 'runtimeName' field.
setRuntimeName(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'runtimeName' field.
setRuntimeName(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'runtimeName' field.
setRuntimeNames(List<CharSequence>) - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes.Builder
Sets the value of the 'runtimeNames' field.
setRuntimeNames(List<CharSequence>) - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
Sets the value of the 'runtimeNames' field.
setRuntimes(List<CharSequence>) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the value of the 'runtimes' field.
setRuntimes(List<CharSequence>) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Sets the value of the 'runtimes' field.
setRuntimes(List<AvroRuntimeDefinition>) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition.Builder
Sets the value of the 'runtimes' field.
setRuntimes(List<AvroRuntimeDefinition>) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
Sets the value of the 'runtimes' field.
setSecrets(Map<String, List<StringEntry>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
setSecurityTokenKind(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'securityTokenKind' field.
setSecurityTokenKind(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'securityTokenKind' field.
setSecurityTokenService(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'securityTokenService' field.
setSecurityTokenService(CharSequence) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'securityTokenService' field.
setSelectedPlan(int) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan.Builder
optional sint32 selected_plan = 1;
setSenderId(String) - Method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec.Builder
 
setSenderId(String) - Method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec.Builder
 
setSeq(long) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf.Builder
required int64 seq = 2;
setSequence(long) - Method in class org.apache.reef.bridge.message.BridgeInterop.Builder
Sets the value of the 'sequence' field.
setSequence(Long) - Method in class org.apache.reef.bridge.message.BridgeInterop
Sets the value of the 'sequence' field.
setSerializedConfiguration(CharSequence) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition.Builder
Sets the value of the 'serializedConfiguration' field.
setSerializedConfiguration(CharSequence) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
Sets the value of the 'serializedConfiguration' field.
setServiceConfiguration(String) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
optional string service_configuration = 3;
setServiceConfigurationBytes(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto.Builder
optional string service_configuration = 3;
setServiceData(Map<String, List<StringEntry>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
setServiceInfo(CharSequence) - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Sets the value of the 'serviceInfo' field.
setServiceInfo(CharSequence) - Method in class org.apache.reef.webserver.AvroReefServiceInfo
Sets the value of the 'serviceInfo' field.
setServiceName(CharSequence) - Method in class org.apache.reef.webserver.AvroReefServiceInfo.Builder
Sets the value of the 'serviceName' field.
setServiceName(CharSequence) - Method in class org.apache.reef.webserver.AvroReefServiceInfo
Sets the value of the 'serviceName' field.
setServices(List<AvroReefServiceInfo>) - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Sets the value of the 'services' field.
setServices(List<AvroReefServiceInfo>) - Method in class org.apache.reef.webserver.AvroDriverInfo
Sets the value of the 'services' field.
setSharedAppSubmissionParameters(AvroAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Sets the value of the 'sharedAppSubmissionParameters' field.
setSharedAppSubmissionParameters(AvroAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Sets the value of the 'sharedAppSubmissionParameters' field.
setSharedAppSubmissionParameters(AvroAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the value of the 'sharedAppSubmissionParameters' field.
setSharedAppSubmissionParameters(AvroAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Sets the value of the 'sharedAppSubmissionParameters' field.
setSharedAppSubmissionParameters(AvroAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Sets the value of the 'sharedAppSubmissionParameters' field.
setSharedAppSubmissionParameters(AvroAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Sets the value of the 'sharedAppSubmissionParameters' field.
setSharedAppSubmissionParametersBuilder(AvroAppSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters.Builder
Sets the Builder instance for the 'sharedAppSubmissionParameters' field
setSharedAppSubmissionParametersBuilder(AvroAppSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the Builder instance for the 'sharedAppSubmissionParameters' field
setSharedAppSubmissionParametersBuilder(AvroAppSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters.Builder
Sets the Builder instance for the 'sharedAppSubmissionParameters' field
setSharedJobSubmissionParameters(AvroJobSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Sets the value of the 'sharedJobSubmissionParameters' field.
setSharedJobSubmissionParameters(AvroJobSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Sets the value of the 'sharedJobSubmissionParameters' field.
setSharedJobSubmissionParameters(AvroJobSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Sets the value of the 'sharedJobSubmissionParameters' field.
setSharedJobSubmissionParameters(AvroJobSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Sets the value of the 'sharedJobSubmissionParameters' field.
setSharedJobSubmissionParametersBuilder(AvroJobSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters.Builder
Sets the Builder instance for the 'sharedJobSubmissionParameters' field
setSharedJobSubmissionParametersBuilder(AvroJobSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters.Builder
Sets the Builder instance for the 'sharedJobSubmissionParameters' field
setShortName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'shortName' field.
setShortName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'shortName' field.
setShortName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string short_name = 6;
setShortNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
optional string short_name = 6;
setSibling(TaskNode) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
setSibling(TaskNode) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
setSignal(ClientRuntimeProtocol.Signal) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto.Builder
optional .Signal signal = 2;
setSimpleArgClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode.Builder
Sets the value of the 'simpleArgClassName' field.
setSimpleArgClassName(CharSequence) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Sets the value of the 'simpleArgClassName' field.
setSimpleArgClassName(String) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string simple_arg_class_name = 1;
setSimpleArgClassNameBytes(ByteString) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode.Builder
required string simple_arg_class_name = 1;
setSize(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
setSourceId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required string source_id = 1;
setSourceId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required string source_id = 1;
setSourceIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto.Builder
required string source_id = 1;
setSourceIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder
required string source_id = 1;
setSrcid(String) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string srcid = 2;
setSrcid(String) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string srcid = 2;
setSrcidBytes(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required string srcid = 2;
setSrcidBytes(ByteString) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf.Builder
required string srcid = 2;
setSrcVersion(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 srcVersion = 7;
setStandardErr(String) - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
setStandardErr(String) - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
Names a file to which stderr will be redirected.
setStandardErr(String) - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
setStandardErr(String) - Method in class org.apache.reef.runtime.common.launch.CLRLaunchCommandBuilder
 
setStandardErr(String) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
setStandardErr(String) - Method in interface org.apache.reef.runtime.common.launch.LaunchCommandBuilder
Names a file to which stderr will be redirected.
setStandardOut(String) - Method in class org.apache.reef.driver.evaluator.CLRProcess
 
setStandardOut(String) - Method in interface org.apache.reef.driver.evaluator.EvaluatorProcess
Names a file to which stdout will be redirected.
setStandardOut(String) - Method in class org.apache.reef.driver.evaluator.JVMProcess
 
setStandardOut(String) - Method in class org.apache.reef.runtime.common.launch.CLRLaunchCommandBuilder
 
setStandardOut(String) - Method in class org.apache.reef.runtime.common.launch.JavaLaunchCommandBuilder
 
setStandardOut(String) - Method in interface org.apache.reef.runtime.common.launch.LaunchCommandBuilder
Names a file to which stdout will be redirected.
setStartedTime(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setStartTask(EvaluatorRuntimeProtocol.StartTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
setStartTask(EvaluatorRuntimeProtocol.StartTaskProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StartTaskProto start_task = 7;
setStartTime(CharSequence) - Method in class org.apache.reef.webserver.AvroDriverInfo.Builder
Sets the value of the 'startTime' field.
setStartTime(CharSequence) - Method in class org.apache.reef.webserver.AvroDriverInfo
Sets the value of the 'startTime' field.
setStartTime(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Sets the value of the 'startTime' field.
setStartTime(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorList
Sets the value of the 'startTime' field.
setState(ReefServiceProtos.State) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto.Builder
required .State state = 2;
setState(ReefServiceProtos.State) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto.Builder
required .State state = 2;
setState(ReefServiceProtos.State) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required .State state = 3;
setState(State) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl.Builder
 
setState(State) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl.Builder
 
setState(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setStatusAndNotify(LauncherStatus) - Method in class org.apache.reef.client.DriverLauncher
Update job status and notify the waiting thread.
setStopEvaluator(EvaluatorRuntimeProtocol.StopEvaluatorProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
setStopEvaluator(EvaluatorRuntimeProtocol.StopEvaluatorProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
optional .StopEvaluatorProto stop_evaluator = 5;
setStopTask(EvaluatorRuntimeProtocol.StopTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
setStopTask(EvaluatorRuntimeProtocol.StopTaskProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .StopTaskProto stop_task = 8;
setSubmissionRuntime(String) - Method in class org.apache.reef.runtime.multi.client.MultiRuntimeConfigurationBuilder
Sets the submission runtime.
setSubplan(InjectionPlanProto.Subplan) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
setSubplan(InjectionPlanProto.Subplan.Builder) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan.Builder
optional .Subplan subplan = 4;
setSuspendedTaskHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setSuspendTask(EvaluatorRuntimeProtocol.SuspendTaskProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
setSuspendTask(EvaluatorRuntimeProtocol.SuspendTaskProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional .SuspendTaskProto suspend_task = 9;
setTaskId(String) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string task_id = 1;
setTaskIdBytes(ByteString) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
required string task_id = 1;
setTaskMessage(ByteString) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto.Builder
optional bytes task_message = 1;
setTaskMessage(int, ReefServiceProtos.TaskStatusProto.TaskMessageProto) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
setTaskMessage(int, ReefServiceProtos.TaskStatusProto.TaskMessageProto.Builder) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.Builder
repeated .TaskStatusProto.TaskMessageProto task_message = 6;
setTaskMessageHandler(long) - Method in class org.apache.reef.javabridge.BridgeHandlerManager
 
setTaskStatus(ReefServiceProtos.TaskStatusProto) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
setTaskStatus(ReefServiceProtos.TaskStatusProto.Builder) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
optional .TaskStatusProto task_status = 4;
setTcpBeginPort(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Sets the value of the 'tcpBeginPort' field.
setTcpBeginPort(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Sets the value of the 'tcpBeginPort' field.
setTcpRangeCount(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Sets the value of the 'tcpRangeCount' field.
setTcpRangeCount(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Sets the value of the 'tcpRangeCount' field.
setTcpTryCount(int) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters.Builder
Sets the value of the 'tcpTryCount' field.
setTcpTryCount(Integer) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Sets the value of the 'tcpTryCount' field.
setTimerPeriodTrigger(int) - Method in class org.apache.reef.vortex.api.VortexAggregatePolicy.AggregatePolicyBuilder
Sets the period to trigger aggregation in milliseconds.
setTimestamp(long) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime.Builder
Sets the value of the 'timestamp' field.
setTimestamp(Long) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime.Builder
Sets the value of the 'timestamp' field.
setTimestamp(Long) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart.Builder
Sets the value of the 'timestamp' field.
setTimestamp(Long) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop.Builder
Sets the value of the 'timestamp' field.
setTimestamp(Long) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto.Builder
required int64 timestamp = 1;
setTimestamp(long) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto.Builder
required int64 timestamp = 1;
setTimestamp(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
setTokens(Map<String, List<StringEntry>>) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
setTotal(int) - Method in class org.apache.reef.webserver.AvroEvaluatorList.Builder
Sets the value of the 'total' field.
setTotal(Integer) - Method in class org.apache.reef.webserver.AvroEvaluatorList
Sets the value of the 'total' field.
setTrackingUI(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setTrackingUrl(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setTuples(List<AvroNamingAssignment>) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse.Builder
Sets the value of the 'tuples' field.
setTuples(List<AvroNamingAssignment>) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Sets the value of the 'tuples' field.
setType(ReefNetworkGroupCommProtos.GroupCommMessage.Type) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
required .GroupCommMessage.Type type = 1;
setType(FileType) - Method in class org.apache.reef.runtime.common.files.FileResourceImpl.Builder
 
setType(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
setType(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo.Builder
Sets the value of the 'type' field.
setType(CharSequence) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
Sets the value of the 'type' field.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.reef.wake.impl.DefaultThreadFactory
Sets a uncaught exception handler.
setUnmanagedAM(boolean) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
SetupBridge - Class in org.apache.reef.bridge.message
 
SetupBridge() - Constructor for class org.apache.reef.bridge.message.SetupBridge
Default constructor.
SetupBridge(Integer) - Constructor for class org.apache.reef.bridge.message.SetupBridge
All-args constructor.
setupBridge() - Method in class org.apache.reef.util.logging.LoggingScopeFactory
The method is to measure the time used to set up Java CRL bridge.
SetupBridge.Builder - Class in org.apache.reef.bridge.message
RecordBuilder for SetupBridge instances.
setupCommonsLogging() - Static method in class org.apache.reef.util.logging.LoggingSetup
Redirect the commons logging to the JDK logger.
setUriSpecification(String) - Method in class org.apache.reef.examples.scheduler.driver.http.SchedulerHttpHandler
 
setUriSpecification(String) - Method in class org.apache.reef.javabridge.HttpServerEventBridge
 
setUriSpecification(String) - Method in interface org.apache.reef.webserver.HttpHandler
Set specification of the handler.
setUriSpecification(String) - Method in class org.apache.reef.webserver.HttpServerReefEventHandler
set URI specification.
setUser(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setUserConf(Configuration) - Method in class org.apache.reef.vortex.driver.VortexJobConf.Builder
 
setUserName(String) - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl.Builder
 
setValue(LocalResource) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResourcesEntry
 
setValue(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
setValue(CharSequence) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry.Builder
Sets the value of the 'value' field.
setValue(CharSequence) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Sets the value of the 'value' field.
setValue(String) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
required string value = 1;
setValue(V) - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage.Pair
 
setValue(CharSequence) - Method in class org.apache.reef.webserver.HeaderEntry.Builder
Sets the value of the 'value' field.
setValue(CharSequence) - Method in class org.apache.reef.webserver.HeaderEntry
Sets the value of the 'value' field.
setValueBytes(ByteString) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance.Builder
required string value = 1;
setvCores(int) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Resource
 
setVCoreSeconds(long) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
setVersion(int) - Method in interface org.apache.reef.io.network.group.api.task.NodeStruct
 
setVersion(int) - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
setVersion(int) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Builder
optional int32 version = 6;
setVirtualCores(int) - Method in class org.apache.reef.runtime.common.driver.api.ResourceRequestEventImpl.Builder
 
setVirtualCores(int) - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceEventImpl.Builder
 
setVisibility(String) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
setVortexMasterConf(Configuration) - Method in class org.apache.reef.vortex.driver.VortexJobConf.Builder
 
setYarnJobSubmissionParameters(AvroYarnJobSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the value of the 'yarnJobSubmissionParameters' field.
setYarnJobSubmissionParameters(AvroYarnJobSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Sets the value of the 'yarnJobSubmissionParameters' field.
setYarnJobSubmissionParametersBuilder(AvroYarnJobSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters.Builder
Sets the Builder instance for the 'yarnJobSubmissionParameters' field
setYarnRuntimeAppParameters(AvroYarnAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the value of the 'yarnRuntimeAppParameters' field.
setYarnRuntimeAppParameters(AvroYarnAppSubmissionParameters) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Sets the value of the 'yarnRuntimeAppParameters' field.
setYarnRuntimeAppParametersBuilder(AvroYarnAppSubmissionParameters.Builder) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters.Builder
Sets the Builder instance for the 'yarnRuntimeAppParameters' field
sharedAppSubmissionParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
Deprecated.
sharedAppSubmissionParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Deprecated.
sharedAppSubmissionParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
Deprecated.
sharedJobSubmissionParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
Deprecated.
sharedJobSubmissionParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
Deprecated.
ShellClient - Class in org.apache.reef.examples.distributedshell
The Client for REEF distributed shell example.
ShellTask - Class in org.apache.reef.examples.library
Execute command, capture its stdout, and return that string to the job driver.
SHORT_NAME - Static variable in class org.apache.reef.runtime.common.launch.parameters.ClockConfigurationPath
 
SHORT_NAME - Static variable in class org.apache.reef.runtime.common.launch.parameters.ErrorHandlerRID
Short name for the command line and such.
SHORT_NAME - Static variable in class org.apache.reef.runtime.common.launch.parameters.LaunchID
 
SHORT_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
shortName - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
shutdown() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
Close message dispatcher for the evaluator.
shutdown(ExecutorDriver) - Method in class org.apache.reef.runtime.mesos.evaluator.REEFExecutor
 
SIG_RESUME_VALUE - Static variable in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
SIG_RESUME = 3;
SIG_SUSPEND_VALUE - Static variable in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
SIG_SUSPEND = 2;
SIG_TERMINATE_VALUE - Static variable in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
SIG_TERMINATE = 1;
SIGNAL_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
SIMPLE_ARG_CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
simpleArgClassName - Variable in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
Deprecated.
simpleName(Class<?>) - Static method in class org.apache.reef.io.network.group.impl.utils.Utils
 
SimpleNamingService - Class in org.apache.reef.io.checkpoint
A naming service that simply returns the name it has been initialized with.
SimpleNamingService(String) - Constructor for class org.apache.reef.io.checkpoint.SimpleNamingService
 
SimpleNamingService.CheckpointName - Class in org.apache.reef.io.checkpoint
Prefix for checkpoints.
SimpleNamingService.CheckpointName() - Constructor for class org.apache.reef.io.checkpoint.SimpleNamingService.CheckpointName
 
SimpleSubject<T> - Class in org.apache.reef.wake.rx.impl
A Subject that relays all messages to its subscribers.
SimpleSubject(Observer<T>) - Constructor for class org.apache.reef.wake.rx.impl.SimpleSubject
Constructs a simple subject.
SimulatedDriverFailure - Exception in org.apache.reef.tests.library.exceptions
Thrown when a test fails on the task side.
SimulatedDriverFailure() - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedDriverFailure
 
SimulatedDriverFailure(String) - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedDriverFailure
 
SimulatedDriverFailure(String, Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedDriverFailure
 
SimulatedDriverFailure(Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedDriverFailure
 
SimulatedTaskFailure - Exception in org.apache.reef.tests.library.exceptions
Thrown when a test fails on the task side.
SimulatedTaskFailure() - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedTaskFailure
 
SimulatedTaskFailure(String) - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedTaskFailure
 
SimulatedTaskFailure(String, Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedTaskFailure
 
SimulatedTaskFailure(Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.SimulatedTaskFailure
 
SingleDataCenterEvaluatorToPartitionStrategy - Class in org.apache.reef.io.data.loading.impl
This is an online version which satisfies requests in a greedy way, for single data center network topologies.
SingleThreadStage<T> - Class in org.apache.reef.wake.impl
Single thread stage that runs the event handler.
SingleThreadStage(EventHandler<T>, int) - Constructor for class org.apache.reef.wake.impl.SingleThreadStage
Constructs a single thread stage.
SingleThreadStage(String, EventHandler<T>, int) - Constructor for class org.apache.reef.wake.impl.SingleThreadStage
Constructs a single thread stage.
SingletonAsserter - Class in org.apache.reef.util
A helper class that can be used to ensure that objects are only instantiated once.
size() - Method in class org.apache.reef.examples.group.utils.math.DenseVector
 
size() - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
The size (dimensionality) of the Vector.
size() - Method in class org.apache.reef.examples.group.utils.math.SparseVector
 
SIZE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
size() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
size() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
size() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
SlaveTask - Class in org.apache.reef.examples.group.bgd
Slave task for BGD example.
SlaveTask(GroupCommClient, ExampleList, LossFunction, double, StepSizes) - Constructor for class org.apache.reef.examples.group.bgd.SlaveTask
 
SlaveTask - Class in org.apache.reef.examples.group.broadcast
Slave task for broadcast example.
SlaveTask(GroupCommClient) - Constructor for class org.apache.reef.examples.group.broadcast.SlaveTask
 
SlaveTask - Class in org.apache.reef.tests.group
Slave task used for testing multiple communication groups.
sleep() - Method in class org.apache.reef.tang.examples.Timer
 
sleep() - Method in interface org.apache.reef.tang.examples.timer.Timer
 
sleep() - Method in class org.apache.reef.tang.examples.timer.TimerImpl
 
sleep() - Method in class org.apache.reef.tang.examples.timer.TimerMock
 
sleep() - Method in class org.apache.reef.tang.examples.TimerV1
 
SleepTask - Class in org.apache.reef.examples.pool
Sleep for delay seconds and quit.
SocketRemoteIdentifier - Class in org.apache.reef.wake.remote.impl
Remote identifier based on a socket address.
SocketRemoteIdentifier(InetSocketAddress) - Constructor for class org.apache.reef.wake.remote.impl.SocketRemoteIdentifier
Constructs a remote identifier.
SocketRemoteIdentifier(String) - Constructor for class org.apache.reef.wake.remote.impl.SocketRemoteIdentifier
Constructs a remote identifier.
SortingRamSpool<T> - Class in org.apache.reef.io.storage.ram
 
SortingRamSpool() - Constructor for class org.apache.reef.io.storage.ram.SortingRamSpool
 
SortingRamSpool(Comparator<T>) - Constructor for class org.apache.reef.io.storage.ram.SortingRamSpool
 
SOURCE_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
SOURCE_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
SourceAdd_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
SourceAdd = 9;
SourceDead_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
SourceDead = 8;
SparseExample - Class in org.apache.reef.examples.group.bgd.data
Example implementation on a index and value array.
SparseExample(double, float[], int[]) - Constructor for class org.apache.reef.examples.group.bgd.data.SparseExample
 
SparseVector - Class in org.apache.reef.examples.group.utils.math
A sparse vector represented by an index and value array.
SparseVector(double[], int[], int) - Constructor for class org.apache.reef.examples.group.utils.math.SparseVector
 
SparseVector(double[], int[]) - Constructor for class org.apache.reef.examples.group.utils.math.SparseVector
 
Spool<T> - Interface in org.apache.reef.io
Spool files can be appended to, and can be scanned starting at the beginning.
SquaredErrorLossFunction - Class in org.apache.reef.examples.group.bgd.loss
The Squared Error LossFunction.
SquaredErrorLossFunction() - Constructor for class org.apache.reef.examples.group.bgd.loss.SquaredErrorLossFunction
Trivial constructor.
SRCID_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
SRCID_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
SRCVERSION_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
SSH_PORT_NUM - Static variable in class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
The port number to attempt the ssh connection.
SSH_PORT_NUM - Static variable in class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
SSh port number.
SshPortNum - Class in org.apache.reef.runtime.standalone.client.parameters
The port number to access the remote nodes.
StackBindLocation - Class in org.apache.reef.tang.implementation
 
StackBindLocation() - Constructor for class org.apache.reef.tang.implementation.StackBindLocation
 
Stage - Interface in org.apache.reef.wake
Stage is an execution unit for events and provides a way to reclaim its resources.
StageConfiguration - Class in org.apache.reef.wake
Configuration options for Wake Stage.
StageConfiguration() - Constructor for class org.apache.reef.wake.StageConfiguration
 
StageConfiguration.Capacity - Class in org.apache.reef.wake
The capacity for the stage.
StageConfiguration.Capacity() - Constructor for class org.apache.reef.wake.StageConfiguration.Capacity
 
StageConfiguration.ErrorHandler - Class in org.apache.reef.wake
The error handler for the stage.
StageConfiguration.ErrorHandler() - Constructor for class org.apache.reef.wake.StageConfiguration.ErrorHandler
 
StageConfiguration.NumberOfThreads - Class in org.apache.reef.wake
The number of threads for the stage.
StageConfiguration.NumberOfThreads() - Constructor for class org.apache.reef.wake.StageConfiguration.NumberOfThreads
 
StageConfiguration.StageExecutorService - Class in org.apache.reef.wake
The executor service for the stage.
StageConfiguration.StageExecutorService() - Constructor for class org.apache.reef.wake.StageConfiguration.StageExecutorService
 
StageConfiguration.StageHandler - Class in org.apache.reef.wake
The event handler for the stage.
StageConfiguration.StageHandler() - Constructor for class org.apache.reef.wake.StageConfiguration.StageHandler
 
StageConfiguration.StageName - Class in org.apache.reef.wake
The stage name.
StageConfiguration.StageName() - Constructor for class org.apache.reef.wake.StageConfiguration.StageName
 
StageConfiguration.StageObserver - Class in org.apache.reef.wake
The observer for the stage.
StageConfiguration.StageObserver() - Constructor for class org.apache.reef.wake.StageConfiguration.StageObserver
 
StageConfiguration.TimerInitialDelay - Class in org.apache.reef.wake
The initial delay for periodic events of the timer stage.
StageConfiguration.TimerInitialDelay() - Constructor for class org.apache.reef.wake.StageConfiguration.TimerInitialDelay
 
StageConfiguration.TimerPeriod - Class in org.apache.reef.wake
The period for periodic events of the timer stage.
StageConfiguration.TimerPeriod() - Constructor for class org.apache.reef.wake.StageConfiguration.TimerPeriod
 
StageManager - Class in org.apache.reef.wake.impl
A manager that manages all the stage.
StandaloneDriverConfiguration - Class in org.apache.reef.runtime.standalone.driver
ConfigurationModule for the Driver executed in the standalone resourcemanager.
StandaloneDriverConfiguration() - Constructor for class org.apache.reef.runtime.standalone.driver.StandaloneDriverConfiguration
 
StandaloneResourceReleaseHandler - Class in org.apache.reef.runtime.standalone.driver
Takes Resource Release requests and closes process managers.
StandaloneRuntimeConfiguration - Class in org.apache.reef.runtime.standalone.client
A ConfigurationModule to configure the standalone resourcemanager.
StandaloneRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.standalone.client.StandaloneRuntimeConfiguration
 
start() - Method in class org.apache.reef.runtime.common.evaluator.context.ContextManager
Start the context manager.
start(VortexThreadPool) - Method in interface org.apache.reef.vortex.api.VortexStart
Implement this method, using VortexThreadPool to run jobs on Vortex.
start() - Method in interface org.apache.reef.webserver.HttpServer
start the server.
start() - Method in class org.apache.reef.webserver.HttpServerImpl
It will be called from RuntimeStartHandler.
start() - Method in class org.apache.reef.webserver.NoOpHttpServerImpl
 
START_INDICATORS - Static variable in class org.apache.reef.util.logging.LogParser
 
START_PREFIX - Static variable in class org.apache.reef.util.logging.LoggingScopeImpl
 
START_TASK_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
STARTED_TIME - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
startPackage(String) - Method in class org.apache.reef.tang.util.Tint
 
StartTime - Class in org.apache.reef.wake.time.event
Represents the Time at which a component started.
StartTime(long) - Constructor for class org.apache.reef.wake.time.event.StartTime
 
startTime - Variable in class org.apache.reef.webserver.AvroDriverInfo
Deprecated.
startTime - Variable in class org.apache.reef.webserver.AvroEvaluatorList
Deprecated.
State - Enum in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of ReefServiceProtos.State.
STATE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
STATE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
STATE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
STATE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
StatePassingDriver - Class in org.apache.reef.tests.statepassing
Driver for StatePassingTest.
StatePassingDriver(JobMessageObserver) - Constructor for class org.apache.reef.tests.statepassing.StatePassingDriver
 
StatePassingTask - Class in org.apache.reef.tests.statepassing
Task for StatePassingTest.
StatePassingTask(Counter) - Constructor for class org.apache.reef.tests.statepassing.StatePassingTask
 
StaticObservable - Interface in org.apache.reef.wake.rx
Defines a "static" provider for push-based notification.
StepSizes - Class in org.apache.reef.examples.group.bgd.utils
Step sizes array.
StepSizes() - Constructor for class org.apache.reef.examples.group.bgd.utils.StepSizes
 
stop() - Method in interface org.apache.reef.wake.time.Clock
This stops the clock immediately, without waiting for client alarms to finish.
stop(Throwable) - Method in interface org.apache.reef.wake.time.Clock
This stops the clock immediately, without waiting for client alarms to finish.
stop() - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
Stop the clock.
stop(Throwable) - Method in class org.apache.reef.wake.time.runtime.RuntimeClock
Stop the clock on exception.
stop() - Method in interface org.apache.reef.webserver.HttpServer
stop the server.
stop() - Method in class org.apache.reef.webserver.HttpServerImpl
stop Jetty Server.
stop() - Method in class org.apache.reef.webserver.NoOpHttpServerImpl
 
STOP_EVALUATOR_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
STOP_TASK_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
StopTime - Class in org.apache.reef.wake.time.event
Represents the Time at which a component stops.
StopTime(long) - Constructor for class org.apache.reef.wake.time.event.StopTime
 
STORAGE_ACCOUNT_KEY - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The Storage account key to be used by Azure.
STORAGE_ACCOUNT_KEY - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
The Storage account key to be used by Azure.
STORAGE_ACCOUNT_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The Storage account to be used by Azure.
STORAGE_ACCOUNT_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
The Storage account to be used by Azure.
StorageException - Exception in org.apache.reef.exception.evaluator
Storage exception.
StorageException(String, Throwable) - Constructor for exception org.apache.reef.exception.evaluator.StorageException
 
StorageException(String) - Constructor for exception org.apache.reef.exception.evaluator.StorageException
 
StorageException(Throwable) - Constructor for exception org.apache.reef.exception.evaluator.StorageException
 
StorageService - Interface in org.apache.reef.io.storage
 
StreamingCodec<T> - Interface in org.apache.reef.io.network.impl
A codec that can make serialization more efficient when an object has to be.
StrictPreemptionEvent - Interface in org.apache.reef.driver
Represents a strict preemption event: It contains the set of Evaluators that the underlying resource manager will take away from the Driver.
StringCodec - Class in org.apache.reef.io.network.util
 
StringCodec() - Constructor for class org.apache.reef.io.network.util.StringCodec
 
StringCodec - Class in org.apache.reef.wake.remote.impl
Codec that encodes/decodes a string.
StringCodec() - Constructor for class org.apache.reef.wake.remote.impl.StringCodec
 
StringDeserializer - Class in org.apache.reef.io.storage.util
 
StringDeserializer() - Constructor for class org.apache.reef.io.storage.util.StringDeserializer
 
StringEntry - Class in org.apache.reef.runtime.hdinsight.client.yarnrest
An Entry with String Key and String Value in the Environment field and the ApplicationAcls field of an ApplicationSubmission.
StringEntry(String, String) - Constructor for class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
StringIdentifier - Class in org.apache.reef.io.network.util
String identifier.
StringIdentifierFactory - Class in org.apache.reef.io.network.util
Factory that creates StringIdentifier.
StringIdentifierFactory() - Constructor for class org.apache.reef.io.network.util.StringIdentifierFactory
 
StringSerializer - Class in org.apache.reef.io.storage.util
 
StringSerializer() - Constructor for class org.apache.reef.io.storage.util.StringSerializer
 
stripCommonPrefixes(String) - Static method in class org.apache.reef.tang.util.Tint
 
stripPrefix(String, String) - Static method in class org.apache.reef.tang.util.Tint
 
stripPrefixHelper2(String, String) - Static method in class org.apache.reef.tang.util.Tint
 
SubConfiguration - Class in org.apache.reef.examples.group.bgd.utils
Subconfiguration: limit given configuration to a given list of classes.
Subject<InType,OutType> - Interface in org.apache.reef.wake.rx
A class implementing Observer<InType> and StaticObservable<OutType>.
submit(Configuration, long) - Method in class org.apache.reef.client.DriverLauncher
Submit REEF job asynchronously and do not wait for its completion.
submit(Configuration) - Method in interface org.apache.reef.client.REEF
Submits the Driver set up in the given Configuration for execution.
submit(EvaluatorRequest) - Method in interface org.apache.reef.driver.evaluator.EvaluatorRequestor
Submit the request for new evaluator.
submit(Configuration, String) - Method in class org.apache.reef.examples.group.bgd.BGDClient
Runs BGD on the given runtime.
submit() - Method in class org.apache.reef.examples.suspend.SuspendClient
Start the job driver.
submit(int, int, int, String, String) - Method in class org.apache.reef.javabridge.EvaluatorRequestorBridge
 
submit(File, boolean, boolean, Configuration) - Method in class org.apache.reef.javabridge.generic.JobClient
Launch the job driver.
submit(Configuration) - Method in class org.apache.reef.runtime.common.client.REEFImplementation
 
submit() - Method in class org.apache.reef.runtime.common.driver.EvaluatorRequestorImpl.Builder
 
submit(EvaluatorRequest) - Method in class org.apache.reef.runtime.common.driver.EvaluatorRequestorImpl
 
submit() - Method in class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
 
submit(VortexFunction<TInput, TOutput>, TInput) - Method in class org.apache.reef.vortex.api.VortexThreadPool
 
submit(VortexFunction<TInput, TOutput>, TInput, FutureCallback<TOutput>) - Method in class org.apache.reef.vortex.api.VortexThreadPool
 
submit(VortexAggregateFunction<TOutput>, VortexFunction<TInput, TOutput>, VortexAggregatePolicy, List<TInput>) - Method in class org.apache.reef.vortex.api.VortexThreadPool
 
submit(VortexAggregateFunction<TOutput>, VortexFunction<TInput, TOutput>, VortexAggregatePolicy, List<TInput>, FutureCallback<AggregateResult<TInput, TOutput>>) - Method in class org.apache.reef.vortex.api.VortexThreadPool
 
submit(ForkJoinTask<?>) - Method in class org.apache.reef.wake.impl.WakeSharedPool
 
submitApplication(ApplicationSubmission) - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.HDInsightInstance
Submits an application for execution.
submitCommand(String) - Method in class org.apache.reef.examples.scheduler.driver.SchedulerDriver
Submit a command to schedule.
submitContext(Configuration) - Method in interface org.apache.reef.driver.context.ActiveContext
 
submitContext(Configuration) - Method in interface org.apache.reef.driver.ContextSubmittable
Submit a Context.
submitContext(Configuration) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
 
submitContext(Configuration) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitContext(String) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitContext(Configuration) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
submitContext(String, String) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
Submit Context with configuration strings.
submitContextAndService(Configuration, Configuration) - Method in interface org.apache.reef.driver.context.ActiveContext
 
submitContextAndService(Configuration, Configuration) - Method in interface org.apache.reef.driver.ContextSubmittable
Submit a Context and a Service Configuration.
submitContextAndService(Configuration, Configuration) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
 
submitContextAndService(Configuration, Configuration) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitContextAndService(String, String) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitContextAndService(String, Optional<String>) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitContextAndService(Configuration, Configuration) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
submitContextAndService(String, String, String) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
Submit Context and Service with configuration strings.
submitContextAndServiceAndTask(Configuration, Configuration, Configuration) - Method in interface org.apache.reef.driver.ContextAndTaskSubmittable
Submit a Context with Services and a Task.
submitContextAndServiceAndTask(Configuration, Configuration, Configuration) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
 
submitContextAndServiceAndTask(Configuration, Configuration, Configuration) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
submitContextAndServiceAndTask(String, String, String, String) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
Submit Context and Service with configuration strings.
submitContextAndServiceAndTaskString(String, String, String, String) - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
Bridge function for REEF .NET to submit context, service.
submitContextAndServiceString(String, String, String) - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
Bridge function for REEF .NET to submit context and service configurations for the allocated evaluator.
submitContextAndTask(Configuration, Configuration) - Method in interface org.apache.reef.driver.ContextAndTaskSubmittable
Submit a Context and a Task.
submitContextAndTask(Configuration, Configuration) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
 
submitContextAndTask(Configuration, Configuration) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
submitContextAndTask(String, String, String) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
Submit Context and Task with configuration strings.
submitContextAndTaskString(String, String, String) - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
Bridge function for REEF .NET to submit context and task configurations for the allocated evaluator.
submitContextString(String, String) - Method in class org.apache.reef.javabridge.AllocatedEvaluatorBridge
Bridge function for REEF .NET to submit context configuration for the allocated evaluator.
submitContextStringAndServiceString(String, String) - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
submitTask(Configuration) - Method in interface org.apache.reef.driver.context.ActiveContext
 
submitTask(Configuration) - Method in interface org.apache.reef.driver.evaluator.AllocatedEvaluator
Submits the given Task for execution.
submitTask(Configuration) - Method in interface org.apache.reef.driver.TaskSubmittable
Submits a Task (encoded in the Configuration) for execution.
submitTask(Configuration) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitTask(String) - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
submitTask(Configuration) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
submitTask(String, String) - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
Submit Task with configuration strings.
submitTaskString(String) - Method in class org.apache.reef.javabridge.ActiveContextBridge
 
SUBMITTED - Static variable in class org.apache.reef.client.LauncherStatus
 
SubmittedJob - Interface in org.apache.reef.client
Represents a completed REEF job.
Subplan<T> - Class in org.apache.reef.tang.implementation
 
Subplan(Node, int, InjectionPlan<T>...) - Constructor for class org.apache.reef.tang.implementation.Subplan
 
Subplan(Node, InjectionPlan<T>...) - Constructor for class org.apache.reef.tang.implementation.Subplan
 
SUBPLAN_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
subscribe(Class<? extends T>, EventHandler<? extends T>) - Method in class org.apache.reef.wake.impl.PubSubEventHandler
Subscribes an event handler for an event class type.
subscribe(Observer<T>) - Method in interface org.apache.reef.wake.rx.DynamicObservable
Subscribes the observer to this observable object.
Subscription<T> - Class in org.apache.reef.wake.remote.impl
Deprecated.
[REEF-1544] Prefer using SubscriptionHandler and the corresponding handlers instead of the Subscription class. Remove class after release 0.16.
Subscription(T, HandlerContainer<T>) - Constructor for class org.apache.reef.wake.remote.impl.Subscription
Deprecated.
Constructs a subscription.
successor() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
successor() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
sum() - Method in interface org.apache.reef.examples.group.utils.math.ImmutableVector
Computes the computeSum of all entries in the Vector.
suspend(byte[]) - Method in interface org.apache.reef.driver.task.RunningTask
Signal the task to suspend.
suspend() - Method in interface org.apache.reef.driver.task.RunningTask
Signal the task to suspend.
suspend(byte[]) - Method in class org.apache.reef.javabridge.RunningTaskBridge
 
suspend(byte[]) - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
suspend() - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
suspend(byte[]) - Method in class org.apache.reef.runtime.common.evaluator.task.TaskRuntime
Suspend the Task.
SUSPEND_TASK_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
SUSPEND_VALUE - Static variable in enum org.apache.reef.proto.ReefServiceProtos.State
SUSPEND = 3;
SuspendClient - Class in org.apache.reef.examples.suspend
Client for suspend example.
SuspendClientControl - Class in org.apache.reef.examples.suspend
(Wake) listener to get suspend/resume commands from Control process.
SuspendClientControl(int, TransportFactory) - Constructor for class org.apache.reef.examples.suspend.SuspendClientControl
 
SuspendClientControl.Port - Class in org.apache.reef.examples.suspend
Port for suspend/resume control commands.
SuspendClientControl.Port() - Constructor for class org.apache.reef.examples.suspend.SuspendClientControl.Port
 
SuspendDriver - Class in org.apache.reef.examples.suspend
Suspend/resume example job driver.
SuspendedTask - Interface in org.apache.reef.driver.task
Represents a suspended Task.
SuspendedTaskBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for SuspendedTask.
SuspendedTaskBridge(SuspendedTask, ActiveContextBridgeFactory) - Constructor for class org.apache.reef.javabridge.SuspendedTaskBridge
 
SuspendedTaskImpl - Class in org.apache.reef.runtime.common.driver.task
Implementation of SuspendedTask.
SuspendedTaskImpl(ActiveContext, byte[], String) - Constructor for class org.apache.reef.runtime.common.driver.task.SuspendedTaskImpl
 
SuspendEvent - Interface in org.apache.reef.task.events
Event fired when the driver called suspend() on this task.
SuspendTestTask - Class in org.apache.reef.examples.suspend
Simple do-nothing task that can send messages to the Driver and can be suspended/resumed.
SuspendTestTask(CheckpointService, int, int) - Constructor for class org.apache.reef.examples.suspend.SuspendTestTask
Task constructor: invoked by TANG.
SuspendTestTask.SuspendHandler - Class in org.apache.reef.examples.suspend
Handler for suspend event.
SuspendTestTask.SuspendHandler() - Constructor for class org.apache.reef.examples.suspend.SuspendTestTask.SuspendHandler
 
SVMLightParser - Class in org.apache.reef.examples.group.bgd.data.parser
A Parser for SVMLight records.
SVMLightParser() - Constructor for class org.apache.reef.examples.group.bgd.data.parser.SVMLightParser
 
SyncStage<T> - Class in org.apache.reef.wake.impl
Stage that synchronously executes an event handler.
SyncStage(EventHandler<T>) - Constructor for class org.apache.reef.wake.impl.SyncStage
Constructs a synchronous stage.
SyncStage(String, EventHandler<T>) - Constructor for class org.apache.reef.wake.impl.SyncStage
Constructs a synchronous stage.
SyncStage(String, EventHandler<T>, EventHandler<Throwable>) - Constructor for class org.apache.reef.wake.impl.SyncStage
Constructs a synchronous stage.
SystemOnStart - Class in org.apache.reef.bridge.message
 
SystemOnStart() - Constructor for class org.apache.reef.bridge.message.SystemOnStart
Default constructor.
SystemOnStart(Long) - Constructor for class org.apache.reef.bridge.message.SystemOnStart
All-args constructor.
SystemOnStart.Builder - Class in org.apache.reef.bridge.message
RecordBuilder for SystemOnStart instances.
SystemTempFileCreator - Class in org.apache.reef.io
A TempFileCreator that uses the system's temp directory.
SystemTempFileCreator() - Constructor for class org.apache.reef.io.SystemTempFileCreator
 
SystemTime - Class in org.apache.reef.util.cache
Return the system time.
SystemTime() - Constructor for class org.apache.reef.util.cache.SystemTime
 

T

takesParameters(ClassNode<?>[]) - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
takesParameters(ClassNode<?>[]) - Method in interface org.apache.reef.tang.types.ConstructorDef
 
Tang - Interface in org.apache.reef.tang
The root factory interface for Tang.
Tang.Factory - Class in org.apache.reef.tang
A factory that returns the default implementation of the Tang interface.
TangImpl - Class in org.apache.reef.tang.implementation
 
TangImpl() - Constructor for class org.apache.reef.tang.implementation.TangImpl
 
TASK - Static variable in class org.apache.reef.driver.task.TaskConfiguration
The task to instantiate.
Task - Interface in org.apache.reef.task
The interface for Tasks.
TASK_COMPLETE - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
TASK_CONF - Static variable in class org.apache.reef.poison.PoisonedConfiguration
 
TASK_CONFIGURATION - Static variable in class org.apache.reef.runtime.common.evaluator.EvaluatorConfiguration
 
TASK_ID - Static variable in class org.apache.reef.examples.group.bgd.MasterTask
 
TASK_ID - Static variable in class org.apache.reef.examples.group.broadcast.MasterTask
 
TASK_ID_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
TASK_MESSAGE - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
TASK_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
TASK_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
TASK_OUTPUT_STREAM_PROVIDER - Static variable in class org.apache.reef.io.data.output.TaskOutputServiceBuilder
A provider through which users create task output streams.
TASK_RUNNING - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
TASK_STATUS_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
TASK_SUSPEND - Static variable in class org.apache.reef.util.logging.LoggingScopeFactory
 
TaskCallFailure - Exception in org.apache.reef.runtime.common.evaluator.task.exceptions
Thrown when a Task.call() throws an exception.
TaskCallFailure(Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.exceptions.TaskCallFailure
 
TaskClientCodeException - Exception in org.apache.reef.runtime.common.evaluator.task
Thrown by REEF's resourcemanager code when it catches an exception thrown by user code.
TaskClientCodeException(String, String, String, Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.TaskClientCodeException
 
TaskCloseHandlerFailure - Exception in org.apache.reef.runtime.common.evaluator.task.exceptions
Thrown when a Task Close Handler throws an exception.
TaskCloseHandlerFailure(Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.exceptions.TaskCloseHandlerFailure
 
taskCompleted(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling taskCompletedHandler.
TaskCompletedHandlers - Class in org.apache.reef.driver.parameters
Completed task handler.
TaskConfiguration - Class in org.apache.reef.driver.task
A ConfigurationModule to fill out to generate legal task Configurations that can be submitted.
TaskConfiguration() - Constructor for class org.apache.reef.driver.task.TaskConfiguration
 
TaskConfigurationOptions - Class in org.apache.reef.driver.task
Configuration parameters for the TaskConfiguration class.
TaskConfigurationOptions() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions
 
TaskConfigurationOptions.CloseHandler - Class in org.apache.reef.driver.task
The event handler that receives the close event.
TaskConfigurationOptions.CloseHandler() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.CloseHandler
 
TaskConfigurationOptions.Identifier - Class in org.apache.reef.driver.task
The Identifier of the Task.
TaskConfigurationOptions.Identifier() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.Identifier
 
TaskConfigurationOptions.Memento - Class in org.apache.reef.driver.task
The memento to be used for the Task.
TaskConfigurationOptions.Memento() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.Memento
 
TaskConfigurationOptions.MessageHandler - Class in org.apache.reef.driver.task
The event handler that receives messages from the driver.
TaskConfigurationOptions.MessageHandler() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.MessageHandler
 
TaskConfigurationOptions.StartHandlers - Class in org.apache.reef.driver.task
The set of event handlers for the TaskStart event.
TaskConfigurationOptions.StartHandlers() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.StartHandlers
 
TaskConfigurationOptions.StopHandlers - Class in org.apache.reef.driver.task
The set of event handlers for the TaskStop event.
TaskConfigurationOptions.StopHandlers() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.StopHandlers
 
TaskConfigurationOptions.SuspendHandler - Class in org.apache.reef.driver.task
The event handler that receives the suspend event.
TaskConfigurationOptions.SuspendHandler() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.SuspendHandler
 
TaskConfigurationOptions.TaskMessageSources - Class in org.apache.reef.driver.task
TaskMessageSource instances.
TaskConfigurationOptions.TaskMessageSources() - Constructor for class org.apache.reef.driver.task.TaskConfigurationOptions.TaskMessageSources
 
TaskFailedHandlers - Class in org.apache.reef.driver.parameters
Task failure handler.
TaskletAggregateExecutionRequest<TInput> - Class in org.apache.reef.vortex.protocol.mastertoworker
A request from the Vortex Driver to run an aggregate-able function.
TaskletAggregateExecutionRequest(int, int, TInput) - Constructor for class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregateExecutionRequest
 
TaskletAggregationFailureReport - Class in org.apache.reef.vortex.protocol.workertomaster
Report of a tasklet exception on aggregation.
TaskletAggregationFailureReport(List<Integer>, Exception) - Constructor for class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationFailureReport
 
TaskletAggregationRequest<TInput,TOutput> - Class in org.apache.reef.vortex.protocol.mastertoworker
A request from the Vortex Driver for the VortexWorker to record aggregate functions for later execution.
TaskletAggregationRequest(int, VortexAggregateFunction<TOutput>, VortexFunction<TInput, TOutput>, VortexAggregatePolicy) - Constructor for class org.apache.reef.vortex.protocol.mastertoworker.TaskletAggregationRequest
 
TaskletAggregationResultReport - Class in org.apache.reef.vortex.protocol.workertomaster
Report of a Tasklet aggregation execution result.
TaskletAggregationResultReport(List<Integer>, Object) - Constructor for class org.apache.reef.vortex.protocol.workertomaster.TaskletAggregationResultReport
 
TaskletCancellationRequest - Class in org.apache.reef.vortex.protocol.mastertoworker
A MasterToWorkerRequest to cancel tasklets.
TaskletCancellationRequest(int) - Constructor for class org.apache.reef.vortex.protocol.mastertoworker.TaskletCancellationRequest
 
TaskletCancelledReport - Class in org.apache.reef.vortex.protocol.workertomaster
The report of a cancelled Tasklet.
TaskletCancelledReport(int) - Constructor for class org.apache.reef.vortex.protocol.workertomaster.TaskletCancelledReport
 
TaskletExecutionRequest<TInput,TOutput> - Class in org.apache.reef.vortex.protocol.mastertoworker
Request to execute a tasklet.
TaskletExecutionRequest(int, VortexFunction<TInput, TOutput>, TInput) - Constructor for class org.apache.reef.vortex.protocol.mastertoworker.TaskletExecutionRequest
Request from Vortex Master to Vortex Worker to execute a tasklet.
TaskletFailureReport - Class in org.apache.reef.vortex.protocol.workertomaster
Report of a Tasklet exception.
TaskletFailureReport(int, Exception) - Constructor for class org.apache.reef.vortex.protocol.workertomaster.TaskletFailureReport
 
TaskletResultReport - Class in org.apache.reef.vortex.protocol.workertomaster
Report of a tasklet execution result.
TaskletResultReport(int, Object) - Constructor for class org.apache.reef.vortex.protocol.workertomaster.TaskletResultReport
 
TaskMessage - Interface in org.apache.reef.driver.task
A message from a running task to the driver.
TaskMessage - Class in org.apache.reef.task
A message sent from a Task to a Driver.
TaskMessageBridge - Class in org.apache.reef.javabridge
The Java-CLR bridge object for TaskMessage.
TaskMessageBridge(TaskMessage) - Constructor for class org.apache.reef.javabridge.TaskMessageBridge
 
TaskMessageHandlerFailure - Exception in org.apache.reef.runtime.common.evaluator.task.exceptions
Thrown when a Task Message Handler throws an exception.
TaskMessageHandlerFailure(Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.exceptions.TaskMessageHandlerFailure
the exception thrown by the task message handler's onNext() method.
TaskMessageHandlers - Class in org.apache.reef.driver.parameters
Task message handler.
TaskMessageImpl - Class in org.apache.reef.runtime.common.driver.task
Implementation of TaskMessage.
TaskMessageImpl(byte[], String, String, String, long) - Constructor for class org.apache.reef.runtime.common.driver.task.TaskMessageImpl
 
TaskMessagePOJO - Class in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of TaskMessageProto.
taskMessageReceived(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling taskMessageReceivedHandler.
TaskMessageSource - Interface in org.apache.reef.task
Message source for control flow messages from a task to the Driver.
TaskMessagingDriver - Class in org.apache.reef.tests.messaging.task
Driver for TaskMessagingTest.
TaskMessagingDriver(JobMessageObserver, Clock) - Constructor for class org.apache.reef.tests.messaging.task.TaskMessagingDriver
 
TaskMessagingDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.tests.messaging.task
Handler for AllocatedEvaluator.
TaskMessagingDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.tests.messaging.task.TaskMessagingDriver.EvaluatorAllocatedHandler
 
TaskMessagingDriver.TaskMessageHandler - Class in org.apache.reef.tests.messaging.task
Handler for TaskMessage.
TaskMessagingDriver.TaskMessageHandler() - Constructor for class org.apache.reef.tests.messaging.task.TaskMessagingDriver.TaskMessageHandler
 
TaskMessagingDriver.TaskRunningHandler - Class in org.apache.reef.tests.messaging.task
Handler for RunningTask.
TaskMessagingDriver.TaskRunningHandler() - Constructor for class org.apache.reef.tests.messaging.task.TaskMessagingDriver.TaskRunningHandler
 
TaskMessagingTask - Class in org.apache.reef.tests.messaging.task
A basic task that receives a message and sends it back to the driver.
TaskMessagingTask() - Constructor for class org.apache.reef.tests.messaging.task.TaskMessagingTask
 
TaskMessagingTask.DriverMessageHandler - Class in org.apache.reef.tests.messaging.task
Handler for DriverMessage.
TaskMessagingTask.DriverMessageHandler() - Constructor for class org.apache.reef.tests.messaging.task.TaskMessagingTask.DriverMessageHandler
 
TaskNode - Interface in org.apache.reef.io.network.group.api.driver
A node in the Topology representing a Task on the driver.
TaskNodeImpl - Class in org.apache.reef.io.network.group.impl.driver
 
TaskNodeImpl(EStage<GroupCommunicationMessage>, Class<? extends Name<String>>, Class<? extends Name<String>>, String, String, boolean) - Constructor for class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
TaskNodeStatus - Interface in org.apache.reef.io.network.group.api.driver
Tracks the Status of the ctrl msgs sent to a task node in the topology - what msgs have been sent to this node and what msgs have been ACKed as received by this node Status of neighbors This is used to see whether the local topology of a Task is completely set-up It also offers convenience methods for waiting on receiving ACKs from the task.
TaskNodeStatusImpl - Class in org.apache.reef.io.network.group.impl.driver
 
TaskNodeStatusImpl(Class<? extends Name<String>>, Class<? extends Name<String>>, String, TaskNode) - Constructor for class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
TaskOutputService - Class in org.apache.reef.io.data.output
A service class of the task output service.
TaskOutputService.OutputPath - Class in org.apache.reef.io.data.output
Path of the directory where output files are created.
TaskOutputService.OutputPath() - Constructor for class org.apache.reef.io.data.output.TaskOutputService.OutputPath
 
TaskOutputServiceBuilder - Class in org.apache.reef.io.data.output
Builder to create a TaskOutputService object.
TaskOutputServiceBuilder() - Constructor for class org.apache.reef.io.data.output.TaskOutputServiceBuilder
 
TaskOutputStreamProvider - Class in org.apache.reef.io.data.output
A provider through which users create task output streams.
TaskOutputStreamProvider() - Constructor for class org.apache.reef.io.data.output.TaskOutputStreamProvider
 
TaskOutputStreamProviderHDFS - Class in org.apache.reef.io.data.output
Implementation of TaskOutputStreamProvider.
TaskOutputStreamProviderLocal - Class in org.apache.reef.io.data.output
Implementation of TaskOutputStreamProvider.
TaskRepresenter - Class in org.apache.reef.runtime.common.driver.task
Represents a Task on the Driver.
TaskRepresenter(String, EvaluatorContext, EvaluatorMessageDispatcher, EvaluatorManager, ExceptionCodec, DriverRestartManager) - Constructor for class org.apache.reef.runtime.common.driver.task.TaskRepresenter
 
taskRunning(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling runningTaskHandler.
TaskRunningHandlers - Class in org.apache.reef.driver.parameters
Running task handler.
TaskRuntime - Class in org.apache.reef.runtime.common.evaluator.task
The execution environment for a Task.
TaskSide - Annotation Type in org.apache.reef.annotations.audience
Annotates interfaces meant to be used by Tasks.
TaskSideFailure - Exception in org.apache.reef.tests.library.exceptions
Thrown when a test fails on the task side.
TaskSideFailure() - Constructor for exception org.apache.reef.tests.library.exceptions.TaskSideFailure
 
TaskSideFailure(String) - Constructor for exception org.apache.reef.tests.library.exceptions.TaskSideFailure
 
TaskSideFailure(String, Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.TaskSideFailure
 
TaskSideFailure(Throwable) - Constructor for exception org.apache.reef.tests.library.exceptions.TaskSideFailure
 
TaskStart - Interface in org.apache.reef.task.events
Represents a TaskStart.
TaskStartHandlerFailure - Exception in org.apache.reef.runtime.common.evaluator.task.exceptions
Thrown when a TaskStart handler throws an exception.
TaskStartHandlerFailure(EventHandler<TaskStart>, Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.exceptions.TaskStartHandlerFailure
 
TaskState - Enum in org.apache.reef.io.network.group.impl.driver
 
TaskStatus - Class in org.apache.reef.runtime.common.evaluator.task
Represents the various states a Task could be in.
TaskStatusPOJO - Class in org.apache.reef.runtime.common.driver.evaluator.pojos
DriverSide representation of TaskStatusProto.
TaskStatusPOJO(ReefServiceProtos.TaskStatusProto, long) - Constructor for class org.apache.reef.runtime.common.driver.evaluator.pojos.TaskStatusPOJO
 
TaskStop - Interface in org.apache.reef.task.events
Represents a Task stop.
TaskStopHandlerFailure - Exception in org.apache.reef.runtime.common.evaluator.task.exceptions
Thrown when a TaskStop handler throws an exception.
TaskStopHandlerFailure(EventHandler<TaskStop>, Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.exceptions.TaskStopHandlerFailure
 
TaskSubmittable - Interface in org.apache.reef.driver
Base interface for classes that support Task submission.
taskSuspended(String) - Method in class org.apache.reef.util.logging.LoggingScopeFactory
This is to measure the time in calling taskSuspendedHandler.
TaskSuspendedHandlers - Class in org.apache.reef.driver.parameters
Suspended task handler.
TaskSuspendHandlerFailure - Exception in org.apache.reef.runtime.common.evaluator.task.exceptions
Thrown when a Task Suspend Handler throws an exception.
TaskSuspendHandlerFailure(Throwable) - Constructor for exception org.apache.reef.runtime.common.evaluator.task.exceptions.TaskSuspendHandlerFailure
 
TaskVersion - Class in org.apache.reef.io.network.group.impl.config.parameters
 
tcpBeginPort - Variable in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Deprecated.
TcpPortConfigurationProvider - Class in org.apache.reef.io
Implements ConfigurationProvider for RangeTcpPortProvider.
TcpPortProvider - Interface in org.apache.reef.wake.remote.ports
Provides an iterator that returns port numbers.
TcpPortRangeBegin - Class in org.apache.reef.wake.remote.ports.parameters
First tcp port number to try.
TcpPortRangeCount - Class in org.apache.reef.wake.remote.ports.parameters
Number of tcp ports in the range.
TcpPortRangeTryCount - Class in org.apache.reef.wake.remote.ports.parameters
Max number tries for port numbers.
tcpRangeCount - Variable in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Deprecated.
tcpTryCount - Variable in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
Deprecated.
TempFileCreator - Interface in org.apache.reef.io
Utility to create temporary files and folders in accordance with the underlying resource manager.
TempFileRootFolder - Class in org.apache.reef.io.parameters
Directory for temp files.
TempFileRootFolder() - Constructor for class org.apache.reef.io.parameters.TempFileRootFolder
 
terminate() - Method in interface org.apache.reef.vortex.driver.VortexMaster
Release all resources and shut down.
TestDriverLauncher - Class in org.apache.reef.tests
A launcher for REEF Drivers.
TestEventStream - Class in org.apache.reef.tests.watcher
Count events in the stream.
TestProtos - Class in org.apache.reef.wake.test.proto
 
TestProtos.TestEventPBuf - Class in org.apache.reef.wake.test.proto
Protobuf type TestEventPBuf
TestProtos.TestEventPBuf.Builder - Class in org.apache.reef.wake.test.proto
Protobuf type TestEventPBuf
TestProtos.TestEventPBufOrBuilder - Interface in org.apache.reef.wake.test.proto
 
ThreadLogFormatter - Class in org.apache.reef.util.logging
A denser logging format for REEF that is similar to the standard SimpleFormatter.
ThreadLogFormatter() - Constructor for class org.apache.reef.util.logging.ThreadLogFormatter
 
ThreadLogger - Class in org.apache.reef.util
Methods to log the currently active set of threads with their stack traces.
ThreadPoolStage<T> - Class in org.apache.reef.wake.impl
Stage that executes an event handler with a thread pool.
ThreadPoolStage(EventHandler<T>, int) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
ThreadPoolStage(String, EventHandler<T>, int, EventHandler<Throwable>) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
ThreadPoolStage(String, EventHandler<T>, int) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
ThreadPoolStage(EventHandler<T>, ExecutorService) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
ThreadPoolStage(EventHandler<T>, ExecutorService, EventHandler<Throwable>) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
ThreadPoolStage(String, EventHandler<T>, ExecutorService) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
ThreadPoolStage(String, EventHandler<T>, ExecutorService, EventHandler<Throwable>) - Constructor for class org.apache.reef.wake.impl.ThreadPoolStage
Constructs a thread-pool stage.
threwException(int, Exception) - Method in class org.apache.reef.vortex.api.VortexAggregateFuture
A Tasklet associated with the aggregation has failed.
threwException(int, Exception) - Method in class org.apache.reef.vortex.api.VortexFuture
Called by VortexMaster to let the user know that the Tasklet threw an exception.
threwException(int, Exception) - Method in interface org.apache.reef.vortex.driver.VortexFutureDelegate
A Tasklet associated with the Future has thrown an Exception.
tick() - Method in class org.apache.reef.wake.metrics.EWMA
Updates the rate.
Time - Class in org.apache.reef.wake.time
An abstract object that has a timestamp.
Time(long) - Constructor for class org.apache.reef.wake.time.Time
Initialize the internal timestamp.
Timeout - Class in org.apache.reef.examples.group.bgd.parameters
Timeout.
Timeout() - Constructor for class org.apache.reef.examples.group.bgd.parameters.Timeout
 
Timer - Class in org.apache.reef.examples.group.utils.timer
Timer.
Timer(Logger, String) - Constructor for class org.apache.reef.examples.group.utils.timer.Timer
 
Timer(String) - Constructor for class org.apache.reef.examples.group.utils.timer.Timer
 
Timer(Logger, Level, String) - Constructor for class org.apache.reef.examples.group.utils.timer.Timer
 
Timer - Class in org.apache.reef.tang.examples
 
Timer(int) - Constructor for class org.apache.reef.tang.examples.Timer
 
Timer - Interface in org.apache.reef.tang.examples.timer
 
Timer - Interface in org.apache.reef.wake.time.runtime
An interface for Timer.
Timer.Seconds - Class in org.apache.reef.tang.examples.timer
 
Timer.Seconds() - Constructor for class org.apache.reef.tang.examples.timer.Timer.Seconds
 
TimerImpl - Class in org.apache.reef.tang.examples.timer
 
TimerImpl(int) - Constructor for class org.apache.reef.tang.examples.timer.TimerImpl
 
TimerMock - Class in org.apache.reef.tang.examples.timer
 
TimerMock.TimerMockConf - Class in org.apache.reef.tang.examples.timer
 
TimerMock.TimerMockConf() - Constructor for class org.apache.reef.tang.examples.timer.TimerMock.TimerMockConf
 
TimerStage - Class in org.apache.reef.wake.impl
Stage that triggers an event handler periodically.
TimerStage(EventHandler<PeriodicEvent>, long) - Constructor for class org.apache.reef.wake.impl.TimerStage
Constructs a timer stage with no initial delay.
TimerStage(String, EventHandler<PeriodicEvent>, long) - Constructor for class org.apache.reef.wake.impl.TimerStage
Constructs a timer stage with no initial delay.
TimerStage(EventHandler<PeriodicEvent>, long, long) - Constructor for class org.apache.reef.wake.impl.TimerStage
Constructs a timer stage.
TimerStage(String, EventHandler<PeriodicEvent>, long, long) - Constructor for class org.apache.reef.wake.impl.TimerStage
Constructs a timer stage.
TimerV1 - Class in org.apache.reef.tang.examples
 
TimerV1(int) - Constructor for class org.apache.reef.tang.examples.TimerV1
 
timestamp - Variable in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
Deprecated.
timestamp - Variable in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
Deprecated.
timestamp - Variable in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
Deprecated.
timestamp - Variable in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
Deprecated.
TIMESTAMP - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
Tint - Class in org.apache.reef.tang.util
Tang Static Analytics Tool.
Tint() - Constructor for class org.apache.reef.tang.util.Tint
 
Tint(URL[]) - Constructor for class org.apache.reef.tang.util.Tint
 
Tint(URL[], boolean) - Constructor for class org.apache.reef.tang.util.Tint
 
toArray() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
toArray(T[]) - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
toAvro(Configuration) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
toAvro(ClassHierarchy) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
Serialize the ClassHierarchy into the AvroNode.
toAvro(String, String, List<AvroReefServiceInfo>) - Method in class org.apache.reef.webserver.AvroDriverInfoSerializer
Build AvroDriverInfo object.
toAvro(List<String>, Map<String, EvaluatorDescriptor>) - Method in class org.apache.reef.webserver.AvroEvaluatorInfoSerializer
Create AvroEvaluatorsInfo object.
toAvro(Map<String, EvaluatorDescriptor>, int, String) - Method in class org.apache.reef.webserver.AvroEvaluatorListSerializer
Build AvroEvaluatorList object.
toAvro(ParsedHttpRequest) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Convert from HttpServletRequest to AvroHttpRequest.
toAvro(String, String, List<AvroReefServiceInfo>) - Method in interface org.apache.reef.webserver.DriverInfoSerializer
Build AvroDriverInfo object from raw data.
toAvro(List<String>, Map<String, EvaluatorDescriptor>) - Method in interface org.apache.reef.webserver.EvaluatorInfoSerializer
Build AvroEvaluatorsInfo object from raw data.
toAvro(Map<String, EvaluatorDescriptor>, int, String) - Method in interface org.apache.reef.webserver.EvaluatorListSerializer
Build AvroEvaluatorList object.
toAvroActiveContext(ActiveContext) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroAllocatedEvaluator(AllocatedEvaluator) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroClosedContext(ClosedContext) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroCompletedEvaluator(CompletedEvaluator) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroCompletedTask(CompletedTask) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroContextBase(ContextBase) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroEvaluatorDescriptor(EvaluatorDescriptor) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroEvaluatorProcess(EvaluatorProcess) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroEvaluatorType(EvaluatorType) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroFailedContext(FailedContext) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroFailedEvaluator(FailedEvaluator) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroFailedTask(FailedTask) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroFailure(Failure) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroNodeDescriptor(NodeDescriptor) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroNodeDescriptorInRackDescriptor(String, String, InetSocketAddress) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroRackDescriptor(RackDescriptor) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroRunningTask(RunningTask) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroRuntimeStart(RuntimeStart) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroRuntimeStop(RuntimeStop) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroStartTime(StartTime) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroStopTime(StopTime) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroSuspendedTask(SuspendedTask) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toAvroTaskMessage(TaskMessage) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toBuilder() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
toBuilder() - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
toBuilder() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
toBuilder() - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
toBuilder() - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
toBuilder() - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
toBuilder() - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
toBuilder() - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
toBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
toBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
toBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
toBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
toBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
toBuilder() - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
toBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
toBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
toBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
toBuilder() - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
toBuilder() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
toBuilder() - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
toBuilder() - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
toByteArray(ClassHierarchy) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Serializes a ClassHierarchy as a byte[].
toByteArray(Configuration) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
toByteArray(Configuration) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Writes the Configuration to a byte[].
toByteArray(ClassHierarchy) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
toBytes(DefinedRuntimes) - Method in class org.apache.reef.javabridge.utils.DefinedRuntimesSerializer
Serializes DefinedRuntimes.
toBytes(Throwable) - Method in interface org.apache.reef.runtime.common.utils.ExceptionCodec
 
toBytes(AvroHttpRequest) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Convert AvroHttpRequest to bytes.
toCantInjectString() - Method in class org.apache.reef.tang.implementation.InjectionPlan
Algorithm for generating cant inject string:
toFile(ClassHierarchy, File) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Writes a ClassHierarchy into a file.
toFile(Configuration, File) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
toFile(Configuration, File) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Stores the given Configuration in the given File.
toFile(ClassHierarchy, File) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
toFile(AvroHttpRequest, File) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Conver AvroHttpRequest to a file.
toHtmlString(NamedParameterNode<?>, String) - Method in class org.apache.reef.tang.util.Tint
 
toHtmlString(ClassNode<?>, String) - Method in class org.apache.reef.tang.util.Tint
 
TOKEN - Static variable in class org.apache.reef.util.logging.LoggingScopeImpl
 
TOKENS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Topology - Interface in org.apache.reef.io.network.group.api.driver
A topology should implement the following interface so that it can work with the elastic group communication framework Currently we have two implementations 1.
TopologyChanges_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
TopologyChanges = 21;
TopologyClass - Class in org.apache.reef.io.network.group.impl.config.parameters
NamedParameter for topology implementation.
TopologyFactory - Class in org.apache.reef.io.network.group.impl.driver
A factory used to create Topology instance.
TopologyFailedEvaluatorHandler - Class in org.apache.reef.io.network.group.impl.driver
 
TopologyFailedEvaluatorHandler(CommunicationGroupDriverImpl) - Constructor for class org.apache.reef.io.network.group.impl.driver.TopologyFailedEvaluatorHandler
 
TopologyFailedTaskHandler - Class in org.apache.reef.io.network.group.impl.driver
 
TopologyFailedTaskHandler(CommunicationGroupDriverImpl) - Constructor for class org.apache.reef.io.network.group.impl.driver.TopologyFailedTaskHandler
 
TopologyMessageHandler - Class in org.apache.reef.io.network.group.impl.driver
 
TopologyMessageHandler(CommunicationGroupDriverImpl) - Constructor for class org.apache.reef.io.network.group.impl.driver.TopologyMessageHandler
 
TopologyRunningTaskHandler - Class in org.apache.reef.io.network.group.impl.driver
 
TopologyRunningTaskHandler(CommunicationGroupDriverImpl) - Constructor for class org.apache.reef.io.network.group.impl.driver.TopologyRunningTaskHandler
 
TopologySerializer - Class in org.apache.reef.io.network.group.impl.driver
Utility class for encoding a Topology into a byte array and vice versa.
TopologySetup_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
TopologySetup = 18;
TopologySimpleNode - Class in org.apache.reef.io.network.group.impl.driver
 
TopologySimpleNode(String) - Constructor for class org.apache.reef.io.network.group.impl.driver.TopologySimpleNode
 
TopologyUpdated_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
TopologyUpdated = 20;
TopologyUpdateWaitHandler - Class in org.apache.reef.io.network.group.impl.driver
 
TopologyUpdateWaitHandler(EStage<GroupCommunicationMessage>, Class<? extends Name<String>>, Class<? extends Name<String>>, String, int, String, int, String, byte[]) - Constructor for class org.apache.reef.io.network.group.impl.driver.TopologyUpdateWaitHandler
The handler will wait for all nodes to acquire topoLock and send TopologySetup msg.
toPrettyString() - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
toPrettyString() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
toShallowString() - Method in class org.apache.reef.tang.implementation.Constructor
 
toShallowString() - Method in class org.apache.reef.tang.implementation.InjectionFuturePlan
 
toShallowString() - Method in class org.apache.reef.tang.implementation.InjectionPlan
 
toShallowString() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
toShallowString() - Method in class org.apache.reef.tang.implementation.ListInjectionPlan
 
toShallowString() - Method in class org.apache.reef.tang.implementation.SetInjectionPlan
 
toShallowString() - Method in class org.apache.reef.tang.implementation.Subplan
 
toString() - Method in class org.apache.reef.client.DriverLauncher
 
toString() - Method in class org.apache.reef.client.JobMessage
 
toString() - Method in class org.apache.reef.client.LauncherStatus
 
toString() - Method in class org.apache.reef.common.AbstractFailure
 
toString() - Method in class org.apache.reef.examples.group.bgd.loss.LogisticLossFunction
 
toString() - Method in class org.apache.reef.examples.group.bgd.loss.SquaredErrorLossFunction
 
toString() - Method in class org.apache.reef.examples.group.bgd.loss.WeightedLogisticLossFunction
 
toString() - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
toString(EvaluatorRequest) - Static method in class org.apache.reef.io.data.loading.impl.AvroEvaluatorRequestSerializer
Serialize EvaluatorRequest.
toString() - Method in class org.apache.reef.io.data.loading.impl.DistributedDataSetPartition
 
toString() - Method in class org.apache.reef.io.data.loading.impl.NumberedSplit
 
toString() - Method in class org.apache.reef.io.network.group.impl.config.BroadcastOperatorSpec
 
toString() - Method in class org.apache.reef.io.network.group.impl.config.GatherOperatorSpec
 
toString() - Method in class org.apache.reef.io.network.group.impl.config.ReduceOperatorSpec
 
toString() - Method in class org.apache.reef.io.network.group.impl.config.ScatterOperatorSpec
 
toString() - Method in class org.apache.reef.io.network.group.impl.driver.IndexedMsg
 
toString() - Method in class org.apache.reef.io.network.group.impl.driver.MsgKey
 
toString() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
toString() - Method in class org.apache.reef.io.network.group.impl.GroupChangesImpl
 
toString() - Method in class org.apache.reef.io.network.group.impl.GroupCommunicationMessage
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastReceiver
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.BroadcastSender
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.GatherReceiver
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.GatherSender
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceReceiver
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.ReduceSender
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterReceiver
 
toString() - Method in class org.apache.reef.io.network.group.impl.operators.ScatterSender
 
toString() - Method in class org.apache.reef.io.network.group.impl.task.NodeStructImpl
 
toString() - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
toString() - Method in class org.apache.reef.io.network.group.impl.utils.ConcurrentCountingMap
 
toString() - Method in class org.apache.reef.io.network.group.impl.utils.CountingMap
 
toString() - Method in class org.apache.reef.io.network.util.Pair
 
toString() - Method in class org.apache.reef.io.network.util.StringIdentifier
Returns a string representation of the object.
toString() - Method in class org.apache.reef.io.TcpPortConfigurationProvider
 
toString() - Method in class org.apache.reef.io.Tuple
 
toString(SpecificRecord) - Static method in class org.apache.reef.io.watcher.util.WatcherAvroUtil
 
toString() - Method in class org.apache.reef.runtime.common.client.api.JobSubmissionEventImpl
 
toString() - Method in class org.apache.reef.runtime.common.client.RunningJobImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.catalog.NodeDescriptorImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.catalog.RackDescriptorImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.catalog.ResourceCatalogImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.context.ClosedContextImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.context.EvaluatorContext
 
toString() - Method in class org.apache.reef.runtime.common.driver.context.FailedContextImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.evaluator.AllocatedEvaluatorImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.evaluator.EvaluatorManager
 
toString() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.ResourceStatusEventImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.resourcemanager.RuntimeStatusEventImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.task.CompletedTaskImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.task.RunningTaskImpl
 
toString() - Method in class org.apache.reef.runtime.common.driver.task.SuspendedTaskImpl
 
toString() - Method in class org.apache.reef.runtime.common.files.FileResourceImpl
 
toString() - Method in class org.apache.reef.runtime.common.files.UnixJVMPathProvider
 
toString() - Method in class org.apache.reef.runtime.common.launch.REEFErrorHandler
 
toString() - Method in class org.apache.reef.runtime.common.launch.REEFUncaughtExceptionHandler
 
toString() - Method in class org.apache.reef.runtime.common.utils.RemoteManager
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.AmContainerSpec
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationID
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationResponse
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationState
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ApplicationSubmission
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Commands
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Credentials
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.ListApplicationResponse
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResourcesEntry
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.Resource
 
toString() - Method in class org.apache.reef.runtime.hdinsight.client.yarnrest.StringEntry
 
toString() - Method in class org.apache.reef.runtime.hdinsight.HDInsightJVMPathProvider
 
toString() - Method in class org.apache.reef.runtime.local.driver.ProcessContainer
 
toString(AvroMultiRuntimeDefinition) - Method in class org.apache.reef.runtime.multi.utils.MultiRuntimeDefinitionSerializer
Serializes MultiRuntimeDefinition.
toString() - Method in class org.apache.reef.runtime.yarn.client.unmanaged.YarnProxyUser
 
toString() - Method in interface org.apache.reef.tang.BindLocation
Implementations of BindLocation should override toString() so that it returns a human readable representation of the source of the configuration option in question.
toString(ClassHierarchy) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Serializes a ClassHierarchy as a String.
toString(Configuration) - Static method in class org.apache.reef.tang.Configurations
Return human-readable representation of the configuration.
toString(Configuration, boolean) - Static method in class org.apache.reef.tang.Configurations
Return human-readable representation of the configuration.
toString() - Method in class org.apache.reef.tang.examples.PrintTypeHierarchy
 
toString(Configuration) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
Produce a JSON string that represents given configuration.
toString(Configuration, boolean) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
Produce a JSON string that represents given configuration.
toString(Configuration) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Writes the Configuration as a String.
toString(ClassHierarchy) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
toString() - Method in class org.apache.reef.tang.implementation.Constructor
 
toString() - Method in class org.apache.reef.tang.implementation.java.JavaInstance
 
toString() - Method in class org.apache.reef.tang.implementation.StackBindLocation
 
toString() - Method in class org.apache.reef.tang.implementation.Subplan
 
toString() - Method in class org.apache.reef.tang.implementation.types.AbstractNode
 
toString() - Method in class org.apache.reef.tang.implementation.types.ClassNodeImpl
 
toString() - Method in class org.apache.reef.tang.implementation.types.ConstructorArgImpl
 
toString() - Method in class org.apache.reef.tang.implementation.types.ConstructorDefImpl
 
toString() - Method in class org.apache.reef.tang.implementation.types.NamedParameterNodeImpl
 
toString() - Method in interface org.apache.reef.tang.types.Node
 
toString(NamedParameterNode<?>) - Method in class org.apache.reef.tang.util.Tint
 
toString() - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
 
toString() - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
 
toString() - Method in exception org.apache.reef.tests.library.exceptions.UnexpectedTaskReturnValue
 
toString() - Method in class org.apache.reef.tests.TestDriverLauncher
 
toString() - Method in class org.apache.reef.util.Optional
 
toString() - Method in class org.apache.reef.wake.AbstractEStage
Get human readable representation of the class (used for logging).
toString() - Method in class org.apache.reef.wake.examples.join.TupleEvent
 
toString() - Method in interface org.apache.reef.wake.Identifier
Return a string representation of this object.
toString() - Method in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
 
toString() - Method in class org.apache.reef.wake.remote.impl.ProxyEventHandler
Returns a string representation of the object.
toString() - Method in class org.apache.reef.wake.remote.impl.RemoteEvent
Returns a string representation of this object.
toString() - Method in class org.apache.reef.wake.remote.impl.SocketRemoteIdentifier
Returns a string representation of the object.
toString() - Method in class org.apache.reef.wake.remote.impl.TransportEvent
 
toString() - Method in class org.apache.reef.wake.remote.impl.Tuple2
 
toString() - Method in class org.apache.reef.wake.remote.ports.RangeTcpPortProvider
 
toString() - Method in class org.apache.reef.wake.remote.transport.netty.NettyLink
 
toString() - Method in class org.apache.reef.wake.time.Time
 
toString(AvroDriverInfo) - Method in class org.apache.reef.webserver.AvroDriverInfoSerializer
Convert AvroDriverInfo object to JSON string.
toString(AvroEvaluatorsInfo) - Method in class org.apache.reef.webserver.AvroEvaluatorInfoSerializer
Convert AvroEvaluatorsInfo object to JSON string.
toString(AvroEvaluatorList) - Method in class org.apache.reef.webserver.AvroEvaluatorListSerializer
Convert AvroEvaluatorList to JSON string.
toString(AvroHttpRequest) - Method in class org.apache.reef.webserver.AvroHttpSerializer
Convert AvroHttpRequest to JSON String.
toString(AvroDriverInfo) - Method in interface org.apache.reef.webserver.DriverInfoSerializer
Convert AvroDriverInfo object to JSon string.
toString(AvroEvaluatorsInfo) - Method in interface org.apache.reef.webserver.EvaluatorInfoSerializer
Convert AvroEvaluatorsInfo object to JSON string.
toString(AvroEvaluatorList) - Method in interface org.apache.reef.webserver.EvaluatorListSerializer
Convert AvroEvaluatorList to JSon string.
toStringPairs() - Method in class org.apache.reef.tang.formats.ConfigurationModule
 
total - Variable in class org.apache.reef.webserver.AvroEvaluatorList
Deprecated.
toTextFile(ClassHierarchy, File) - Method in interface org.apache.reef.tang.ClassHierarchySerializer
Writes a ClassHierarchy into a text file.
toTextFile(Configuration, File) - Method in class org.apache.reef.tang.formats.AvroConfigurationSerializer
 
toTextFile(Configuration, File) - Method in interface org.apache.reef.tang.formats.ConfigurationSerializer
Stores the given Configuration in the given Text File.
toTextFile(ClassHierarchy, File) - Method in class org.apache.reef.tang.implementation.avro.AvroClassHierarchySerializer
 
TracingMonotonicMap<K,V> - Interface in org.apache.reef.tang.util
 
TracingMonotonicTreeMap<K,V> - Class in org.apache.reef.tang.util
 
TracingMonotonicTreeMap() - Constructor for class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
TRACKING_UI - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
TRACKING_URL - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
TrackingURLProvider - Interface in org.apache.reef.runtime.yarn.driver
Implement this interface to set the tracking URL reported to YARN.
Transport - Interface in org.apache.reef.wake.remote.transport
Transport for sending and receiving data.
TransportEvent - Class in org.apache.reef.wake.remote.impl
Event sent from a remote node.
TransportEvent(byte[], SocketAddress, SocketAddress) - Constructor for class org.apache.reef.wake.remote.impl.TransportEvent
Constructs an object event.
TransportEvent(byte[], Link<byte[]>) - Constructor for class org.apache.reef.wake.remote.impl.TransportEvent
Constructs the transport even object using link to.
TransportFactory - Interface in org.apache.reef.wake.remote.transport
Factory that creates a transport.
TransportRuntimeException - Exception in org.apache.reef.wake.remote.transport.exception
Transport runtime exception.
TransportRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.wake.remote.transport.exception.TransportRuntimeException
Constructs a new runtime transport exception with the specified detail message and cause.
TransportRuntimeException(String) - Constructor for exception org.apache.reef.wake.remote.transport.exception.TransportRuntimeException
Constructs a new runtime transport exception with the specified detail message.
TransportRuntimeException(Throwable) - Constructor for exception org.apache.reef.wake.remote.transport.exception.TransportRuntimeException
Constructs a new runtime transport exception with the specified cause.
Traversable<T extends Traversable<T>> - Interface in org.apache.reef.tang.types
 
TreeTopology - Class in org.apache.reef.io.network.group.impl.driver
Implements a tree topology with the specified Fan Out.
TreeTopologyFanOut - Class in org.apache.reef.io.network.group.impl.config.parameters
The fan out for the tree topology.
triggerHeartBeat() - Method in class org.apache.reef.task.HeartBeatTriggerManager
Immediately send a heartbeat message to the Driver.
Tuple<K,V> - Class in org.apache.reef.io
A key-value pair of elements.
Tuple(K, V) - Constructor for class org.apache.reef.io.Tuple
 
Tuple2<T1,T2> - Class in org.apache.reef.wake.remote.impl
Tuple with two values.
Tuple2(T1, T2) - Constructor for class org.apache.reef.wake.remote.impl.Tuple2
 
TupleEvent - Class in org.apache.reef.wake.examples.join
A tuple event consisting key and value pair.
TupleEvent(int, String) - Constructor for class org.apache.reef.wake.examples.join.TupleEvent
 
TupleKeyComparator<K,V> - Class in org.apache.reef.io.storage.util
 
TupleKeyComparator(Comparator<K>) - Constructor for class org.apache.reef.io.storage.util.TupleKeyComparator
 
tuples - Variable in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
Deprecated.
TupleSource - Class in org.apache.reef.wake.examples.join
A source class generating TupleEvent.
TupleSource(Observer<TupleEvent>, int, int, boolean) - Constructor for class org.apache.reef.wake.examples.join.TupleSource
 
TYPE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
type - Variable in class org.apache.reef.webserver.AvroEvaluatorInfo
Deprecated.
TYPE_ARCHIVE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
TYPE_FILE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
TYPE_PATTERN - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 

U

UnbindNSFromTask - Class in org.apache.reef.io.network.impl
 
UnbindNSFromTask(NetworkService<?>, IdentifierFactory) - Constructor for class org.apache.reef.io.network.impl.UnbindNSFromTask
 
uncaughtException(Thread, Throwable) - Method in class org.apache.reef.runtime.common.launch.REEFUncaughtExceptionHandler
 
uncaughtException(Thread, Throwable) - Method in class org.apache.reef.wake.impl.WakeUncaughtExceptionHandler
 
UnexpectedTaskReturnValue - Exception in org.apache.reef.tests.library.exceptions
Thrown by the Driver in a test if a Task returned an unexpected value.
UnexpectedTaskReturnValue(String, String) - Constructor for exception org.apache.reef.tests.library.exceptions.UnexpectedTaskReturnValue
 
UniformHistogram - Class in org.apache.reef.wake.metrics
An Histogram that implements uniform binning of numbers (>=0).
UniformHistogram(long, int) - Constructor for class org.apache.reef.wake.metrics.UniformHistogram
Constructs a histogram.
Unit - Annotation Type in org.apache.reef.tang.annotations
A TANG Unit consists of an outer class and some non-static inner classes.
UnixJVMPathProvider - Class in org.apache.reef.runtime.common.files
Supplies the java binary's path for Unix systems based on JAVA_HOME.
UnixJVMPathProvider() - Constructor for class org.apache.reef.runtime.common.files.UnixJVMPathProvider
 
UNKNOWN_HOST_NAME - Static variable in class org.apache.reef.wake.remote.impl.DefaultRemoteManagerImplementation
Indicates a hostname that isn't set or known.
UNKNOWN_HOST_NAME - Static variable in class org.apache.reef.wake.remote.transport.netty.NettyMessagingTransport
Indicates a hostname that isn't set or known.
UNMANAGED_AM - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
UNMANAGED_DRIVER - Static variable in class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
 
UnmanagedAmYarnClientConfiguration - Class in org.apache.reef.runtime.yarn.client.unmanaged
A ConfigurationModule for the YARN resource manager.
UnmanagedAmYarnClientConfiguration() - Constructor for class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnClientConfiguration
 
UnmanagedAmYarnDriverConfiguration - Class in org.apache.reef.runtime.yarn.client.unmanaged
Build configuration for REEF driver running in unmanaged mode under the YARN resource manager.
unregister(Identifier) - Method in interface org.apache.reef.io.naming.NamingRegistry
Unregister the given Identifier from the registry.
unregister(Identifier) - Method in class org.apache.reef.io.network.naming.LocalNameResolverImpl
 
unregister(Identifier) - Method in class org.apache.reef.io.network.naming.NameClient
Unregisters an identifier.
unregister(Identifier) - Method in class org.apache.reef.io.network.naming.NameRegistryClient
Unregisters an identifier.
unregister(Identifier) - Method in interface org.apache.reef.io.network.naming.NameServer
Unregisters an identifier locally.
unregister(Identifier) - Method in class org.apache.reef.io.network.naming.NameServerImpl
Unregisters an identifier locally.
unregisterConnectionFactory(Identifier) - Method in class org.apache.reef.io.network.impl.NetworkConnectionServiceImpl
 
unregisterConnectionFactory(Identifier) - Method in interface org.apache.reef.io.network.NetworkConnectionService
Unregisters a connectionFactory corresponding to the connectionFactoryId and removes the localEndPointID of the connection factory from NameServer.
unregisterId(Identifier) - Method in class org.apache.reef.io.network.impl.NetworkService
 
UnsafeClientConstructor - Class in org.apache.reef.runtime.hdinsight.client.sslhacks
A Client constructor that produces Clients that do not check SSL.
UnsafeHDInsightRuntimeConfiguration - Class in org.apache.reef.runtime.hdinsight.client
Same as HDInsightRuntimeConfiguration, but ignores SSL errors on submission.
UnsafeHDInsightRuntimeConfiguration() - Constructor for class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
 
UnsafeHDInsightRuntimeConfigurationStatic - Class in org.apache.reef.runtime.hdinsight.client
The static part of the UnsafeHDInsightRuntimeConfiguration.
UnsafeHDInsightRuntimeConfigurationStatic() - Constructor for class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfigurationStatic
 
Unstable - Annotation Type in org.apache.reef.annotations
Indicates that the code annotated this way is unstable, both in terms of its APIs and its functionality.
UnsuccessfulException - Exception in org.apache.reef.examples.scheduler.driver.exceptions
The operation was unsuccessful, for reasons stated in the message.
UnsuccessfulException(String) - Constructor for exception org.apache.reef.examples.scheduler.driver.exceptions.UnsuccessfulException
 
unwrap() - Method in exception org.apache.reef.exception.evaluator.ServiceRuntimeException
Upon catching a ServiceRuntimeException, the receiving code should call unwrap().
update(Set<GroupCommunicationMessage>) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
update(GroupCommunicationMessage) - Method in interface org.apache.reef.io.network.group.api.task.OperatorTopologyStruct
 
update(GroupCommunicationMessage) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
Updates the topology structure with the received message.
update(Set<GroupCommunicationMessage>) - Method in class org.apache.reef.io.network.group.impl.task.OperatorTopologyStructImpl
 
update(long) - Method in class org.apache.reef.wake.metrics.EWMA
Updates the EWMA with a new value.
update(long) - Method in interface org.apache.reef.wake.metrics.Histogram
Updates the value in this histogram.
update(long) - Method in class org.apache.reef.wake.metrics.UniformHistogram
Updates the value.
updateFailureOf(String) - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
This should remove state concerning neighboring tasks.
updateFailureOf(String) - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
updateTopology() - Method in interface org.apache.reef.io.network.group.api.task.CommunicationGroupClient
Asks the driver to update the topology of this communication group.
updateTopology() - Method in class org.apache.reef.io.network.group.impl.task.CommunicationGroupClientImpl
 
UpdateTopology_VALUE - Static variable in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
UpdateTopology = 19;
updatingTopology() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
updatingTopology() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
Called to denote that a UpdateTopology msg will.
updatingTopology() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
updatingTopology() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
upload(File) - Method in class org.apache.reef.runtime.yarn.client.uploader.JobFolder
Upload given file to the DFS.
uploadAsLocalResource(File, LocalResourceType) - Method in class org.apache.reef.runtime.yarn.client.uploader.JobFolder
Shortcut to first upload the file and then form a LocalResource for the YARN submission.
URL - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The URL of the hdinsight web service.
URL - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
The URL of the hdinsight web service.
usedSpace() - Method in class org.apache.reef.io.storage.local.LocalScratchSpace
 
usedSpace() - Method in interface org.apache.reef.io.storage.ScratchSpace
 
USER - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
USER_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightRuntimeConfiguration
The username to be used for connecting to hdinsight.
USER_NAME - Static variable in class org.apache.reef.runtime.hdinsight.client.UnsafeHDInsightRuntimeConfiguration
The username to be used for connecting to hdinsight.
UserCredentials - Interface in org.apache.reef.runtime.common
A holder object for REEF user credentials.
UserCredentialSecurityTokenProvider - Class in org.apache.reef.runtime.yarn.client
Reads security token from user credentials.
Utilities - Class in org.apache.reef.javabridge
CLR/Java bridge utilities.
Utils - Class in org.apache.reef.io.network.group.impl.utils
Utility class for group communications.
Utils - Class in org.apache.reef.io.network.util
Utility class for REEF IO network module.

V

validate() - Method in class org.apache.reef.tests.watcher.TestEventStream
This validation is called in WatcherTestDriver#RuntimeStopHandler, so RuntimeStop should not be guaranteed to be called before this.
ValidateConfiguration - Class in org.apache.reef.tang.util
 
ValidateConfiguration(File, File, File) - Constructor for class org.apache.reef.tang.util.ValidateConfiguration
 
ValidateConfiguration(String, File, File, File) - Constructor for class org.apache.reef.tang.util.ValidateConfiguration
 
ValidateConfiguration.ClassHierarchyIn - Class in org.apache.reef.tang.util
 
ValidateConfiguration.ClassHierarchyIn() - Constructor for class org.apache.reef.tang.util.ValidateConfiguration.ClassHierarchyIn
 
ValidateConfiguration.ConfigurationIn - Class in org.apache.reef.tang.util
 
ValidateConfiguration.ConfigurationIn() - Constructor for class org.apache.reef.tang.util.ValidateConfiguration.ConfigurationIn
 
ValidateConfiguration.ConfigurationOut - Class in org.apache.reef.tang.util
 
ValidateConfiguration.ConfigurationOut() - Constructor for class org.apache.reef.tang.util.ValidateConfiguration.ConfigurationOut
 
ValidateConfiguration.FileParser - Class in org.apache.reef.tang.util
 
ValidateConfiguration.Target - Class in org.apache.reef.tang.util
 
ValidateConfiguration.Target() - Constructor for class org.apache.reef.tang.util.ValidateConfiguration.Target
 
validatePlan() - Method in class org.apache.reef.tang.util.ValidateConfiguration
 
VALUE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
value - Variable in class org.apache.reef.tang.formats.avro.ConfigurationEntry
Deprecated.
value - Variable in class org.apache.reef.webserver.HeaderEntry
Deprecated.
VALUE_FIELD_NUMBER - Static variable in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
valueOf(String) - Static method in enum org.apache.reef.bridge.message.MessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.driver.evaluator.EvaluatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.driver.restart.DriverRestartState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.driver.restart.EvaluatorRestartState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.examples.group.bgd.ControlMessages
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.examples.group.broadcast.ControlMessages
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.io.network.group.impl.driver.TaskState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
 
valueOf(String) - Static method in enum org.apache.reef.io.PartitionSpec.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.io.watcher.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
 
valueOf(String) - Static method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
 
valueOf(String) - Static method in enum org.apache.reef.proto.ReefServiceProtos.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.reef.proto.ReefServiceProtos.State
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.reef.proto.ReefServiceProtos.State
 
valueOf(String) - Static method in enum org.apache.reef.runtime.common.driver.DriverStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.ContextState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.runtime.common.files.FileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.runtime.common.launch.ProcessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.vortex.protocol.mastertoworker.MasterToWorkerRequest.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.reef.vortex.protocol.workertomaster.WorkerToMasterReport.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.reef.bridge.message.MessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.driver.evaluator.EvaluatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.driver.restart.DriverRestartState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.driver.restart.EvaluatorRestartState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.examples.group.bgd.ControlMessages
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.examples.group.broadcast.ControlMessages
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.io.network.group.impl.driver.TaskState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.io.PartitionSpec.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.io.watcher.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.proto.ClientRuntimeProtocol.Signal
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.proto.ReefServiceProtos.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.runtime.common.driver.DriverStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.ContextState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.runtime.common.driver.evaluator.pojos.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.runtime.common.files.FileType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.runtime.common.launch.ProcessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.reef.tang.util.AbstractMonotonicMultiMap
 
values() - Method in class org.apache.reef.tang.util.MonotonicTreeMap
 
values() - Method in class org.apache.reef.tang.util.TracingMonotonicTreeMap
 
values() - Static method in enum org.apache.reef.vortex.protocol.mastertoworker.MasterToWorkerRequest.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.reef.vortex.protocol.workertomaster.WorkerToMasterReport.Type
Returns an array containing the constants of this enum type, in the order they are declared.
VCORE_SECONDS - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
VCORES - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
Vector - Interface in org.apache.reef.examples.group.utils.math
An interface for Linear Alebra Vectors.
VectorCodec - Class in org.apache.reef.examples.group.utils.math
Codec for the Vector type Uses Data*Stream.
VectorCodec() - Constructor for class org.apache.reef.examples.group.utils.math.VectorCodec
This class is instantiated by TANG.
VERSION_FIELD_NUMBER - Static variable in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
Vertex<T> - Class in org.apache.reef.wake.profiler
A vertex in the object graph.
Vertex(T, String, ConstructorDef<T>, Vertex<?>[]) - Constructor for class org.apache.reef.wake.profiler.Vertex
 
Vertex(T, ConstructorDef<T>, Vertex<?>[]) - Constructor for class org.apache.reef.wake.profiler.Vertex
 
Vertex(Object) - Constructor for class org.apache.reef.wake.profiler.Vertex
 
VISIBILITY - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.Constants
 
VISIBILITY_APPLICATION - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
VISIBILITY_PRIVATE - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
VISIBILITY_PUBLIC - Static variable in class org.apache.reef.runtime.hdinsight.client.yarnrest.LocalResource
 
visit(Node) - Method in class org.apache.reef.tang.util.walk.AbstractClassHierarchyNodeVisitor
Manually dispatch between different types of Nodes and call a proper visit() method.
visit(ClassNode<?>) - Method in class org.apache.reef.tang.util.walk.AbstractClassHierarchyNodeVisitor
Process current configuration node of ClassNode type.
visit(PackageNode) - Method in class org.apache.reef.tang.util.walk.AbstractClassHierarchyNodeVisitor
Process current configuration node of PackageNode type.
visit(NamedParameterNode<?>) - Method in class org.apache.reef.tang.util.walk.AbstractClassHierarchyNodeVisitor
Process current configuration node of NamedParameterNode type.
visit(InjectionPlan<?>) - Method in class org.apache.reef.tang.util.walk.AbstractInjectionPlanNodeVisitor
Manually dispatch between different types of injection plan objects and call proper visit() method.
visit(Constructor<?>) - Method in class org.apache.reef.tang.util.walk.AbstractInjectionPlanNodeVisitor
Process current injection plan node of Constructor type.
visit(JavaInstance<?>) - Method in class org.apache.reef.tang.util.walk.AbstractInjectionPlanNodeVisitor
Process current injection plan node of JavaInstance type.
visit(Subplan<?>) - Method in class org.apache.reef.tang.util.walk.AbstractInjectionPlanNodeVisitor
Process current injection plan node of Subplan type.
visit(T, T) - Method in interface org.apache.reef.tang.util.walk.EdgeVisitor
Process current edge of the configuration graph.
visit(ClassNode<?>) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
Process current class configuration node.
visit(PackageNode) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
Process current package configuration node.
visit(NamedParameterNode<?>) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
Process current configuration node for the named parameter.
visit(Node, Node) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizConfigVisitor
Process current edge of the configuration graph.
visit(Constructor<?>) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
Process current injection plan node of Constructor type.
visit(JavaInstance<?>) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
Process current injection plan node of JavaInstance type.
visit(Subplan<?>) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
Process current injection plan node of Subplan type.
visit(InjectionPlan<?>, InjectionPlan<?>) - Method in class org.apache.reef.tang.util.walk.graphviz.GraphvizInjectionPlanVisitor
Process current edge of the injection plan.
visit(T) - Method in interface org.apache.reef.tang.util.walk.NodeVisitor
Process current configuration node.
VORTEX_START - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Vortex Start.
VortexAggregateException - Exception in org.apache.reef.vortex.api
Exception thrown when an aggregate function fails.
VortexAggregateException(Throwable, List<?>) - Constructor for exception org.apache.reef.vortex.api.VortexAggregateException
 
VortexAggregateException(String, Throwable, List<?>) - Constructor for exception org.apache.reef.vortex.api.VortexAggregateException
 
VortexAggregateFunction<TOutput> - Interface in org.apache.reef.vortex.api
Typed user function for Local Aggregation.
VortexAggregateFuture<TInput,TOutput> - Class in org.apache.reef.vortex.api
The interface between user code and aggregation Tasklets.
VortexAggregateFuture(Executor, Map<Integer, TInput>, FutureCallback<AggregateResult<TInput, TOutput>>) - Constructor for class org.apache.reef.vortex.api.VortexAggregateFuture
 
VortexAggregatePolicy - Class in org.apache.reef.vortex.api
The policy for local aggregation on the VortexWorkers.
VortexAggregatePolicy.AggregatePolicyBuilder - Class in org.apache.reef.vortex.api
A Builder class for VortexAggregatePolicy.
VortexFunction<TInput,TOutput> - Interface in org.apache.reef.vortex.api
Typed user function.
VortexFuture<TOutput> - Class in org.apache.reef.vortex.api
The interface between user code and submitted task.
VortexFuture(Executor, VortexMaster, int) - Constructor for class org.apache.reef.vortex.api.VortexFuture
Creates a VortexFuture.
VortexFuture(Executor, VortexMaster, int, FutureCallback<TOutput>) - Constructor for class org.apache.reef.vortex.api.VortexFuture
Creates a VortexFuture with a callback.
VortexFutureDelegate<TOutput> - Interface in org.apache.reef.vortex.driver
Exposes functions to be called by the VortexMaster to note that a list of Tasklets associated with a Future has completed.
VortexJobConf - Class in org.apache.reef.vortex.driver
Helper class for building a configuration for Vortex.
VortexJobConf.Builder - Class in org.apache.reef.vortex.driver
Builder object to create a VortexJobConf.
VortexLauncher - Class in org.apache.reef.vortex.driver
Launches a Vortex Job.
VortexMaster - Interface in org.apache.reef.vortex.driver
The heart of Vortex.
VortexMasterConf - Class in org.apache.reef.vortex.driver
Vortex Master configuration.
VortexMasterConf() - Constructor for class org.apache.reef.vortex.driver.VortexMasterConf
 
VortexStart - Interface in org.apache.reef.vortex.api
The starting point of Vortex user thread.
VortexThreadPool - Class in org.apache.reef.vortex.api
Distributed thread pool.
VortexWorker - Class in org.apache.reef.vortex.evaluator
Receives commands from VortexMaster, executes them, and returns the results.
VortexWorker.DriverMessageHandler - Class in org.apache.reef.vortex.evaluator
Handle requests from Vortex Master.
VortexWorker.DriverMessageHandler() - Constructor for class org.apache.reef.vortex.evaluator.VortexWorker.DriverMessageHandler
 
VortexWorker.TaskCloseHandler - Class in org.apache.reef.vortex.evaluator
Shut down this worker.
VortexWorker.TaskCloseHandler() - Constructor for class org.apache.reef.vortex.evaluator.VortexWorker.TaskCloseHandler
 
VortexWorkerConf - Class in org.apache.reef.vortex.driver
Vortex Worker configuration.
VortexWorkerConf() - Constructor for class org.apache.reef.vortex.driver.VortexWorkerConf
 
VortexWorkerConf.NumOfThreads - Class in org.apache.reef.vortex.driver
Worker Threads.
VortexWorkerConf.NumOfThreads() - Constructor for class org.apache.reef.vortex.driver.VortexWorkerConf.NumOfThreads
 

W

waitForCompletion() - Method in class org.apache.reef.examples.suspend.SuspendClient
Wait for the job to complete.
waitForCompletion(int) - Method in class org.apache.reef.javabridge.generic.JobClient
Wait for the job driver to complete.
waitForStatus(long, LauncherStatus...) - Method in class org.apache.reef.client.DriverLauncher
Wait for one of the specified statuses of the REEF job.
waitForTopologyChanges(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommGroupNetworkHandler
 
waitForTopologyChanges(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommGroupNetworkHandlerImpl
 
waitForTopologySetup() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNodeStatus
 
waitForTopologySetup() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeStatusImpl
 
waitForTopologySetupOrFailure() - Method in interface org.apache.reef.io.network.group.api.driver.TaskNode
 
waitForTopologySetupOrFailure() - Method in class org.apache.reef.io.network.group.impl.driver.TaskNodeImpl
 
waitForTopologyUpdate(Class<? extends Name<String>>) - Method in interface org.apache.reef.io.network.group.api.task.CommGroupNetworkHandler
 
waitForTopologyUpdate(Class<? extends Name<String>>) - Method in class org.apache.reef.io.network.group.impl.task.CommGroupNetworkHandlerImpl
 
WakeParameters - Class in org.apache.reef.wake
Default parameters for Wake.
WakeParameters.ExecutorShutdownTimeout - Class in org.apache.reef.wake
Executor shutdown timeout.
WakeParameters.ExecutorShutdownTimeout() - Constructor for class org.apache.reef.wake.WakeParameters.ExecutorShutdownTimeout
 
WakeParameters.MaxFrameLength - Class in org.apache.reef.wake
Maximum frame length unit.
WakeParameters.MaxFrameLength() - Constructor for class org.apache.reef.wake.WakeParameters.MaxFrameLength
 
WakeParameters.RemoteSendTimeout - Class in org.apache.reef.wake
Remote send timeout.
WakeParameters.RemoteSendTimeout() - Constructor for class org.apache.reef.wake.WakeParameters.RemoteSendTimeout
 
WakeProfiler - Class in org.apache.reef.wake.profiler
A graphical profiler class that instruments Tang-based Wake applications.
WakeProfiler() - Constructor for class org.apache.reef.wake.profiler.WakeProfiler
 
WakeRemoteProtos - Class in org.apache.reef.wake.remote.proto
 
WakeRemoteProtos.WakeMessagePBuf - Class in org.apache.reef.wake.remote.proto
Protobuf type WakeMessagePBuf
WakeRemoteProtos.WakeMessagePBuf.Builder - Class in org.apache.reef.wake.remote.proto
Protobuf type WakeMessagePBuf
WakeRemoteProtos.WakeMessagePBufOrBuilder - Interface in org.apache.reef.wake.remote.proto
 
WakeRemoteProtos.WakeTuplePBuf - Class in org.apache.reef.wake.remote.proto
Protobuf type WakeTuplePBuf
WakeRemoteProtos.WakeTuplePBuf.Builder - Class in org.apache.reef.wake.remote.proto
Protobuf type WakeTuplePBuf
WakeRemoteProtos.WakeTuplePBufOrBuilder - Interface in org.apache.reef.wake.remote.proto
 
WakeRuntimeException - Exception in org.apache.reef.wake.exception
Wake runtime exception.
WakeRuntimeException(String, Throwable) - Constructor for exception org.apache.reef.wake.exception.WakeRuntimeException
Constructs a new runtime wake exception with the specified detail message and cause.
WakeRuntimeException(String) - Constructor for exception org.apache.reef.wake.exception.WakeRuntimeException
Constructs a new runtime stage exception with the specified detail message.
WakeRuntimeException(Throwable) - Constructor for exception org.apache.reef.wake.exception.WakeRuntimeException
Constructs a new runtime stage exception with the specified cause.
WakeSharedPool - Class in org.apache.reef.wake.impl
This implementation uses the fork join framework to reduce the cost of spawning events in stages.
WakeSharedPool(int) - Constructor for class org.apache.reef.wake.impl.WakeSharedPool
 
WakeSharedPool() - Constructor for class org.apache.reef.wake.impl.WakeSharedPool
 
WakeUncaughtExceptionHandler - Class in org.apache.reef.wake.impl
Exception handler for uncaught exceptions.
WakeUncaughtExceptionHandler() - Constructor for class org.apache.reef.wake.impl.WakeUncaughtExceptionHandler
 
WakeUncaughtExceptionHandler(EventHandler<Throwable>) - Constructor for class org.apache.reef.wake.impl.WakeUncaughtExceptionHandler
 
Walk - Class in org.apache.reef.tang.util.walk
Generic graph traversal.
wasClosed(String) - Method in class org.apache.reef.runtime.common.driver.evaluator.Evaluators
 
Watcher - Class in org.apache.reef.io.watcher
Subscribe events and transfer them as wrapping with corresponding avro classes.
Watcher.ContextActiveHandler - Class in org.apache.reef.io.watcher
 
Watcher.ContextActiveHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.ContextActiveHandler
 
Watcher.ContextClosedHandler - Class in org.apache.reef.io.watcher
 
Watcher.ContextClosedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.ContextClosedHandler
 
Watcher.ContextFailedHandler - Class in org.apache.reef.io.watcher
 
Watcher.ContextFailedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.ContextFailedHandler
 
Watcher.DriverRuntimeStartHandler - Class in org.apache.reef.io.watcher
 
Watcher.DriverRuntimeStartHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.DriverRuntimeStartHandler
 
Watcher.DriverRuntimeStopHandler - Class in org.apache.reef.io.watcher
 
Watcher.DriverRuntimeStopHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.DriverRuntimeStopHandler
 
Watcher.DriverStartHandler - Class in org.apache.reef.io.watcher
 
Watcher.DriverStartHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.DriverStartHandler
 
Watcher.DriverStopHandler - Class in org.apache.reef.io.watcher
 
Watcher.DriverStopHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.DriverStopHandler
 
Watcher.EvaluatorAllocatedHandler - Class in org.apache.reef.io.watcher
 
Watcher.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.EvaluatorAllocatedHandler
 
Watcher.EvaluatorCompletedHandler - Class in org.apache.reef.io.watcher
 
Watcher.EvaluatorCompletedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.EvaluatorCompletedHandler
 
Watcher.EvaluatorFailedHandler - Class in org.apache.reef.io.watcher
 
Watcher.EvaluatorFailedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.EvaluatorFailedHandler
 
Watcher.TaskCompletedHandler - Class in org.apache.reef.io.watcher
 
Watcher.TaskCompletedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.TaskCompletedHandler
 
Watcher.TaskFailedHandler - Class in org.apache.reef.io.watcher
 
Watcher.TaskFailedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.TaskFailedHandler
 
Watcher.TaskMessageHandler - Class in org.apache.reef.io.watcher
 
Watcher.TaskMessageHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.TaskMessageHandler
 
Watcher.TaskRunningHandler - Class in org.apache.reef.io.watcher
 
Watcher.TaskRunningHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.TaskRunningHandler
 
Watcher.TaskSuspendedHandler - Class in org.apache.reef.io.watcher
 
Watcher.TaskSuspendedHandler() - Constructor for class org.apache.reef.io.watcher.Watcher.TaskSuspendedHandler
 
WatcherAvroUtil - Class in org.apache.reef.io.watcher.util
 
WatcherConfiguration - Class in org.apache.reef.io.watcher
ConfigurationModule for Watcher.
WatcherTestDriver - Class in org.apache.reef.tests.watcher
Driver for WatcherTest.
WatcherTestDriver.ContextActivatedHandler - Class in org.apache.reef.tests.watcher
Handler for ActiveContext.
WatcherTestDriver.ContextActivatedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.ContextActivatedHandler
 
WatcherTestDriver.ContextFailedHandler - Class in org.apache.reef.tests.watcher
Handler for FailedContext.
WatcherTestDriver.ContextFailedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.ContextFailedHandler
 
WatcherTestDriver.DriverStartedHandler - Class in org.apache.reef.tests.watcher
Handler for StartTime.
WatcherTestDriver.DriverStartedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.DriverStartedHandler
 
WatcherTestDriver.EvaluatorAllocatedHandler - Class in org.apache.reef.tests.watcher
Handler for AllocatedEvaluator.
WatcherTestDriver.EvaluatorAllocatedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.EvaluatorAllocatedHandler
 
WatcherTestDriver.EvaluatorFailedHandler - Class in org.apache.reef.tests.watcher
Handler for FailedEvaluator.
WatcherTestDriver.EvaluatorFailedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.EvaluatorFailedHandler
 
WatcherTestDriver.RuntimeStopHandler - Class in org.apache.reef.tests.watcher
Handler for RuntimeStop.
WatcherTestDriver.RuntimeStopHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.RuntimeStopHandler
 
WatcherTestDriver.TaskFailedHandler - Class in org.apache.reef.tests.watcher
Handler for FailedTask.
WatcherTestDriver.TaskFailedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.TaskFailedHandler
 
WatcherTestDriver.TaskRunningHandler - Class in org.apache.reef.tests.watcher
Handler for RunningTask.
WatcherTestDriver.TaskRunningHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.TaskRunningHandler
 
WatcherTestDriver.TaskSuspendedHandler - Class in org.apache.reef.tests.watcher
Handler for SuspendedTask.
WatcherTestDriver.TaskSuspendedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestDriver.TaskSuspendedHandler
 
WatcherTestTask - Class in org.apache.reef.tests.watcher
Task for WatcherTest.
WatcherTestTask.TaskSuspendedHandler - Class in org.apache.reef.tests.watcher
Handler for SuspendEvent.
WatcherTestTask.TaskSuspendedHandler() - Constructor for class org.apache.reef.tests.watcher.WatcherTestTask.TaskSuspendedHandler
 
WeightedLogisticLossFunction - Class in org.apache.reef.examples.group.bgd.loss
Weighted logistic LossFunction.
WeightedLogisticLossFunction() - Constructor for class org.apache.reef.examples.group.bgd.loss.WeightedLogisticLossFunction
Trivial constructor.
Window - Class in org.apache.reef.examples.group.utils.math
Maintaining a fixed-size queue for sliding window operation.
Window(int) - Constructor for class org.apache.reef.examples.group.utils.math.Window
 
wireIn() - Method in class org.apache.reef.wake.examples.accumulate.CombinerStage
 
wireLeft() - Method in class org.apache.reef.wake.examples.join.BlockingJoin
 
wireLeft() - Method in class org.apache.reef.wake.examples.join.NonBlockingJoin
 
wireRight() - Method in class org.apache.reef.wake.examples.join.BlockingJoin
 
wireRight() - Method in class org.apache.reef.wake.examples.join.NonBlockingJoin
 
WORKER_CAPACITY - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Worker Cores.
WORKER_CORES - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Worker Cores.
WORKER_MEM - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Worker Memory.
WORKER_NUM - Static variable in class org.apache.reef.vortex.driver.VortexMasterConf
Number of Workers.
workerAllocated(VortexWorkerManager) - Method in interface org.apache.reef.vortex.driver.VortexMaster
Call this when a new worker is up and running.
workerPreempted(String) - Method in interface org.apache.reef.vortex.driver.VortexMaster
Call this when a worker is preempted.
workerReported(String, WorkerToMasterReports) - Method in interface org.apache.reef.vortex.driver.VortexMaster
Call this when a worker has reported back.
WorkerToMasterReport - Interface in org.apache.reef.vortex.protocol.workertomaster
The interface for a status report from the VortexWorker.
WorkerToMasterReport.Type - Enum in org.apache.reef.vortex.protocol.workertomaster
Type of WorkerToMasterReport.
WorkerToMasterReports - Class in org.apache.reef.vortex.protocol.workertomaster
Container for multiple WorkerToMasterReports.
WorkerToMasterReports(Collection<WorkerToMasterReport>) - Constructor for class org.apache.reef.vortex.protocol.workertomaster.WorkerToMasterReports
 
WorkingDirectoryTempFileCreator - Class in org.apache.reef.io
Creates temp files in a directory named "temp" within the current working directory.
WritableSerializer - Class in org.apache.reef.io.data.loading.impl
A serializer class that serializes Writables into String using the below Codec that encodes and decodes Writables By default this stores the class name in the serialized form so that the specific type can be instantiated on de-serialization.
write(DataOutput) - Method in class org.apache.reef.io.checkpoint.fs.FSCheckpointID
 
write(T) - Method in interface org.apache.reef.io.network.Connection
Writes a message to the connection.
write(List<T>) - Method in interface org.apache.reef.io.network.Connection
Writes a list of messages to the connection.
write(int) - Method in class org.apache.reef.io.storage.FramingOutputStream
 
write(byte[]) - Method in class org.apache.reef.io.storage.FramingOutputStream
 
write(byte[], int, int) - Method in class org.apache.reef.io.storage.FramingOutputStream
 
write(T) - Method in interface org.apache.reef.wake.remote.transport.Link
Asynchronously writes the value to this link.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.reef.wake.remote.transport.netty.ChunkedReadWriteHandler
Thread-safe since there is no shared instance state.
write(T) - Method in class org.apache.reef.wake.remote.transport.netty.NettyLink
Writes the message to this link.
writeExternal(ObjectOutput) - Method in class org.apache.reef.bridge.message.Acknowledgement
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.bridge.message.BridgeInterop
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.bridge.message.Header
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.bridge.message.Protocol
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.bridge.message.SetupBridge
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.bridge.message.SystemOnStart
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.data.loading.avro.AvroEvaluatorRequest
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingAssignment
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupRequest
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingLookupResponse
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingRegisterRequest
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.network.naming.avro.AvroNamingUnRegisterRequest
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.common.AvroFailure
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptor
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroNodeDescriptorInRackDescriptor
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.catalog.AvroRackDescriptor
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.context.AvroActiveContext
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.context.AvroClosedContext
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextBase
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.context.AvroContextMessage
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.context.AvroFailedContext
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroAllocatedEvaluator
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroCompletedEvaluator
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorDescriptor
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroEvaluatorProcess
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.evaluator.AvroFailedEvaluator
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.task.AvroCompletedTask
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.task.AvroFailedTask
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.task.AvroRunningTask
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.task.AvroSuspendedTask
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.driver.task.AvroTaskMessage
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStartTime
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.wake.time.event.AvroStopTime
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStart
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.io.watcher.wake.time.runtime.event.AvroRuntimeStop
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.javabridge.avro.AvroFailedTask
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.javabridge.avro.DefinedRuntimes
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroAppSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroJobSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalAppSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroLocalJobSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnAppSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.reef.bridge.client.avro.AvroYarnJobSubmissionParameters
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorControl
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorLaunch
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.runtime.mesos.util.EvaluatorRelease
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroMultiRuntimeDefinition
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.runtime.multi.utils.avro.AvroRuntimeDefinition
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.formats.avro.AvroConfiguration
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.formats.avro.ConfigurationEntry
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.implementation.avro.AvroClassNode
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorArg
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.implementation.avro.AvroConstructorDef
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.implementation.avro.AvroNamedParameterNode
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.implementation.avro.AvroNode
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.tang.implementation.avro.AvroPackageNode
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroDriverInfo
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroEvaluatorEntry
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroEvaluatorInfo
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroEvaluatorList
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroEvaluatorsInfo
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroHttpRequest
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.AvroReefServiceInfo
 
writeExternal(ObjectOutput) - Method in class org.apache.reef.webserver.HeaderEntry
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupCommMessage
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.io.network.proto.ReefNetworkGroupCommProtos.GroupMessageBody
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSMessagePBuf
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.io.network.proto.ReefNetworkServiceProtos.NSRecordPBuf
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ClientRuntimeProtocol.JobControlProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.AddContextProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextControlProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.ContextMessageProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.DoneEvaluatorProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorControlProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.EvaluatorHeartbeatProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.KillEvaluatorProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.RemoveContextProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StartTaskProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopEvaluatorProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.StopTaskProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.EvaluatorRuntimeProtocol.SuspendTaskProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.REEFProtocol.REEFMessage
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto.ContextMessageProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.ContextStatusProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.EvaluatorStatusProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.JobStatusProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.RuntimeErrorProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto.TaskMessageProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.proto.ReefServiceProtos.TaskStatusProto
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ClassNode
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorArg
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.ConstructorDef
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.NamedParameterNode
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.Node
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.ClassHierarchyProto.PackageNode
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Constructor
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.InjectionPlan
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Instance
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.tang.proto.InjectionPlanProto.Subplan
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeMessagePBuf
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.wake.remote.proto.WakeRemoteProtos.WakeTuplePBuf
 
writeTo(CodedOutputStream) - Method in class org.apache.reef.wake.test.proto.TestProtos.TestEventPBuf
 
writeToEvaluatorLog(String) - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogAppendReaderWriter
Writes a formatted entry (addition or removal) for an Evaluator ID into the DFS evaluator log.
writeToEvaluatorLog(String) - Method in class org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogOverwriteReaderWriter
Writes a formatted entry (addition or removal) for an Evaluator ID into the DFS evaluator log.
writeToEvaluatorLog(String) - Method in interface org.apache.reef.runtime.yarn.driver.restart.DFSEvaluatorLogReaderWriter
Writes a formatted entry (addition or removal) for an Evaluator ID into the DFS evaluator log.

Y

YARN_HEARTBEAT_INTERVAL - Static variable in class org.apache.reef.runtime.hdinsight.client.HDInsightDriverConfiguration
 
YARN_HEARTBEAT_INTERVAL - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnDriverConfiguration
 
YARN_HEARTBEAT_INTERVAL - Static variable in class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
YARN_PRIORITY - Static variable in class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
 
YARN_PRIORITY - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnClientConfiguration
 
YARN_PRIORITY - Static variable in class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
 
YARN_QUEUE_NAME - Static variable in class org.apache.reef.runtime.yarn.client.ExtensibleYarnClientConfiguration
 
YARN_QUEUE_NAME - Static variable in class org.apache.reef.runtime.yarn.client.unmanaged.UnmanagedAmYarnClientConfiguration
 
YARN_QUEUE_NAME - Static variable in class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
 
YarnBootstrapREEFLauncher - Class in org.apache.reef.bridge.client
This is a bootstrap launcher for YARN for submission from C#.
YarnClasspathProvider - Class in org.apache.reef.runtime.yarn
Access to the classpath according to the REEF file system standard.
YarnClientConfiguration - Class in org.apache.reef.runtime.yarn.client
A ConfigurationModule for the YARN resource manager.
YarnClientConfiguration() - Constructor for class org.apache.reef.runtime.yarn.client.YarnClientConfiguration
 
YarnConfigurationConstructor - Class in org.apache.reef.runtime.yarn.util
An external constructor that creates YarnConfiguration instances.
YarnContainerRequestHandler - Interface in org.apache.reef.runtime.yarn.driver
Interface to request containers from YARN using AMRMClient.ContainerRequest requests.
YarnContainerRequestHandlerImpl - Class in org.apache.reef.runtime.yarn.driver
Side-channel to request containers from YARN using AMRMClient.ContainerRequest requests.
YarnDriverConfiguration - Class in org.apache.reef.runtime.yarn.client
Additional YARN-Specific configuration options to be merged with DriverConfiguration.
YarnDriverConfiguration() - Constructor for class org.apache.reef.runtime.yarn.client.YarnDriverConfiguration
 
YarnDriverConfiguration - Class in org.apache.reef.runtime.yarn.driver
ConfigurationModule to create YARN Driver configurations.
YarnDriverConfiguration() - Constructor for class org.apache.reef.runtime.yarn.driver.YarnDriverConfiguration
 
YarnDriverConfigurationProviderImpl - Class in org.apache.reef.runtime.yarn.client
Default driver configuration provider for yarn runtime.
YarnDriverRestartConfiguration - Class in org.apache.reef.runtime.yarn.driver
Use this ConfigurationModule to configure YARN-specific Restart options for the driver.
YarnDriverRestartConfiguration() - Constructor for class org.apache.reef.runtime.yarn.driver.YarnDriverRestartConfiguration
 
YarnDriverRuntimeRestartManager - Class in org.apache.reef.runtime.yarn.driver
The implementation of restart manager for YARN.
YarnEvaluatorPreserver - Class in org.apache.reef.runtime.yarn.driver.parameters
The Evaluator Preserver to use on YARN, defaults to DFS.
YarnHeartbeatPeriod - Class in org.apache.reef.runtime.yarn.driver.parameters
How often we talk to YARN.
YarnHeartbeatPeriod() - Constructor for class org.apache.reef.runtime.yarn.driver.parameters.YarnHeartbeatPeriod
 
YarnJobSubmissionClient - Class in org.apache.reef.bridge.client
The Java-side of the C# YARN Job Submission API.
yarnJobSubmissionParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroYarnClusterJobSubmissionParameters
Deprecated.
YarnProxyUser - Class in org.apache.reef.runtime.yarn.client.unmanaged
A holder class for the proxy UserGroupInformation object required for Unmanaged YARN Application Master in REEF-on-REEF or REEF-on-Spark mode.
YARNResourceLaunchHandler - Class in org.apache.reef.runtime.yarn.driver
Resource launch handler for YARN.
YARNResourceReleaseHandler - Class in org.apache.reef.runtime.yarn.driver
ResourceReleaseHandler for YARN.
YarnResourceRequestHandler - Class in org.apache.reef.runtime.yarn.driver
Accepts resource requests from the REEF layer, translates them into requests for YARN and hands them to the appropriate handler for those.
yarnRuntimeAppParameters - Variable in class org.apache.reef.reef.bridge.client.avro.AvroMultiRuntimeAppSubmissionParameters
Deprecated.
YARNRuntimeStartHandler - Class in org.apache.reef.runtime.yarn.driver
Handler of RuntimeStart for the YARN Runtime.
YARNRuntimeStartHandler(YarnContainerManager) - Constructor for class org.apache.reef.runtime.yarn.driver.YARNRuntimeStartHandler
 
YARNRuntimeStopHandler - Class in org.apache.reef.runtime.yarn.driver
Shuts down the YARN resource manager.
YarnSubmissionHelper - Class in org.apache.reef.runtime.yarn.client
Helper code that wraps the YARN Client API for our purposes.
YarnSubmissionHelper(YarnConfiguration, REEFFileNames, ClasspathProvider, YarnProxyUser, SecurityTokenProvider, boolean, List<String>) - Constructor for class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
 
YarnSubmissionHelper(YarnConfiguration, REEFFileNames, ClasspathProvider, YarnProxyUser, SecurityTokenProvider, boolean) - Constructor for class org.apache.reef.runtime.yarn.client.YarnSubmissionHelper
 
YarnTypes - Class in org.apache.reef.runtime.yarn.util
Helper class that creates the various records in the YARN API.
YarnUtilities - Class in org.apache.reef.runtime.yarn.util
A helper class for YARN applications.
YES - Static variable in class org.apache.reef.runtime.common.client.parameters.ClientPresent
 
A B C D E F G H I J K L M N O P Q R S T U V W Y 

Copyright © 2017 The Apache Software Foundation. All rights reserved.