- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- getReduceFunction() - Method in interface org.apache.reef.io.network.group.api.operators.ReduceScatter
-
- 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
-
- 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.
- 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
-
- NumEvaluatorsToSubmit - Class in org.apache.reef.tests.evaluator.failure.parameters
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- setEvaluatorReregistered(String) - Method in class org.apache.reef.driver.restart.DriverRestartManager
-
- 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
-
- 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
-
- 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
-